You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by at...@apache.org on 2013/11/07 17:01:29 UTC

[1/3] AMBARI-3714 [perf] UI should only request data from master host-components. (atkach)

Updated Branches:
  refs/heads/trunk 8944c1db3 -> 5820bd7c6


http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/5820bd7c/ambari-web/app/controllers/global/update_controller.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/controllers/global/update_controller.js b/ambari-web/app/controllers/global/update_controller.js
index d3a46ed..381a4b5 100644
--- a/ambari-web/app/controllers/global/update_controller.js
+++ b/ambari-web/app/controllers/global/update_controller.js
@@ -38,7 +38,7 @@ App.UpdateController = Em.Controller.extend({
   updateAll:function(){
     if(this.get('isWorking')) {
       App.updater.run(this, 'updateHostConditionally', 'isWorking');
-      App.updater.run(this, 'updateServiceMetric', 'isWorking');
+      App.updater.run(this, 'updateServiceMetric', 'isWorking', App.componentsUpdateInterval);
       App.updater.run(this, 'graphsUpdate', 'isWorking');
       if (App.supports.hostOverrides) {
         App.updater.run(this, 'updateComponentConfig', 'isWorking');
@@ -100,7 +100,7 @@ App.UpdateController = Em.Controller.extend({
     self.set('isUpdated', false);
 
     var conditionalFields = [];
-    var initialFields = ['components/host_components/HostRoles/state'];
+    var initialFields = [];
     var services = [
         {
             name: 'FLUME',
@@ -117,7 +117,7 @@ App.UpdateController = Em.Controller.extend({
     ];
     services.forEach(function(service) {
         if (App.Service.find(service.name)) {
-            conditionalFields.push("components/host_components/metrics/" + service.urlParam);
+            conditionalFields.push("host_components/metrics/" + service.urlParam);
         }
     });
     var conditionalFieldsString = conditionalFields.length > 0 ? ',' + conditionalFields.join(',') : '';
@@ -125,28 +125,30 @@ App.UpdateController = Em.Controller.extend({
     var methodStartTs = new Date().getTime();
     var testUrl = App.get('isHadoop2Stack') ? '/data/dashboard/HDP2/services.json':'/data/dashboard/services.json';
 
-    var realUrl = '/services?fields=components/ServiceComponentInfo,' +
-      'components/host_components/metrics/jvm/memHeapUsedM,' +
-      'components/host_components/metrics/jvm/memHeapCommittedM,' +
-      'components/host_components/metrics/mapred/jobtracker/trackers_decommissioned,' +
-      'components/host_components/metrics/cpu/cpu_wio,' +
-      'components/host_components/metrics/rpc/RpcQueueTime_avg_time,' +
-      'components/host_components/metrics/dfs/FSNamesystem/HAState,' +
-      'components/host_components/metrics/dfs/FSNamesystem/CapacityUsed,' +
-      'components/host_components/metrics/dfs/FSNamesystem/CapacityTotal,' +
-      'components/host_components/metrics/dfs/FSNamesystem/CapacityRemaining,' +
-      'components/host_components/metrics/dfs/FSNamesystem/BlocksTotal,' +
-      'components/host_components/metrics/dfs/FSNamesystem/CorruptBlocks,' +
-      'components/host_components/metrics/dfs/FSNamesystem/MissingBlocks,' +
-      'components/host_components/metrics/dfs/FSNamesystem/UnderReplicatedBlocks,' +
-      'components/host_components/metrics/dfs/namenode/Version,' +
-      'components/host_components/metrics/dfs/namenode/LiveNodes,' +
-      'components/host_components/metrics/dfs/namenode/DeadNodes,' +
-      'components/host_components/metrics/dfs/namenode/DecomNodes,' +
-      'components/host_components/metrics/dfs/namenode/TotalFiles,' +
-      'components/host_components/metrics/dfs/namenode/UpgradeFinalized,' +
-      'components/host_components/metrics/dfs/namenode/Safemode,' +
-      'components/host_components/metrics/runtime/StartTime' +
+    var realUrl = '/components/?ServiceComponentInfo/category=MASTER&fields=' +
+      'ServiceComponentInfo,' +
+      'host_components/HostRoles/state,' +
+      'host_components/metrics/jvm/memHeapUsedM,' +
+      'host_components/metrics/jvm/memHeapCommittedM,' +
+      'host_components/metrics/mapred/jobtracker/trackers_decommissioned,' +
+      'host_components/metrics/cpu/cpu_wio,' +
+      'host_components/metrics/rpc/RpcQueueTime_avg_time,' +
+      'host_components/metrics/dfs/FSNamesystem/HAState,' +
+      'host_components/metrics/dfs/FSNamesystem/CapacityUsed,' +
+      'host_components/metrics/dfs/FSNamesystem/CapacityTotal,' +
+      'host_components/metrics/dfs/FSNamesystem/CapacityRemaining,' +
+      'host_components/metrics/dfs/FSNamesystem/BlocksTotal,' +
+      'host_components/metrics/dfs/FSNamesystem/CorruptBlocks,' +
+      'host_components/metrics/dfs/FSNamesystem/MissingBlocks,' +
+      'host_components/metrics/dfs/FSNamesystem/UnderReplicatedBlocks,' +
+      'host_components/metrics/dfs/namenode/Version,' +
+      'host_components/metrics/dfs/namenode/LiveNodes,' +
+      'host_components/metrics/dfs/namenode/DeadNodes,' +
+      'host_components/metrics/dfs/namenode/DecomNodes,' +
+      'host_components/metrics/dfs/namenode/TotalFiles,' +
+      'host_components/metrics/dfs/namenode/UpgradeFinalized,' +
+      'host_components/metrics/dfs/namenode/Safemode,' +
+      'host_components/metrics/runtime/StartTime' +
       conditionalFieldsString;
 
     var servicesUrl = isInitialLoad ? this.getUrl(testUrl, realUrl + initialFieldsString) : this.getUrl(testUrl, realUrl);

http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/5820bd7c/ambari-web/app/mappers/hosts_mapper.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/mappers/hosts_mapper.js b/ambari-web/app/mappers/hosts_mapper.js
index 32171d0..e02d67b 100644
--- a/ambari-web/app/mappers/hosts_mapper.js
+++ b/ambari-web/app/mappers/hosts_mapper.js
@@ -55,6 +55,7 @@ App.hostsMapper = App.QuickDataMapper.create({
       var result = [];
       var hostIds = {};
       var cacheData = App.cache['Hosts'];
+      var currentHostStatuses = {};
 
       json.items.forEach(function (item) {
         //receive host_components when added hosts
@@ -64,8 +65,11 @@ App.hostsMapper = App.QuickDataMapper.create({
         }, this);
 
         hostIds[item.Hosts.host_name] = true;
+        currentHostStatuses[item.Hosts.host_name] = item.Hosts.host_status;
         result.push(this.parseIt(item, this.config));
       }, this);
+
+      App.cache['previousHostStatuses'] = currentHostStatuses;
       result = this.sortByPublicHostName(result);
 
       var clientHosts = App.Host.find();

http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/5820bd7c/ambari-web/app/mappers/server_data_mapper.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/mappers/server_data_mapper.js b/ambari-web/app/mappers/server_data_mapper.js
index e77a261..0762a6b 100644
--- a/ambari-web/app/mappers/server_data_mapper.js
+++ b/ambari-web/app/mappers/server_data_mapper.js
@@ -20,7 +20,9 @@ var App = require('app');
 
 //initialize common cache container for mappers
 App.cache = {
-  'Hosts': {}
+  'Hosts': {},
+  'previousHostStatuses': {},
+  'previousComponentStatuses': {}
 };
 
 App.ServerDataMapper = Em.Object.extend({

http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/5820bd7c/ambari-web/app/mappers/service_mapper.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/mappers/service_mapper.js b/ambari-web/app/mappers/service_mapper.js
index fe6e215..53bbf41 100644
--- a/ambari-web/app/mappers/service_mapper.js
+++ b/ambari-web/app/mappers/service_mapper.js
@@ -175,55 +175,136 @@ App.servicesMapper = App.QuickDataMapper.create({
     }
     console.time('App.servicesMapper execution time');
     if (json.items) {
+
+      // Host components
+      var hostComponents = [];
+      var services = [];
+      var previousComponentStatuses = App.cache['previousComponentStatuses'];
+      /**
+       * services contains constructed service-components structure from components array
+       */
+      json.items.forEach(function (component) {
+        var service = services.findProperty('ServiceInfo.service_name', component.ServiceComponentInfo.service_name);
+        var serviceName = component.ServiceComponentInfo.service_name;
+        if (!service) {
+          service = {
+            ServiceInfo: {
+              service_name: component.ServiceComponentInfo.service_name
+            },
+            host_components: [],
+            components: []
+          };
+          services.push(service);
+        }
+        service.components.push(component);
+        component.host_components.forEach(function (host_component) {
+          host_component.id = host_component.HostRoles.component_name + "_" + host_component.HostRoles.host_name;
+          previousComponentStatuses[host_component.id] = host_component.HostRoles.state;
+          if (host_component.HostRoles.component_name == "HBASE_MASTER") {
+            this.config3.ha_status = 'metrics.hbase.master.IsActiveMaster';
+          }
+          var comp = this.parseIt(host_component, this.config3);
+          comp.service_id = serviceName;
+          hostComponents.push(comp);
+        }, this);
+      }, this);
+
+      //load master components to model
+      App.store.loadMany(this.get('model3'), hostComponents);
+
       var result = [];
-      json.items.forEach(function (item) {
-        var finalConfig = jQuery.extend({}, this.config);
+
+      //establish relations between services and host-components
+      var serviceComponents = {},
+          masterComponents = [],
+          datanodeHosts = [],
+          taskTrackerHosts = [],
+          hbaseRegionserverHosts = [],
+          nodemanagerHosts = [],
+          yarnClientHosts = [],
+          mapreduce2ClientHosts = [];
+      App.HostComponent.find().forEach(function (hostComponent) {
+        if (serviceComponents[hostComponent.get('service.id')]) {
+          serviceComponents[hostComponent.get('service.id')].hostComponents.push(hostComponent.get('id'));
+        } else {
+          serviceComponents[hostComponent.get('service.id')] = {
+            hostComponents: [hostComponent.get('id')]
+          }
+        }
+
+        if (hostComponent.get('isMaster')) {
+          masterComponents.push(hostComponent);
+        }
+
+        switch (hostComponent.get('componentName')) {
+          case 'DATANODE':
+            datanodeHosts.push(hostComponent.get('host.id'));
+            break;
+          case 'TASKTRACKER':
+            taskTrackerHosts.push(hostComponent.get('host.id'));
+            break;
+          case 'HBASE_REGIONSERVER':
+            hbaseRegionserverHosts.push(hostComponent.get('host.id'));
+            break;
+          case 'NODEMANAGER':
+            nodemanagerHosts.push(hostComponent.get('host.id'));
+            break;
+          case 'YARN_CLIENT':
+            yarnClientHosts.push(hostComponent.get('host.id'));
+            break;
+          case 'MAPREDUCE2_CLIENT':
+            mapreduce2ClientHosts.push(hostComponent.get('host.id'));
+            break;
+        }
+      });
+      //parse service metrics from components
+      services.forEach(function (item) {
         var finalJson = [];
-        item.host_components = [];
-        item.components.forEach(function (component) {
-          component.host_components.forEach(function (host_component) {
-            host_component.id = host_component.HostRoles.component_name + "_" + host_component.HostRoles.host_name;
-            item.host_components.push(host_component.id);
-          }, this);
-        }, this);
+        item.host_components = serviceComponents[item.ServiceInfo.service_name].hostComponents;
         item.host_components.sort();
 
         if (item && item.ServiceInfo && item.ServiceInfo.service_name == "HDFS") {
           finalJson = this.hdfsMapper(item);
+          finalJson.data_nodes = datanodeHosts;
           finalJson.rand = Math.random();
           result.push(finalJson);
           App.store.load(App.HDFSService, finalJson);
-        }else if (item && item.ServiceInfo && item.ServiceInfo.service_name == "MAPREDUCE") {
+        } else if (item && item.ServiceInfo && item.ServiceInfo.service_name == "MAPREDUCE") {
           finalJson = this.mapreduceMapper(item);
+          finalJson.task_trackers = taskTrackerHosts;
           finalJson.rand = Math.random();
           result.push(finalJson);
           App.store.load(App.MapReduceService, finalJson);
-        }else if (item && item.ServiceInfo && item.ServiceInfo.service_name == "HBASE") {
+        } else if (item && item.ServiceInfo && item.ServiceInfo.service_name == "HBASE") {
           finalJson = this.hbaseMapper(item);
+          finalJson.region_servers = hbaseRegionserverHosts;
           finalJson.rand = Math.random();
           result.push(finalJson);
           App.store.load(App.HBaseService, finalJson);
-        }else if (item && item.ServiceInfo && item.ServiceInfo.service_name == "FLUME") {
+        } else if (item && item.ServiceInfo && item.ServiceInfo.service_name == "FLUME") {
           finalJson = this.flumeMapper(item);
           finalJson.rand = Math.random();
           result.push(finalJson);
-          if(finalJson.nodeObjs){
-            finalJson.nodeObjs.forEach(function(no){
+          if (finalJson.nodeObjs) {
+            finalJson.nodeObjs.forEach(function (no) {
               App.store.load(App.FlumeNode, no);
             });
           }
           App.store.load(App.FlumeService, finalJson);
-        }else if (item && item.ServiceInfo && item.ServiceInfo.service_name == "YARN") {
+        } else if (item && item.ServiceInfo && item.ServiceInfo.service_name == "YARN") {
           finalJson = this.yarnMapper(item);
+          finalJson.node_manager_nodes = nodemanagerHosts;
+          finalJson.yarn_client_nodes = yarnClientHosts;
           finalJson.rand = Math.random();
           result.push(finalJson);
           App.store.load(App.YARNService, finalJson);
-        }else if (item && item.ServiceInfo && item.ServiceInfo.service_name == "MAPREDUCE2") {
+        } else if (item && item.ServiceInfo && item.ServiceInfo.service_name == "MAPREDUCE2") {
           finalJson = this.mapreduce2Mapper(item);
+          finalJson.map_reduce2_clients = mapreduce2ClientHosts;
           finalJson.rand = Math.random();
           result.push(finalJson);
           App.store.load(App.MapReduce2Service, finalJson);
-        }else {
+        } else {
           finalJson = this.parseIt(item, this.config);
           finalJson.rand = Math.random();
           this.mapQuickLinks(finalJson, item);
@@ -231,73 +312,19 @@ App.servicesMapper = App.QuickDataMapper.create({
         }
       }, this);
 
-
       result = this.sortByOrder(this.get('servicesSortOrder'), result);
-      App.store.loadMany(this.get('model'), result);
-
-      // Host components
-      result = [];
-      var hostComponentsMap = {};
-      json.items.forEach(function(item){
-        item.components.forEach(function(component){
-          var service = component.ServiceComponentInfo.service_name;
-          component.host_components.forEach(function(host_component){
-            if(host_component.HostRoles.component_name == "HBASE_MASTER"){
-              this.config3.ha_status = 'metrics.hbase.master.IsActiveMaster';
-            }
-            var comp = this.parseIt(host_component, this.config3);
-            comp.service_id = service;
-            this.calculateState(comp);
-            result.push(comp);
-            hostComponentsMap[comp.id] = comp;
-          }, this)
-        }, this)
-      }, this);
 
+      //load services to model
+      App.store.loadMany(this.get('model'), result);
 
-      var oldHostComponents = App.HostComponent.find();
-      var item;
-      var currentHCWithComponentNames = {};
-      var currentComponentNameHostNames = {};
-      var doHostComponentsLoad = false;
       var servicesMap = {};
-      oldHostComponents.forEach(function (item) {
+      //calculate service statuses according to their host-components
+      masterComponents.forEach(function (item) {
         if (item) {
-          if (!hostComponentsMap[item.get('id')]) {
-            item.deleteRecord();
-            item.get('stateManager').transitionTo('loading');
-          } else {
-            var componentName = item.get('componentName');
-            if (componentName) {
-              currentHCWithComponentNames[item.get('id')] = item.get('id');
-            }
-            if (!currentComponentNameHostNames[componentName]) {
-              currentComponentNameHostNames[componentName] = [];
-            }
-            currentComponentNameHostNames[componentName].pushObject(item.get('host.hostName'));
-          }
           this.countServiceComponents(item, servicesMap, servicesMap[item.get('service.id')]);
         }
       }, this);
-
       this.updateServicesStatus(App.Service.find(), servicesMap);
-
-      for(var i in hostComponentsMap) {
-        if(!currentHCWithComponentNames[i]) {
-          doHostComponentsLoad = true;
-          break;
-        }
-      }
-      result.forEach(function (item) {
-        if (currentHCWithComponentNames[item.id] != null && 
-            !currentComponentNameHostNames[item.component_name].contains(item.host_id)) {
-          item.id = (new Date).getTime();
-        }
-      });
-
-      if (!App.router.get('clusterController.isLoaded') || doHostComponentsLoad) {
-        App.store.loadMany(this.get('model3'), result);
-      }
     }
     console.timeEnd('App.servicesMapper execution time');
   },
@@ -600,16 +627,6 @@ App.servicesMapper = App.QuickDataMapper.create({
           });
         }
       }
-      if (component.ServiceComponentInfo && component.ServiceComponentInfo.component_name == "DATANODE") {
-        if (!item.data_nodes) {
-          item.data_nodes = [];
-        }
-        if (component.host_components) {
-          component.host_components.forEach(function (hc) {
-            item.data_nodes.push(hc.HostRoles.host_name);
-          });
-        }
-      }
     });
     // Map
     var finalJson = this.parseIt(item, finalConfig);
@@ -650,26 +667,6 @@ App.servicesMapper = App.QuickDataMapper.create({
         // extend config
         finalConfig = jQuery.extend(finalConfig, yarnConfig);
       }
-      if (component.ServiceComponentInfo && component.ServiceComponentInfo.component_name == "NODEMANAGER") {
-        if (!item.node_manager_nodes) {
-          item.node_manager_nodes = [];
-        }
-        if (component.host_components) {
-          component.host_components.forEach(function (hc) {
-            item.node_manager_nodes.push(hc.HostRoles.host_name);
-          });
-        }
-      }
-      if (component.ServiceComponentInfo && component.ServiceComponentInfo.component_name == "YARN_CLIENT") {
-        if (!item.yarn_client_nodes) {
-          item.yarn_client_nodes = [];
-        }
-        if (component.host_components) {
-          component.host_components.forEach(function (hc) {
-            item.yarn_client_nodes.push(hc.HostRoles.host_name);
-          });
-        }
-      }
     });
     // Map
     var finalJson = this.parseIt(item, finalConfig);
@@ -700,16 +697,6 @@ App.servicesMapper = App.QuickDataMapper.create({
         item.jobHistoryServerComponent = component;
         finalConfig = jQuery.extend(finalConfig, mapReduce2Config);
       }
-      if (component.ServiceComponentInfo && component.ServiceComponentInfo.component_name == "MAPREDUCE2_CLIENT") {
-        if (!item.map_reduce2_clients) {
-          item.map_reduce2_clients = [];
-        }
-        if (component.host_components) {
-          component.host_components.forEach(function (hc) {
-            item.map_reduce2_clients.push(hc.HostRoles.host_name);
-          });
-        }
-      }
     });
     // Map
     var finalJson = this.parseIt(item, finalConfig);
@@ -759,19 +746,9 @@ App.servicesMapper = App.QuickDataMapper.create({
           });
         }
       }
-      if (component.ServiceComponentInfo && component.ServiceComponentInfo.component_name == "TASKTRACKER") {
-        if (!item.task_trackers) {
-          item.task_trackers = [];
-        }
-        if (component.host_components) {
-          component.host_components.forEach(function (hc) {
-            item.task_trackers.push(hc.HostRoles.host_name);
-          });
-        }
-      }
     });
     // Map
-    finalJson = this.parseIt(item, finalConfig);
+    var finalJson = this.parseIt(item, finalConfig);
     finalJson.quick_links = [5, 6, 7, 8, 9, 10, 11, 12];
     return finalJson;
   },
@@ -791,19 +768,9 @@ App.servicesMapper = App.QuickDataMapper.create({
           item.regions_in_transition = regionsArray == null ? 0 : regionsArray;
         }
       }
-      if (component.ServiceComponentInfo && component.ServiceComponentInfo.component_name == "HBASE_REGIONSERVER") {
-        if (!item.region_servers) {
-          item.region_servers = [];
-        }
-        if (component.host_components) {
-          component.host_components.forEach(function (hc) {
-            item.region_servers.push(hc.HostRoles.host_name);
-          });
-        }
-      }
     });
     // Map
-    finalJson = this.parseIt(item, finalConfig);
+    var finalJson = this.parseIt(item, finalConfig);
     finalJson.average_load = parseFloat(finalJson.average_load).toFixed(2);
     finalJson.quick_links = [13, 14, 15, 16, 17, 18];
     return finalJson;

http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/5820bd7c/ambari-web/app/mappers/status_mapper.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/mappers/status_mapper.js b/ambari-web/app/mappers/status_mapper.js
index 3ae39cd..08bdb19 100644
--- a/ambari-web/app/mappers/status_mapper.js
+++ b/ambari-web/app/mappers/status_mapper.js
@@ -17,9 +17,6 @@
 
 var App = require('app');
 
-var previousComponentStatuses = {};
-var previousHostStatuses = {};
-
 App.statusMapper = App.QuickDataMapper.create({
   model: App.HostComponent,
   componentServiceMap: {
@@ -71,6 +68,8 @@ App.statusMapper = App.QuickDataMapper.create({
       var componentServiceMap = this.get('componentServiceMap');
       var currentComponentStatuses = {};
       var currentHostStatuses = {};
+      var previousHostStatuses = App.cache['previousHostStatuses'];
+      var previousComponentStatuses = App.cache['previousComponentStatuses'];
 
       json.items.forEach(function (host) {
         //update hosts, which have status changed
@@ -130,8 +129,8 @@ App.statusMapper = App.QuickDataMapper.create({
         App.store.loadMany(this.get('model'), addedHostComponents);
       }
 
-      previousComponentStatuses = currentComponentStatuses;
-      previousHostStatuses = currentHostStatuses;
+      App.cache['previousHostStatuses'] = currentHostStatuses;
+      App.cache['previousComponentStatuses'] = currentComponentStatuses;
 
       hosts.forEach(function (host) {
         var status = hostStatuses[host.get('id')];


[2/3] AMBARI-3714 [perf] UI should only request data from master host-components. (atkach)

Posted by at...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/5820bd7c/ambari-web/app/assets/data/dashboard/HDP2/services.json
----------------------------------------------------------------------
diff --git a/ambari-web/app/assets/data/dashboard/HDP2/services.json b/ambari-web/app/assets/data/dashboard/HDP2/services.json
index dd41fbf..1de962f 100644
--- a/ambari-web/app/assets/data/dashboard/HDP2/services.json
+++ b/ambari-web/app/assets/data/dashboard/HDP2/services.json
@@ -1,2226 +1,304 @@
 {
-  "href" : "http://dev01:8080/api/v1/clusters/vm/services?fields=components/ServiceComponentInfo,components/host_components,components/host_components/HostRoles,components/host_components/metrics/jvm/memHeapUsedM,components/host_components/metrics/jvm/memHeapCommittedM,components/host_components/metrics/mapred/jobtracker/trackers_decommissioned,components/host_components/metrics/cpu/cpu_wio,components/host_components/metrics/rpc/RpcQueueTime_avg_time,components/host_components/metrics/flume/flume,components/host_components/metrics/yarn/Queue&_=1375467778021",
+  "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/components/?ServiceComponentInfo/category=MASTER&fields=ServiceComponentInfo/MasterActiveTime,host_components/metrics/jvm/memHeapUsedM,host_components/metrics/jvm/memHeapCommittedM,host_components/metrics/mapred/jobtracker/trackers_decommissioned,host_components/metrics/cpu/cpu_wio,host_components/metrics/rpc/RpcQueueTime_avg_time,host_components/metrics/dfs/FSNamesystem/HAState,host_components/metrics/dfs/FSNamesystem/CapacityUsed,host_components/metrics/dfs/FSNamesystem/CapacityTotal,host_components/metrics/dfs/FSNamesystem/CapacityRemaining,host_components/metrics/dfs/FSNamesystem/BlocksTotal,host_components/metrics/dfs/FSNamesystem/CorruptBlocks,host_components/metrics/dfs/FSNamesystem/MissingBlocks,host_components/metrics/dfs/FSNamesystem/UnderReplicatedBlocks,host_components/metrics/dfs/namenode/Version,host_components/metrics/dfs/namenode/LiveNodes,host_components/metrics/dfs/namenode/DeadNodes,host_components/metric
 s/dfs/namenode/DecomNodes,host_components/metrics/dfs/namenode/TotalFiles,host_components/metrics/dfs/namenode/UpgradeFinalized,host_components/metrics/dfs/namenode/Safemode,host_components/metrics/runtime/StartTime,host_components/metrics/flume/flume,host_components/metrics/yarn/Queue,host_components/metrics/hbase/master/IsActiveMaster,host_components/HostRoles/state",
   "items" : [
     {
-      "href" : "http://dev01:8080/api/v1/clusters/vm/services/GANGLIA",
-      "ServiceInfo" : {
-        "cluster_name" : "vm",
+      "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/components/GANGLIA_SERVER",
+      "ServiceComponentInfo" : {
+        "category" : "MASTER",
+        "cluster_name" : "perf",
+        "component_name" : "GANGLIA_SERVER",
         "service_name" : "GANGLIA"
       },
-      "components" : [
+      "host_components" : [
         {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/GANGLIA/components/GANGLIA_MONITOR",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "GANGLIA_MONITOR",
-            "service_name" : "GANGLIA",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/GANGLIA_MONITOR",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "GANGLIA_MONITOR",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "GANGLIA",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "stale_configs": "true",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
-        },
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/GANGLIA/components/GANGLIA_SERVER",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
+          "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/hosts/dev01.hortonworks.com/host_components/GANGLIA_SERVER",
+          "HostRoles" : {
+            "cluster_name" : "perf",
             "component_name" : "GANGLIA_SERVER",
-            "service_name" : "GANGLIA",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/GANGLIA_SERVER",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "GANGLIA_SERVER",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "GANGLIA",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "stale_configs": "true",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
+            "host_name" : "dev01.hortonworks.com",
+            "state" : "STARTED"
+          }
         }
       ]
     },
     {
-      "href" : "http://dev01:8080/api/v1/clusters/vm/services/HBASE",
-      "ServiceInfo" : {
-        "cluster_name" : "vm",
+      "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/components/HBASE_MASTER",
+      "ServiceComponentInfo" : {
+        "category" : "MASTER",
+        "cluster_name" : "perf",
+        "component_name" : "HBASE_MASTER",
         "service_name" : "HBASE"
       },
-      "components" : [
+      "host_components" : [
         {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HBASE/components/HBASE_CLIENT",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "HBASE_CLIENT",
-            "service_name" : "HBASE",
-            "state" : "INSTALLED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/HBASE_CLIENT",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "HBASE_CLIENT",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "INSTALLED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HBASE",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "INSTALLED",
-                "actual_configs" : { },
-                "configs" : { },
-                "desired_configs" : { }
-              },
-              "metrics" : {
-                "cpu" : {
-                  "cpu_wio" : 0.1
-                },
-                "jvm" : {
-                  "memHeapCommittedM" : 28.5041666667,
-                  "memHeapUsedM" : 11.9096411333
-                }
-              }
-            }
-          ]
-        },
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HBASE/components/HBASE_MASTER",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
+          "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/hosts/dev01.hortonworks.com/host_components/HBASE_MASTER",
+          "HostRoles" : {
+            "cluster_name" : "perf",
             "component_name" : "HBASE_MASTER",
-            "service_name" : "HBASE",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/HBASE_MASTER",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "HBASE_MASTER",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "stale_configs": "true",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HBASE",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "INSTALLED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              },
-              "metrics" : {
-                "cpu" : {
-                  "cpu_wio" : 0.1
-                }
-              }
-            }
-          ]
-        },
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HBASE/components/HBASE_REGIONSERVER",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "HBASE_REGIONSERVER",
-            "service_name" : "HBASE",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/HBASE_REGIONSERVER",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "HBASE_REGIONSERVER",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HBASE",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "INSTALLED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              },
-              "metrics" : {
-                "cpu" : {
-                  "cpu_wio" : 0.1
-                },
-                "jvm" : {
-                  "memHeapCommittedM" : 28.5041666667,
-                  "memHeapUsedM" : 11.9096411333
-                }
-              }
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "href" : "http://dev01:8080/api/v1/clusters/vm/services/HCATALOG",
-      "ServiceInfo" : {
-        "cluster_name" : "vm",
-        "service_name" : "HCATALOG"
-      },
-      "components" : [
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HCATALOG/components/HCAT",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "HCAT",
-            "service_name" : "HCATALOG",
-            "state" : "INSTALLED",
-            "desired_configs" : { }
+            "host_name" : "dev01.hortonworks.com",
+            "state" : "STARTED"
           },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/HCAT",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "HCAT",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "INSTALLED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HCATALOG",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "INSTALLED",
-                "actual_configs" : { },
-                "configs" : { },
-                "desired_configs" : { }
+          "metrics" : {
+            "cpu" : {
+              "cpu_wio" : 1.68305555556
+            },
+            "hbase" : {
+              "master" : {
+                "IsActiveMaster" : "true"
               }
+            },
+            "jvm" : {
+              "memHeapCommittedM" : 81.0625,
+              "memHeapUsedM" : 14.4296904856
             }
-          ]
+          }
         }
       ]
     },
     {
-      "href" : "http://dev01:8080/api/v1/clusters/vm/services/HDFS",
-      "ServiceInfo" : {
-        "cluster_name" : "vm",
+      "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/components/NAMENODE",
+      "ServiceComponentInfo" : {
+        "category" : "MASTER",
+        "cluster_name" : "perf",
+        "component_name" : "NAMENODE",
         "service_name" : "HDFS"
       },
-      "components" : [
+      "host_components" : [
         {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HDFS/components/DATANODE",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "DATANODE",
-            "service_name" : "HDFS",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/DATANODE",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "DATANODE",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HDFS",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              },
-              "metrics" : {
-                "cpu" : {
-                  "cpu_wio" : 0.1
-                },
-                "jvm" : {
-                  "memHeapCommittedM" : 28.4375,
-                  "memHeapUsedM" : 13.903183
-                }
-              }
-            }
-          ]
-        },
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HDFS/components/HDFS_CLIENT",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "HDFS_CLIENT",
-            "service_name" : "HDFS",
-            "state" : "INSTALLED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/HDFS_CLIENT",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "HDFS_CLIENT",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "INSTALLED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HDFS",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "INSTALLED",
-                "actual_configs" : { },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
-        },
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HDFS/components/NAMENODE",
-          "ServiceComponentInfo" : {
-            "BlocksTotal" : 379,
-            "CapacityRemaining" : 490802069504,
-            "CapacityTotal" : 525282689023,
-            "CapacityUsed" : 182407168,
-            "CorruptBlocks" : 0,
-            "DeadNodes" : "{}",
-            "DecomNodes" : "{}",
-            "HeapMemoryMax" : 1006632960,
-            "HeapMemoryUsed" : 194751064,
-            "LiveNodes" : "{\"dev01.hortonworks.com\":{\"numBlocks\":379,\"usedSpace\":182407168,\"lastContact\":1,\"capacity\":525282689023,\"nonDfsUsedSpace\":34298212351,\"adminState\":\"In Service\"}}",
-            "MissingBlocks" : 0,
-            "NonDfsUsedSpace" : 34298212351,
-            "NonHeapMemoryMax" : 136314880,
-            "NonHeapMemoryUsed" : 42712328,
-            "PercentRemaining" : 93.4358,
-            "PercentUsed" : 0.034725524,
-            "Safemode" : "",
-            "StartTime" : 1375383936364,
-            "TotalFiles" : 617,
-            "UnderReplicatedBlocks" : 379,
-            "UpgradeFinalized" : true,
-            "Version" : "2.1.0.2.0.3.0-116, r707031d22de185c6af3023b0689578b9ec743113",
-            "cluster_name" : "vm",
+          "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/hosts/dev01.hortonworks.com/host_components/NAMENODE",
+          "HostRoles" : {
+            "cluster_name" : "perf",
             "component_name" : "NAMENODE",
-            "service_name" : "HDFS",
-            "state" : "STARTED",
-            "desired_configs" : { }
+            "host_name" : "dev01.hortonworks.com",
+            "state" : "STARTED"
           },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/NAMENODE",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "NAMENODE",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HDFS",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
+          "metrics" : {
+            "cpu" : {
+              "cpu_wio" : 1.15722222222
+            },
+            "dfs" : {
+              "FSNamesystem" : {
+                "BlocksTotal" : 461,
+                "CapacityRemaining" : 47220695040,
+                "CapacityTotal" : 51770945536,
+                "CapacityUsed" : 193253376,
+                "CorruptBlocks" : 0,
+                "HAState" : "active",
+                "MissingBlocks" : 0,
+                "UnderReplicatedBlocks" : 461
               },
-              "metrics" : {
-                "cpu" : {
-                  "cpu_wio" : 0.3
-                },
-                "jvm" : {
-                  "memHeapCommittedM" : 960.0,
-                  "memHeapUsedM" : 186.13074
-                }
-              }
-            }
-          ]
-        },
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HDFS/components/SECONDARY_NAMENODE",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "SECONDARY_NAMENODE",
-            "service_name" : "HDFS",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/SECONDARY_NAMENODE",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "SECONDARY_NAMENODE",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HDFS",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
+              "namenode" : {
+                "DeadNodes" : "{\"dev01.hortonworks.com\":{\"lastContact\":692,\"decommissioned\":false}}",
+                "DecomNodes" : "{}",
+                "LiveNodes" : "{\"dev02.hortonworks.com\":{\"numBlocks\":461,\"usedSpace\":193253376,\"lastContact\":1,\"capacity\":51770945536,\"nonDfsUsedSpace\":4356997120,\"adminState\":\"In Service\",\"version\":\"2.2.0.2.0.6.0-76\"}}",
+                "Safemode" : "",
+                "TotalFiles" : 606,
+                "UpgradeFinalized" : true,
+                "Version" : "2.2.0.2.0.6.0-76, r8656b1cfad13b03b29e98cad042626205e7a1c86"
               }
+            },
+            "jvm" : {
+              "memHeapCommittedM" : 960.0,
+              "memHeapUsedM" : 106.43069
+            },
+            "rpc" : {
+              "RpcQueueTime_avg_time" : 0.0
+            },
+            "runtime" : {
+              "StartTime" : 1383649085429
             }
-          ]
+          }
         }
       ]
     },
     {
-      "href" : "http://dev01:8080/api/v1/clusters/vm/services/HIVE",
-      "ServiceInfo" : {
-        "cluster_name" : "vm",
-        "service_name" : "HIVE"
+      "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/components/SECONDARY_NAMENODE",
+      "ServiceComponentInfo" : {
+        "category" : "MASTER",
+        "cluster_name" : "perf",
+        "component_name" : "SECONDARY_NAMENODE",
+        "service_name" : "HDFS"
       },
-      "components" : [
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HIVE/components/HIVE_CLIENT",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "HIVE_CLIENT",
-            "service_name" : "HIVE",
-            "state" : "INSTALLED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/HIVE_CLIENT",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "HIVE_CLIENT",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "INSTALLED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HIVE",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "INSTALLED",
-                "actual_configs" : { },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
-        },
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HIVE/components/HIVE_METASTORE",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "HIVE_METASTORE",
-            "service_name" : "HIVE",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/HIVE_METASTORE",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "HIVE_METASTORE",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HIVE",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
-        },
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HIVE/components/HIVE_SERVER",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "HIVE_SERVER",
-            "service_name" : "HIVE",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/HIVE_SERVER",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "HIVE_SERVER",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HIVE",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
-        },
+      "host_components" : [
         {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HIVE/components/MYSQL_SERVER",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "MYSQL_SERVER",
-            "service_name" : "HIVE",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/MYSQL_SERVER",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "MYSQL_SERVER",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "HIVE",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
+          "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/hosts/dev01.hortonworks.com/host_components/SECONDARY_NAMENODE",
+          "HostRoles" : {
+            "cluster_name" : "perf",
+            "component_name" : "SECONDARY_NAMENODE",
+            "host_name" : "dev01.hortonworks.com",
+            "state" : "STARTED"
+          }
         }
       ]
     },
     {
-      "href" : "http://dev01:8080/api/v1/clusters/vm/services/MAPREDUCE2",
-      "ServiceInfo" : {
-        "cluster_name" : "vm",
+      "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/components/HISTORYSERVER",
+      "ServiceComponentInfo" : {
+        "category" : "MASTER",
+        "cluster_name" : "perf",
+        "component_name" : "HISTORYSERVER",
         "service_name" : "MAPREDUCE2"
       },
-      "components" : [
+      "host_components" : [
         {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/MAPREDUCE2/components/HISTORYSERVER",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
+          "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/hosts/dev01.hortonworks.com/host_components/HISTORYSERVER",
+          "HostRoles" : {
+            "cluster_name" : "perf",
             "component_name" : "HISTORYSERVER",
-            "service_name" : "MAPREDUCE2",
-            "state" : "STARTED",
-            "desired_configs" : { }
+            "host_name" : "dev01.hortonworks.com",
+            "state" : "STARTED"
           },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/HISTORYSERVER",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "HISTORYSERVER",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "MAPREDUCE2",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "stale_configs": "true",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              },
-              "metrics" : {
-                "jvm" : {
-                  "memHeapCommittedM" : 28.5625,
-                  "memHeapUsedM" : 10.363014
-                }
-              }
+          "metrics" : {
+            "jvm" : {
+              "memHeapCommittedM" : 60.0,
+              "memHeapUsedM" : 20.311676
             }
-          ]
-        },
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/MAPREDUCE2/components/MAPREDUCE2_CLIENT",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "MAPREDUCE2_CLIENT",
-            "service_name" : "MAPREDUCE2",
-            "state" : "INSTALLED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/MAPREDUCE2_CLIENT",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "MAPREDUCE2_CLIENT",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "INSTALLED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "MAPREDUCE2",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "INSTALLED",
-                "stale_configs": "true",
-                "actual_configs" : { },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
+          }
         }
       ]
     },
     {
-      "href" : "http://dev01:8080/api/v1/clusters/vm/services/NAGIOS",
-      "ServiceInfo" : {
-        "cluster_name" : "vm",
+      "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/components/NAGIOS_SERVER",
+      "ServiceComponentInfo" : {
+        "category" : "MASTER",
+        "cluster_name" : "perf",
+        "component_name" : "NAGIOS_SERVER",
         "service_name" : "NAGIOS"
       },
-      "components" : [
+      "host_components" : [
         {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/NAGIOS/components/NAGIOS_SERVER",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
+          "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/hosts/dev01.hortonworks.com/host_components/NAGIOS_SERVER",
+          "HostRoles" : {
+            "cluster_name" : "perf",
             "component_name" : "NAGIOS_SERVER",
-            "service_name" : "NAGIOS",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/NAGIOS_SERVER",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "NAGIOS_SERVER",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "nagios_alerts" : {
-                  "alerts" : [
-                    {
-                      "service_description" : "Check ambari-agent process",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: Ambari agent is running [PID:8339]",
-                      "last_hard_state_change" : "1375462335",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467735",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467735",
-                      "service_type" : "AMBARI"
-                    },
-                    {
-                      "service_description" : "DataNode process down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "TCP OK - 0.001 second response time on port 50075",
-                      "last_hard_state_change" : "1375462338",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467858",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467858",
-                      "service_type" : "HDFS"
-                    },
-                    {
-                      "service_description" : "DataNode storage full",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: Capacity:[525282689023], Remaining Capacity:[490802098176], percent_full:[6.5641970633246]",
-                      "last_hard_state_change" : "1375462341",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467741",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467741",
-                      "service_type" : "HDFS"
-                    },
-                    {
-                      "service_description" : "Ganglia Server [gmond] process down alert for HBase Master",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "TCP OK - 0.001 second response time on port 8663",
-                      "last_hard_state_change" : "1375462344",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467894",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467894",
-                      "service_type" : "GANGLIA"
-                    },
-                    {
-                      "service_description" : "Ganglia Server [gmond] process down alert for History Server 2",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "TCP OK - 0.003 second response time on port 8666",
-                      "last_hard_state_change" : "1375462347",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375388826",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467237",
-                      "service_type" : "GANGLIA"
-                    },
-                    {
-                      "service_description" : "Ganglia Server [gmond] process down alert for NameNode",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "TCP OK - 0.005 second response time on port 8661",
-                      "last_hard_state_change" : "1375462350",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375388829",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467240",
-                      "service_type" : "GANGLIA"
-                    },
-                    {
-                      "service_description" : "Ganglia Server [gmond] process down alert for NodeManager",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "TCP OK - 0.002 second response time on port 8660",
-                      "last_hard_state_change" : "1375462353",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467889",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467889",
-                      "service_type" : "GANGLIA"
-                    },
-                    {
-                      "service_description" : "Ganglia Server [gmond] process down alert for ResourceManager",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "TCP OK - 0.001 second response time on port 8664",
-                      "last_hard_state_change" : "1375462356",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467891",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467891",
-                      "service_type" : "GANGLIA"
-                    },
-                    {
-                      "service_description" : "Ganglia Server [gmond] process down alert for slaves",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "TCP OK - 0.003 second response time on port 8660",
-                      "last_hard_state_change" : "1375462359",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467894",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467894",
-                      "service_type" : "GANGLIA"
-                    },
-                    {
-                      "service_description" : "Ganglia [gmetad] process down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "TCP OK - 0.001 second response time on port 8651",
-                      "last_hard_state_change" : "1375462362",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375388826",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467237",
-                      "service_type" : "GANGLIA"
-                    },
-                    {
-                      "service_description" : "Percent RegionServers down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: total:<1>, affected:<0>",
-                      "last_hard_state_change" : "1375462935",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375388814",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "1375384494",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467225",
-                      "service_type" : "HBASE"
-                    },
-                    {
-                      "service_description" : "HBase Master CPU utilization",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "1 CPU, load 13.0% < 200% : OK",
-                      "last_hard_state_change" : "1375462368",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467768",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467768",
-                      "service_type" : "HBASE"
-                    },
-                    {
-                      "service_description" : "HBase Master Web UI down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "3",
-                      "current_state" : "1",
-                      "plugin_output" : "WARNING: HBase Master web UI not accessible : http://dev01.hortonworks.com:60010/master-status",
-                      "last_hard_state_change" : "1375467711",
-                      "last_hard_state" : "1",
-                      "last_time_ok" : "1375467531",
-                      "last_time_warning" : "1375467891",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467891",
-                      "service_type" : "HBASE"
-                    },
-                    {
-                      "service_description" : "HBase Master process down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "4",
-                      "current_state" : "2",
-                      "plugin_output" : "Connection refused",
-                      "last_hard_state_change" : "1375467625",
-                      "last_hard_state" : "2",
-                      "last_time_ok" : "1375467550",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "1375467895",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467895",
-                      "service_type" : "HBASE"
-                    },
-                    {
-                      "service_description" : "Corrupt/Missing blocks",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: corrupt_blocks:<>, missing_blocks:<>, total_blocks:<>",
-                      "last_hard_state_change" : "1375462378",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467898",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467898",
-                      "service_type" : "HDFS"
-                    },
-                    {
-                      "service_description" : "HDFS capacity utilization",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: DFSUsedGB:<0.2>, DFSTotalGB:<457.3>",
-                      "last_hard_state_change" : "1375462381",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467781",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467781",
-                      "service_type" : "HDFS"
-                    },
-                    {
-                      "service_description" : "NameNode RPC latency",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: RpcQueueTime_avg_time:<0> Secs, RpcProcessingTime_avg_time:<0> Secs",
-                      "last_hard_state_change" : "1375462384",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467784",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467784",
-                      "service_type" : "HDFS"
-                    },
-                    {
-                      "service_description" : "Percent DataNodes down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: total:<1>, affected:<0>",
-                      "last_hard_state_change" : "1375462387",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467877",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467877",
-                      "service_type" : "HDFS"
-                    },
-                    {
-                      "service_description" : "Percent DataNodes storage full",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: total:<1>, affected:<0>",
-                      "last_hard_state_change" : "1375462390",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467790",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467790",
-                      "service_type" : "HDFS"
-                    },
-                    {
-                      "service_description" : "Hive Metastore status check",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: Hive metaserver status OK",
-                      "last_hard_state_change" : "1375462723",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375388812",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "1375384282",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467223",
-                      "service_type" : "HIVE"
-                    },
-                    {
-                      "service_description" : "History Server 2 CPU utilization",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "1 CPU, load 12.0% < 200% : OK",
-                      "last_hard_state_change" : "1375462396",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467796",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467796",
-                      "service_type" : "UNKNOWN"
-                    },
-                    {
-                      "service_description" : "History Server 2 RPC latency",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: RpcQueueTime_avg_time:<0> Secs, RpcProcessingTime_avg_time:<0> Secs",
-                      "last_hard_state_change" : "1375462399",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467799",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467799",
-                      "service_type" : "UNKNOWN"
-                    },
-                    {
-                      "service_description" : "History Server 2 Web UI down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: Successfully accessed historyserver2 Web UI",
-                      "last_hard_state_change" : "1375462762",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467862",
-                      "last_time_warning" : "1375384291",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467862",
-                      "service_type" : "UNKNOWN"
-                    },
-                    {
-                      "service_description" : "Percent TaskTrackers down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: total:<0>, affected:<0>",
-                      "last_hard_state_change" : "1375462405",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467895",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467895",
-                      "service_type" : "MAPREDUCE"
-                    },
-                    {
-                      "service_description" : "Nagios status log staleness",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "NAGIOS OK: 2 processes, status log updated 6 seconds ago",
-                      "last_hard_state_change" : "1375462408",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467808",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467808",
-                      "service_type" : "NAGIOS"
-                    },
-                    {
-                      "service_description" : "NameNode Web UI down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: Successfully accessed namenode Web UI",
-                      "last_hard_state_change" : "1375462411",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467871",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467871",
-                      "service_type" : "HDFS"
-                    },
-                    {
-                      "service_description" : "NameNode edit logs directory status",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: All Namenode directories are active",
-                      "last_hard_state_change" : "1375462415",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467875",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467875",
-                      "service_type" : "HDFS"
-                    },
-                    {
-                      "service_description" : "NameNode host CPU utilization",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "1 CPU, load 12.0% < 200% : OK",
-                      "last_hard_state_change" : "1375462418",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467818",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467818",
-                      "service_type" : "HDFS"
-                    },
-                    {
-                      "service_description" : "NameNode process down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "TCP OK - 0.001 second response time on port 8020",
-                      "last_hard_state_change" : "1375462421",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467881",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467881",
-                      "service_type" : "HDFS"
-                    },
-                    {
-                      "service_description" : "NodeManager process down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "TCP OK - 0.001 second response time on port 8042",
-                      "last_hard_state_change" : "1375462964",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467884",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "1375384493",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467884",
-                      "service_type" : "UNKNOWN"
-                    },
-                    {
-                      "service_description" : "Oozie Server status check",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: Oozie server status [System mode: NORMAL]",
-                      "last_hard_state_change" : "1375462787",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467887",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "1375384316",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467887",
-                      "service_type" : "OOZIE"
-                    },
-                    {
-                      "service_description" : "RegionServer process down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "3",
-                      "current_state" : "2",
-                      "plugin_output" : "Connection refused",
-                      "last_hard_state_change" : "1375467350",
-                      "last_hard_state" : "2",
-                      "last_time_ok" : "1375388819",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "1375467890",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467890",
-                      "service_type" : "HBASE"
-                    },
-                    {
-                      "service_description" : "ResourceManager CPU utilization",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "1 CPU, load 11.0% < 200% : OK",
-                      "last_hard_state_change" : "1375462433",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467833",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467833",
-                      "service_type" : "UNKNOWN"
-                    },
-                    {
-                      "service_description" : "ResourceManager RPC latency",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: RpcQueueTime_avg_time:<0> Secs, RpcProcessingTime_avg_time:<0> Secs",
-                      "last_hard_state_change" : "1375462436",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467836",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467836",
-                      "service_type" : "UNKNOWN"
-                    },
-                    {
-                      "service_description" : "ResourceManager Web UI down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: Successfully accessed resorcemanager Web UI",
-                      "last_hard_state_change" : "1375462859",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467899",
-                      "last_time_warning" : "1375384388",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "0",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467899",
-                      "service_type" : "UNKNOWN"
-                    },
-                    {
-                      "service_description" : "WebHCat Server status check",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "",
-                      "last_hard_state_change" : "1375463162",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467842",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "1375384691",
-                      "is_flapping" : "",
-                      "last_check" : "",
-                      "service_type" : "WEBHCAT"
-                    },
-                    {
-                      "service_description" : "Percent ZooKeeper Servers down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "OK: total:<1>, affected:<0>",
-                      "last_hard_state_change" : "1375462715",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467875",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "1375384274",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467875",
-                      "service_type" : "ZOOKEEPER"
-                    },
-                    {
-                      "service_description" : "ZooKeeper Server process down",
-                      "host_name" : "dev01.hortonworks.com",
-                      "current_attempt" : "1",
-                      "current_state" : "0",
-                      "plugin_output" : "TCP OK - 0.001 second response time on port 2181",
-                      "last_hard_state_change" : "1375462688",
-                      "last_hard_state" : "0",
-                      "last_time_ok" : "1375467848",
-                      "last_time_warning" : "0",
-                      "last_time_unknown" : "0",
-                      "last_time_critical" : "1375384217",
-                      "is_flapping" : "0",
-                      "last_check" : "1375467848",
-                      "service_type" : "ZOOKEEPER"
-                    }
-                  ],
-                  "hostcounts" : {
-                    "up_hosts" : "1",
-                    "down_hosts" : "0"
-                  },
-                  "servicestates" : {
-                    "PUPPET" : "0",
-                    "HIVE-METASTORE" : "0",
-                    "HDFS" : "0",
-                    "OOZIE" : "0",
-                    "WEBHCAT" : "0",
-                    "ZOOKEEPER" : "0"
-                  }
-                },
-                "service_name" : "NAGIOS",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
+            "host_name" : "dev01.hortonworks.com",
+            "state" : "STARTED"
+          }
         }
       ]
     },
     {
-      "href" : "http://dev01:8080/api/v1/clusters/vm/services/OOZIE",
-      "ServiceInfo" : {
-        "cluster_name" : "vm",
+      "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/components/OOZIE_SERVER",
+      "ServiceComponentInfo" : {
+        "category" : "MASTER",
+        "cluster_name" : "perf",
+        "component_name" : "OOZIE_SERVER",
         "service_name" : "OOZIE"
       },
-      "components" : [
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/OOZIE/components/OOZIE_CLIENT",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "OOZIE_CLIENT",
-            "service_name" : "OOZIE",
-            "state" : "INSTALLED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/OOZIE_CLIENT",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "OOZIE_CLIENT",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "INSTALLED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "OOZIE",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "INSTALLED",
-                "actual_configs" : { },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
-        },
+      "host_components" : [
         {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/OOZIE/components/OOZIE_SERVER",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
+          "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/hosts/dev01.hortonworks.com/host_components/OOZIE_SERVER",
+          "HostRoles" : {
+            "cluster_name" : "perf",
             "component_name" : "OOZIE_SERVER",
-            "service_name" : "OOZIE",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/OOZIE_SERVER",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "OOZIE_SERVER",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "OOZIE",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "href" : "http://dev01:8080/api/v1/clusters/vm/services/PIG",
-      "ServiceInfo" : {
-        "cluster_name" : "vm",
-        "service_name" : "PIG"
-      },
-      "components" : [
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/PIG/components/PIG",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "PIG",
-            "service_name" : "PIG",
-            "state" : "INSTALLED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/PIG",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "PIG",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "INSTALLED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "PIG",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "INSTALLED",
-                "actual_configs" : { },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
+            "host_name" : "dev01.hortonworks.com",
+            "state" : "STARTED"
+          }
         }
       ]
     },
     {
-      "href" : "http://dev01:8080/api/v1/clusters/vm/services/WEBHCAT",
-      "ServiceInfo" : {
-        "cluster_name" : "vm",
-        "service_name" : "WEBHCAT"
-      },
-      "components" : [
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/WEBHCAT/components/WEBHCAT_SERVER",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "WEBHCAT_SERVER",
-            "service_name" : "WEBHCAT",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/WEBHCAT_SERVER",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "WEBHCAT_SERVER",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "WEBHCAT",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "STARTED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              }
-            }
-          ]
-        }
-      ]
-    },
-    {
-      "href" : "http://dev01:8080/api/v1/clusters/vm/services/YARN",
-      "ServiceInfo" : {
-        "cluster_name" : "vm",
+      "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/components/RESOURCEMANAGER",
+      "ServiceComponentInfo" : {
+        "category" : "MASTER",
+        "cluster_name" : "perf",
+        "component_name" : "RESOURCEMANAGER",
         "service_name" : "YARN"
       },
-      "components" : [
-        {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/YARN/components/NODEMANAGER",
-          "ServiceComponentInfo" : {
-            "cluster_name" : "vm",
-            "component_name" : "NODEMANAGER",
-            "service_name" : "YARN",
-            "state" : "STARTED",
-            "desired_configs" : { }
-          },
-          "host_components" : [
-            {
-              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.hortonworks.com/host_components/NODEMANAGER",
-              "HostRoles" : {
-                "cluster_name" : "vm",
-                "component_name" : "NODEMANAGER",
-                "desired_stack_id" : "HDP-2.0.5",
-                "desired_state" : "STARTED",
-                "ha_status" : "passive",
-                "host_name" : "dev01.hortonworks.com",
-                "service_name" : "YARN",
-                "stack_id" : "HDP-2.0.5",
-                "state" : "INSTALLED",
-                "actual_configs" : {
-                  "capacity-scheduler" : {
-                    "tag" : "version1"
-                  },
-                  "core-site" : {
-                    "tag" : "version1"
-                  },
-                  "global" : {
-                    "tag" : "version1"
-                  },
-                  "hbase-site" : {
-                    "tag" : "version1"
-                  },
-                  "hdfs-site" : {
-                    "tag" : "version1"
-                  },
-                  "hive-site" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-queue-acls" : {
-                    "tag" : "version1"
-                  },
-                  "mapred-site" : {
-                    "tag" : "version1"
-                  },
-                  "oozie-site" : {
-                    "tag" : "version1"
-                  },
-                  "webhcat-site" : {
-                    "tag" : "version1"
-                  },
-                  "yarn-site" : {
-                    "tag" : "version1"
-                  }
-                },
-                "configs" : { },
-                "desired_configs" : { }
-              },
-              "metrics" : {
-                "cpu" : {
-                  "cpu_wio" : 0.1
-                },
-                "jvm" : {
-                  "memHeapCommittedM" : 28.5625,
-                  "memHeapUsedM" : 11.703217
-                }
-              }
-            }
-          ]
-        },
+      "host_components" : [
         {
-          "href" : "http://dev01:8080/api/v1/clusters/vm/services/YARN/components/RESOURCEMANAGER",
-          "ServiceComponentInfo" : {
-            "StartTime" : 1375384390054,
-            "cluster_name" : "vm",
+          "href" : "http://192.168.56.101:8080/api/v1/clusters/perf/hosts/dev01.hortonworks.com/host_components/RESOURCEMANAGER",
+          "HostRoles" : {
+            "cluster_name" : "perf",
             "component_name" : "RESOURCEMANAGER",
-            "service_name" : "YARN",
-            "state" : "STARTED",
-            "desired_configs" : { },
-            "rm_metrics" : {
-              "cluster" : {
-                "activeNMcount" : 1,
-                "decommissionedNMcount" : 0,
-                "lostNMcount" : 0,
-                "nodeManagers" : "[{\"HostName\":\"dev01.hortonworks.com\",\"Rack\":\"/default-rack\",\"State\":\"RUNNING\",\"NodeId\":\"dev01.hortonworks.com:45454\",\"NodeHTTPAddress\":\"dev01.hortonworks.com:8042\",\"LastHealthUpdate\":1375467828765,\"HealthReport\":\"\",\"NumContainers\":0,\"UsedMemoryMB\":0,\"AvailableMemoryMB\":8192}]",
-                "rebootedNMcount" : 0,
-                "unhealthyNMcount" : 0
-              }
-            }
+            "host_nam

<TRUNCATED>

[3/3] git commit: AMBARI-3714 [perf] UI should only request data from master host-components. (atkach)

Posted by at...@apache.org.
AMBARI-3714 [perf] UI should only request data from master host-components. (atkach)


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

Branch: refs/heads/trunk
Commit: 5820bd7c63b2aec52d3fad2cc40cb69be03f6164
Parents: 8944c1d
Author: atkach <an...@gmail.com>
Authored: Thu Nov 7 18:01:25 2013 +0200
Committer: atkach <an...@gmail.com>
Committed: Thu Nov 7 18:01:25 2013 +0200

----------------------------------------------------------------------
 .../assets/data/dashboard/HDP2/services.json    | 2358 ++----------------
 .../app/controllers/global/update_controller.js |   52 +-
 ambari-web/app/mappers/hosts_mapper.js          |    4 +
 ambari-web/app/mappers/server_data_mapper.js    |    4 +-
 ambari-web/app/mappers/service_mapper.js        |  241 +-
 ambari-web/app/mappers/status_mapper.js         |    9 +-
 6 files changed, 360 insertions(+), 2308 deletions(-)
----------------------------------------------------------------------