You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by sr...@apache.org on 2013/08/02 20:46:28 UTC

[1/3] AMBARI-2799. YARN service summary additional information. (onechiporenko via srimanth)

Updated Branches:
  refs/heads/trunk 57b478442 -> 09c2ddae7


http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/09c2ddae/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 4874319..4b1e4f6 100644
--- a/ambari-web/app/mappers/service_mapper.js
+++ b/ambari-web/app/mappers/service_mapper.js
@@ -105,6 +105,10 @@ App.servicesMapper = App.QuickDataMapper.create({
     node_managers_count_unhealthy: 'resourceManagerComponent.ServiceComponentInfo.rm_metrics.cluster.unhealthyNMcount',
     node_managers_count_rebooted: 'resourceManagerComponent.ServiceComponentInfo.rm_metrics.cluster.rebootedNMcount',
     node_managers_count_decommissioned: 'resourceManagerComponent.ServiceComponentInfo.rm_metrics.cluster.decommissionedNMcount',
+    allocated_memory: 'resourceManagerComponent.host_components[0].metrics.yarn.Queue.root.AllocatedMB',
+    reserved_memory: 'resourceManagerComponent.host_components[0].metrics.yarn.Queue.root.ReservedMB',
+    available_memory: 'resourceManagerComponent.host_components[0].metrics.yarn.Queue.root.AvailableMB',
+    queue: 'resourceManagerComponent.queue'
   },
   mapReduce2Config: {
     version: 'jobHistoryServerComponent.ServiceComponentInfo.Version',
@@ -370,6 +374,7 @@ App.servicesMapper = App.QuickDataMapper.create({
   },
   yarnMapper: function (item) {
     var result = [];
+    var self = this;
     var finalConfig = jQuery.extend({}, this.config);
     // Change the JSON so that it is easy to map
     var yarnConfig = this.yarnConfig;
@@ -389,6 +394,12 @@ App.servicesMapper = App.QuickDataMapper.create({
             item.node_manager_live_nodes.push(nm.HostName);
           }
         });
+
+        var root = component.host_components[0].metrics.yarn.Queue.root;
+        var queue = JSON.stringify({
+          'root': self.parseObject(root)
+        });
+        component.queue = queue;
         // extend config
         finalConfig = jQuery.extend(finalConfig, yarnConfig);
       }
@@ -419,6 +430,19 @@ App.servicesMapper = App.QuickDataMapper.create({
 
     return finalJson;
   },
+
+  parseObject: function(obj) {
+    var res = {};
+    for (var p in obj) {
+      if (obj.hasOwnProperty(p)) {
+        if (obj[p] instanceof Object) {
+          res[p] = this.parseObject(obj[p]);
+        }
+      }
+    }
+    return res;
+  },
+
   mapreduce2Mapper: function (item) {
     var result = [];
     var finalConfig = jQuery.extend({}, this.config);

http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/09c2ddae/ambari-web/app/messages.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/messages.js b/ambari-web/app/messages.js
index 9f4517d..4f24640 100644
--- a/ambari-web/app/messages.js
+++ b/ambari-web/app/messages.js
@@ -1213,6 +1213,10 @@ Em.I18n.translations = {
   'dashboard.services.yarn.containers.msg': '{0} allocated / {1} pending / {2} reserved',
   'dashboard.services.yarn.apps': 'Applications',
   'dashboard.services.yarn.apps.msg': '{0} submitted / {1} running / {2} pending / {3} completed / {4} killed / {5} failed',
+  'dashboard.services.yarn.memory': 'Memory',
+  'dashboard.services.yarn.memory.msg': '{0} used / {1} reserved / {2} total',
+  'dashboard.services.yarn.queues': 'Queues',
+  'dashboard.services.yarn.queues.msg': '{0} Queues',
 
   'dashboard.services.mapreduce.summary':'{0} of {1} trackers live, {2} jobs running, {3} jobs waiting',
   'dashboard.services.mapreduce.taskTrackers':'TaskTrackers',

http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/09c2ddae/ambari-web/app/models/service/yarn.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/models/service/yarn.js b/ambari-web/app/models/service/yarn.js
index b4b007f..b094a9b 100644
--- a/ambari-web/app/models/service/yarn.js
+++ b/ambari-web/app/models/service/yarn.js
@@ -16,6 +16,7 @@
  */
 
 var App = require('app');
+var objectUtils = require('utils/object_utils');
 
 App.YARNService = App.Service.extend({
   version: DS.attr('string'),
@@ -39,7 +40,19 @@ App.YARNService = App.Service.extend({
   yarnClientNodes: DS.hasMany('App.Host'),
   resourceManagerStartTime: DS.attr('number'),
   jvmMemoryHeapUsed: DS.attr('number'),
-  jvmMemoryHeapCommitted: DS.attr('number')
+  jvmMemoryHeapCommitted: DS.attr('number'),
+  allocatedMemory: DS.attr('number'),
+  reservedMemory: DS.attr('number'),
+  availableMemory: DS.attr('number'),
+  queue: DS.attr('string'),
+  queueFormatted: function() {
+    var queue = JSON.parse(this.get('queue'));
+    return objectUtils.recursiveTree(queue);
+  }.property('queue'),
+  queuesCount: function() {
+    var queue = JSON.parse(this.get('queue'));
+    return objectUtils.recursiveKeysCount(queue);
+  }.property('queue')
 });
 
 App.YARNService.FIXTURES = [];

http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/09c2ddae/ambari-web/app/templates/main/dashboard/service/yarn.hbs
----------------------------------------------------------------------
diff --git a/ambari-web/app/templates/main/dashboard/service/yarn.hbs b/ambari-web/app/templates/main/dashboard/service/yarn.hbs
index a35b78b..169a120 100644
--- a/ambari-web/app/templates/main/dashboard/service/yarn.hbs
+++ b/ambari-web/app/templates/main/dashboard/service/yarn.hbs
@@ -96,6 +96,16 @@
         <td>{{t dashboard.services.yarn.apps}}</td>
         <td>{{view.apps}}</td>
       </tr>
+      <!-- Memory -->
+      <tr>
+          <td>{{t dashboard.services.yarn.memory}}</td>
+          <td>{{view.memory}}</td>
+      </tr>
+      <!-- Queues -->
+      <tr>
+          <td>{{t dashboard.services.yarn.queues}}</td>
+          <td><a href="#" {{action showQueues target="view"}}>{{view.queues}}</a></td>
+      </tr>
     {{#unless view.showOnlyRows}}
       </tbody>
     </table>

http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/09c2ddae/ambari-web/app/utils/object_utils.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/utils/object_utils.js b/ambari-web/app/utils/object_utils.js
new file mode 100644
index 0000000..e2bf63b
--- /dev/null
+++ b/ambari-web/app/utils/object_utils.js
@@ -0,0 +1,63 @@
+/**
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements.  See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership.  The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License.  You may obtain a copy of the License at
+ *
+ *     http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+var stringUtils = require('utils/string_utils');
+
+module.exports = {
+
+  recursiveKeysCount: function(obj) {
+    if (!(obj instanceof Object)) {
+      return null;
+    }
+
+    function r(obj) {
+      var count = 0;
+      for (var k in obj) {
+        if (obj.hasOwnProperty(k)) {
+          if (obj[k] instanceof Object) {
+            count += 1 + r(obj[k]);
+          }
+        }
+      }
+      return count;
+    }
+
+    return r(obj);
+  },
+
+  recursiveTree: function(obj) {
+    if (!(obj instanceof Object)) {
+      return null;
+    }
+    function r(obj, indx) {
+      var str = '';
+      for (var k in obj) {
+        if (obj.hasOwnProperty(k)) {
+          if (obj[k] instanceof Object) {
+            var spaces = (new Array(indx + 1).join('&nbsp;'));
+            var bull = (indx != 0 ? '&bull; ' : ' '); // empty for "root" element
+            str += spaces + bull + k + '<br />' + r(obj[k], indx + 1);
+          }
+        }
+      }
+      return str;
+    }
+    return r(obj, 0);
+  }
+
+};

http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/09c2ddae/ambari-web/app/views/main/dashboard/service/yarn.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/views/main/dashboard/service/yarn.js b/ambari-web/app/views/main/dashboard/service/yarn.js
index 29bcb96..e0d56ec 100644
--- a/ambari-web/app/views/main/dashboard/service/yarn.js
+++ b/ambari-web/app/views/main/dashboard/service/yarn.js
@@ -105,4 +105,28 @@ App.MainDashboardServiceYARNView = App.MainDashboardServiceView.extend({
     return this.t('dashboard.services.yarn.apps.msg').format(appsSubmitted, appsRunning, appsPending, appsCompleted, appsKilled, appsFailed);
   }.property('service.appsSubmitted', 'service.appsRunning', 'service.appsPending', 'service.appsCompleted', 'service.appsKilled', 'service.appsFailed'),
 
+  memory: function() {
+    return Em.I18n.t('dashboard.services.yarn.memory.msg').format(
+      this.get('service.allocatedMemory').bytesToSize(1, 'parseFloat'),
+      this.get('service.reservedMemory').bytesToSize(1, 'parseFloat'),
+      this.get('service.availableMemory').bytesToSize(1, 'parseFloat')
+    );
+  }.property('service.allocatedMemory', 'service.reservedMemory', 'service.availableMemory'),
+
+  queues: function() {
+    return Em.I18n.t('dashboard.services.yarn.queues.msg').format(this.get('service.queuesCount'));
+  }.property('service.queuesCount'),
+
+  showQueues: function() {
+    var self = this;
+    return App.ModalPopup.show({
+      secondary: null,
+      header: Em.I18n.t('dashboard.services.yarn.queues'),
+      bodyClass: Em.View.extend({
+        template: Em.Handlebars.compile('{{{view.queues}}}'),
+        queues: self.get('service.queueFormatted')
+      })
+    });
+  }
+
 });


[3/3] git commit: AMBARI-2799. YARN service summary additional information. (onechiporenko via srimanth)

Posted by sr...@apache.org.
AMBARI-2799. YARN service summary additional information. (onechiporenko via srimanth)


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

Branch: refs/heads/trunk
Commit: 09c2ddae7a28fbd1e2606c2d3f11e4dd10713bac
Parents: 57b4784
Author: Srimanth Gunturi <sg...@hortonworks.com>
Authored: Fri Aug 2 11:46:09 2013 -0700
Committer: Srimanth Gunturi <sg...@hortonworks.com>
Committed: Fri Aug 2 11:46:09 2013 -0700

----------------------------------------------------------------------
 .../assets/data/dashboard/HDP2/services.json    | 3776 +++++++++---------
 ambari-web/app/mappers/service_mapper.js        |   24 +
 ambari-web/app/messages.js                      |    4 +
 ambari-web/app/models/service/yarn.js           |   15 +-
 .../templates/main/dashboard/service/yarn.hbs   |   10 +
 ambari-web/app/utils/object_utils.js            |   63 +
 .../app/views/main/dashboard/service/yarn.js    |   24 +
 7 files changed, 2004 insertions(+), 1912 deletions(-)
----------------------------------------------------------------------



[2/3] AMBARI-2799. YARN service summary additional information. (onechiporenko via srimanth)

Posted by sr...@apache.org.
http://git-wip-us.apache.org/repos/asf/incubator-ambari/blob/09c2ddae/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 3d45390..b1b4b7f 100644
--- a/ambari-web/app/assets/data/dashboard/HDP2/services.json
+++ b/ambari-web/app/assets/data/dashboard/HDP2/services.json
@@ -1,135 +1,135 @@
 {
-  "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services?fields=components/ServiceComponentInfo,components/host_components,components/host_components/HostRoles",
-  "items": [
+  "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",
+  "items" : [
     {
-      "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/GANGLIA",
-      "ServiceInfo": {
-        "cluster_name": "c1",
-        "service_name": "GANGLIA"
+      "href" : "http://dev01:8080/api/v1/clusters/vm/services/GANGLIA",
+      "ServiceInfo" : {
+        "cluster_name" : "vm",
+        "service_name" : "GANGLIA"
       },
-      "components": [
+      "components" : [
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/GANGLIA/components/GANGLIA_MONITOR",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "GANGLIA_MONITOR",
-            "service_name": "GANGLIA",
-            "state": "STARTED",
-            "desired_configs": { }
+          "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": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/GANGLIA_MONITOR",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "GANGLIA_MONITOR",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "STARTED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "GANGLIA",
-                "stack_id": "HDP-2.0.3",
-                "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"
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/GANGLIA_MONITOR",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "GANGLIA_MONITOR",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "GANGLIA",
+                "stack_id" : "HDP-2.0.3",
+                "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": { }
+                "configs" : { },
+                "desired_configs" : { }
               }
             }
           ]
         },
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/GANGLIA/components/GANGLIA_SERVER",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "GANGLIA_SERVER",
-            "service_name": "GANGLIA",
-            "state": "STARTED",
-            "desired_configs": { }
+          "href" : "http://dev01:8080/api/v1/clusters/vm/services/GANGLIA/components/GANGLIA_SERVER",
+          "ServiceComponentInfo" : {
+            "cluster_name" : "vm",
+            "component_name" : "GANGLIA_SERVER",
+            "service_name" : "GANGLIA",
+            "state" : "STARTED",
+            "desired_configs" : { }
           },
-          "host_components": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/GANGLIA_SERVER",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "GANGLIA_SERVER",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "STARTED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "GANGLIA",
-                "stack_id": "HDP-2.0.3",
-                "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"
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/GANGLIA_SERVER",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "GANGLIA_SERVER",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "GANGLIA",
+                "stack_id" : "HDP-2.0.3",
+                "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": { }
+                "configs" : { },
+                "desired_configs" : { }
               }
             }
           ]
@@ -137,173 +137,186 @@
       ]
     },
     {
-      "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HBASE",
-      "ServiceInfo": {
-        "cluster_name": "c1",
-        "service_name": "HBASE"
+      "href" : "http://dev01:8080/api/v1/clusters/vm/services/HBASE",
+      "ServiceInfo" : {
+        "cluster_name" : "vm",
+        "service_name" : "HBASE"
       },
-      "components": [
+      "components" : [
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HBASE/components/HBASE_CLIENT",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "HBASE_CLIENT",
-            "service_name": "HBASE",
-            "state": "INSTALLED",
-            "desired_configs": { }
+          "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": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/HBASE_CLIENT",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "HBASE_CLIENT",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "INSTALLED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HBASE",
-                "stack_id": "HDP-2.0.3",
-                "state": "INSTALLED",
-                "actual_configs": { },
-                "configs": { },
-                "desired_configs": { }
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/HBASE_CLIENT",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "HBASE_CLIENT",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "INSTALLED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HBASE",
+                "stack_id" : "HDP-2.0.3",
+                "state" : "INSTALLED",
+                "actual_configs" : { },
+                "configs" : { },
+                "desired_configs" : { }
+              },
+              "metrics" : {
+                "cpu" : {
+                  "cpu_wio" : 0.1
+                },
+                "jvm" : {
+                  "memHeapCommittedM" : 28.5041666667,
+                  "memHeapUsedM" : 11.9096411333
+                }
               }
             }
           ]
         },
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HBASE/components/HBASE_MASTER",
-          "ServiceComponentInfo": {
-            "AverageLoad": 2.0,
-            "HeapMemoryMax": 1071579136,
-            "HeapMemoryUsed": 12600208,
-            "MasterActiveTime": 1375290042954,
-            "MasterStartTime": 1375290042930,
-            "NonHeapMemoryMax": 136314880,
-            "NonHeapMemoryUsed": 38262016,
-            "RegionsInTransition": [ ],
-            "Revision": "1a62b76bde7776a433ee069ab47ee6270f8992d4",
-            "Version": "0.94.6.2.0.3.0-116",
-            "cluster_name": "c1",
-            "component_name": "HBASE_MASTER",
-            "service_name": "HBASE",
-            "state": "STARTED",
-            "desired_configs": { }
+          "href" : "http://dev01:8080/api/v1/clusters/vm/services/HBASE/components/HBASE_MASTER",
+          "ServiceComponentInfo" : {
+            "cluster_name" : "vm",
+            "component_name" : "HBASE_MASTER",
+            "service_name" : "HBASE",
+            "state" : "STARTED",
+            "desired_configs" : { }
           },
-          "host_components": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/HBASE_MASTER",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "HBASE_MASTER",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "STARTED",
-                "ha_status": "active",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HBASE",
-                "stack_id": "HDP-2.0.3",
-                "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"
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/HBASE_MASTER",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "HBASE_MASTER",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HBASE",
+                "stack_id" : "HDP-2.0.3",
+                "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": { }
+                "configs" : { },
+                "desired_configs" : { }
+              },
+              "metrics" : {
+                "cpu" : {
+                  "cpu_wio" : 0.1
+                }
               }
             }
           ]
         },
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HBASE/components/HBASE_REGIONSERVER",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "HBASE_REGIONSERVER",
-            "service_name": "HBASE",
-            "state": "STARTED",
-            "desired_configs": { }
+          "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": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/HBASE_REGIONSERVER",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "HBASE_REGIONSERVER",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "STARTED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HBASE",
-                "stack_id": "HDP-2.0.3",
-                "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"
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/HBASE_REGIONSERVER",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "HBASE_REGIONSERVER",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HBASE",
+                "stack_id" : "HDP-2.0.3",
+                "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": { }
+                "configs" : { },
+                "desired_configs" : { }
+              },
+              "metrics" : {
+                "cpu" : {
+                  "cpu_wio" : 0.1
+                },
+                "jvm" : {
+                  "memHeapCommittedM" : 28.5041666667,
+                  "memHeapUsedM" : 11.9096411333
+                }
               }
             }
           ]
@@ -311,37 +324,37 @@
       ]
     },
     {
-      "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HCATALOG",
-      "ServiceInfo": {
-        "cluster_name": "c1",
-        "service_name": "HCATALOG"
+      "href" : "http://dev01:8080/api/v1/clusters/vm/services/HCATALOG",
+      "ServiceInfo" : {
+        "cluster_name" : "vm",
+        "service_name" : "HCATALOG"
       },
-      "components": [
+      "components" : [
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HCATALOG/components/HCAT",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "HCAT",
-            "service_name": "HCATALOG",
-            "state": "INSTALLED",
-            "desired_configs": { }
+          "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_components": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/HCAT",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "HCAT",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "INSTALLED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HCATALOG",
-                "stack_id": "HDP-2.0.3",
-                "state": "INSTALLED",
-                "actual_configs": { },
-                "configs": { },
-                "desired_configs": { }
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/HCAT",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "HCAT",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "INSTALLED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HCATALOG",
+                "stack_id" : "HDP-2.0.3",
+                "state" : "INSTALLED",
+                "actual_configs" : { },
+                "configs" : { },
+                "desired_configs" : { }
               }
             }
           ]
@@ -349,248 +362,266 @@
       ]
     },
     {
-      "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HDFS",
-      "ServiceInfo": {
-        "cluster_name": "c1",
-        "service_name": "HDFS"
+      "href" : "http://dev01:8080/api/v1/clusters/vm/services/HDFS",
+      "ServiceInfo" : {
+        "cluster_name" : "vm",
+        "service_name" : "HDFS"
       },
-      "components": [
+      "components" : [
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HDFS/components/DATANODE",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "DATANODE",
-            "service_name": "HDFS",
-            "state": "STARTED",
-            "desired_configs": { }
+          "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": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/DATANODE",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "DATANODE",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "STARTED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HDFS",
-                "stack_id": "HDP-2.0.3",
-                "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"
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/DATANODE",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "DATANODE",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HDFS",
+                "stack_id" : "HDP-2.0.3",
+                "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": { }
+                "configs" : { },
+                "desired_configs" : { }
+              },
+              "metrics" : {
+                "cpu" : {
+                  "cpu_wio" : 0.1
+                },
+                "jvm" : {
+                  "memHeapCommittedM" : 28.4375,
+                  "memHeapUsedM" : 13.903183
+                }
               }
             }
           ]
         },
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HDFS/components/HDFS_CLIENT",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "HDFS_CLIENT",
-            "service_name": "HDFS",
-            "state": "INSTALLED",
-            "desired_configs": { }
+          "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": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/HDFS_CLIENT",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "HDFS_CLIENT",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "INSTALLED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HDFS",
-                "stack_id": "HDP-2.0.3",
-                "state": "INSTALLED",
-                "actual_configs": { },
-                "configs": { },
-                "desired_configs": { }
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/HDFS_CLIENT",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "HDFS_CLIENT",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "INSTALLED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HDFS",
+                "stack_id" : "HDP-2.0.3",
+                "state" : "INSTALLED",
+                "actual_configs" : { },
+                "configs" : { },
+                "desired_configs" : { }
               }
             }
           ]
         },
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HDFS/components/NAMENODE",
-          "ServiceComponentInfo": {
-            "BlocksTotal": 379,
-            "CapacityRemaining": 45343223808,
-            "CapacityTotal": 52844687359,
-            "CapacityUsed": 182407168,
-            "CorruptBlocks": 0,
-            "DeadNodes": "{}",
-            "DecomNodes": "{}",
-            "HeapMemoryMax": 1006632960,
-            "HeapMemoryUsed": 495427800,
-            "LiveNodes": "{\"dev01.hortonworks.com\":{\"numBlocks\":379,\"usedSpace\":182407168,\"lastContact\":1,\"capacity\":52844687359,\"nonDfsUsedSpace\":7319056383,\"adminState\":\"In Service\"}}",
-            "MissingBlocks": 0,
-            "NonDfsUsedSpace": 7319056383,
-            "NonHeapMemoryMax": 136314880,
-            "NonHeapMemoryUsed": 42028744,
-            "PercentRemaining": 85.8047,
-            "PercentUsed": 0.34517598,
-            "Safemode": "",
-            "StartTime": 1375289702242,
-            "TotalFiles": 617,
-            "UnderReplicatedBlocks": 379,
-            "UpgradeFinalized": true,
-            "Version": "2.1.0.2.0.3.0-116, r707031d22de185c6af3023b0689578b9ec743113",
-            "cluster_name": "c1",
-            "component_name": "NAMENODE",
-            "service_name": "HDFS",
-            "state": "STARTED",
-            "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.ambari.apache.org\":{\"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",
+            "component_name" : "NAMENODE",
+            "service_name" : "HDFS",
+            "state" : "STARTED",
+            "desired_configs" : { }
           },
-          "host_components": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/NAMENODE",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "NAMENODE",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "STARTED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HDFS",
-                "stack_id": "HDP-2.0.3",
-                "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"
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/NAMENODE",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "NAMENODE",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HDFS",
+                "stack_id" : "HDP-2.0.3",
+                "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": { }
+                "configs" : { },
+                "desired_configs" : { }
+              },
+              "metrics" : {
+                "cpu" : {
+                  "cpu_wio" : 0.3
+                },
+                "jvm" : {
+                  "memHeapCommittedM" : 960.0,
+                  "memHeapUsedM" : 186.13074
+                }
               }
             }
           ]
         },
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HDFS/components/SECONDARY_NAMENODE",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "SECONDARY_NAMENODE",
-            "service_name": "HDFS",
-            "state": "STARTED",
-            "desired_configs": { }
+          "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": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/SECONDARY_NAMENODE",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "SECONDARY_NAMENODE",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "STARTED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HDFS",
-                "stack_id": "HDP-2.0.3",
-                "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"
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/SECONDARY_NAMENODE",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "SECONDARY_NAMENODE",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HDFS",
+                "stack_id" : "HDP-2.0.3",
+                "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": { }
+                "configs" : { },
+                "desired_configs" : { }
               }
             }
           ]
@@ -598,226 +629,226 @@
       ]
     },
     {
-      "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HIVE",
-      "ServiceInfo": {
-        "cluster_name": "c1",
-        "service_name": "HIVE"
+      "href" : "http://dev01:8080/api/v1/clusters/vm/services/HIVE",
+      "ServiceInfo" : {
+        "cluster_name" : "vm",
+        "service_name" : "HIVE"
       },
-      "components": [
+      "components" : [
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HIVE/components/HIVE_CLIENT",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "HIVE_CLIENT",
-            "service_name": "HIVE",
-            "state": "INSTALLED",
-            "desired_configs": { }
+          "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": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/HIVE_CLIENT",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "HIVE_CLIENT",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "INSTALLED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HIVE",
-                "stack_id": "HDP-2.0.3",
-                "state": "INSTALLED",
-                "actual_configs": { },
-                "configs": { },
-                "desired_configs": { }
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/HIVE_CLIENT",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "HIVE_CLIENT",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "INSTALLED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HIVE",
+                "stack_id" : "HDP-2.0.3",
+                "state" : "INSTALLED",
+                "actual_configs" : { },
+                "configs" : { },
+                "desired_configs" : { }
               }
             }
           ]
         },
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HIVE/components/HIVE_METASTORE",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "HIVE_METASTORE",
-            "service_name": "HIVE",
-            "state": "STARTED",
-            "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": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/HIVE_METASTORE",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "HIVE_METASTORE",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "STARTED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HIVE",
-                "stack_id": "HDP-2.0.3",
-                "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"
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/HIVE_METASTORE",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "HIVE_METASTORE",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HIVE",
+                "stack_id" : "HDP-2.0.3",
+                "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": { }
+                "configs" : { },
+                "desired_configs" : { }
               }
             }
           ]
         },
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HIVE/components/HIVE_SERVER",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "HIVE_SERVER",
-            "service_name": "HIVE",
-            "state": "STARTED",
-            "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": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/HIVE_SERVER",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "HIVE_SERVER",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "STARTED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HIVE",
-                "stack_id": "HDP-2.0.3",
-                "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"
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/HIVE_SERVER",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "HIVE_SERVER",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HIVE",
+                "stack_id" : "HDP-2.0.3",
+                "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": { }
+                "configs" : { },
+                "desired_configs" : { }
               }
             }
           ]
         },
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/HIVE/components/MYSQL_SERVER",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "MYSQL_SERVER",
-            "service_name": "HIVE",
-            "state": "STARTED",
-            "desired_configs": { }
+          "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": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/MYSQL_SERVER",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "MYSQL_SERVER",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "STARTED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "HIVE",
-                "stack_id": "HDP-2.0.3",
-                "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"
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/MYSQL_SERVER",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "MYSQL_SERVER",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "HIVE",
+                "stack_id" : "HDP-2.0.3",
+                "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": { }
+                "configs" : { },
+                "desired_configs" : { }
               }
             }
           ]
@@ -825,100 +856,106 @@
       ]
     },
     {
-      "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/MAPREDUCE2",
-      "ServiceInfo": {
-        "cluster_name": "c1",
-        "service_name": "MAPREDUCE2"
+      "href" : "http://dev01:8080/api/v1/clusters/vm/services/MAPREDUCE2",
+      "ServiceInfo" : {
+        "cluster_name" : "vm",
+        "service_name" : "MAPREDUCE2"
       },
-      "components": [
+      "components" : [
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/MAPREDUCE2/components/HISTORYSERVER",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "HISTORYSERVER",
-            "service_name": "MAPREDUCE2",
-            "state": "STARTED",
-            "desired_configs": { }
+          "href" : "http://dev01:8080/api/v1/clusters/vm/services/MAPREDUCE2/components/HISTORYSERVER",
+          "ServiceComponentInfo" : {
+            "cluster_name" : "vm",
+            "component_name" : "HISTORYSERVER",
+            "service_name" : "MAPREDUCE2",
+            "state" : "STARTED",
+            "desired_configs" : { }
           },
-          "host_components": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/HISTORYSERVER",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "HISTORYSERVER",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "STARTED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "MAPREDUCE2",
-                "stack_id": "HDP-2.0.3",
-                "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"
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/HISTORYSERVER",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "HISTORYSERVER",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "MAPREDUCE2",
+                "stack_id" : "HDP-2.0.3",
+                "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": { }
+                "configs" : { },
+                "desired_configs" : { }
+              },
+              "metrics" : {
+                "jvm" : {
+                  "memHeapCommittedM" : 28.5625,
+                  "memHeapUsedM" : 10.363014
+                }
               }
             }
           ]
         },
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/MAPREDUCE2/components/MAPREDUCE2_CLIENT",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "MAPREDUCE2_CLIENT",
-            "service_name": "MAPREDUCE2",
-            "state": "INSTALLED",
-            "desired_configs": { }
+          "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": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/MAPREDUCE2_CLIENT",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "MAPREDUCE2_CLIENT",
-                "desired_stack_id": "HDP-2.0.3",
-                "desired_state": "INSTALLED",
-                "ha_status": "passive",
-                "host_name": "dev01.hortonworks.com",
-                "service_name": "MAPREDUCE2",
-                "stack_id": "HDP-2.0.3",
-                "state": "INSTALLED",
-                "actual_configs": { },
-                "configs": { },
-                "desired_configs": { }
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/MAPREDUCE2_CLIENT",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "MAPREDUCE2_CLIENT",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "INSTALLED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "service_name" : "MAPREDUCE2",
+                "stack_id" : "HDP-2.0.3",
+                "state" : "INSTALLED",
+                "actual_configs" : { },
+                "configs" : { },
+                "desired_configs" : { }
               }
             }
           ]
@@ -926,711 +963,695 @@
       ]
     },
     {
-      "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/NAGIOS",
-      "ServiceInfo": {
-        "cluster_name": "c1",
-        "service_name": "NAGIOS"
+      "href" : "http://dev01:8080/api/v1/clusters/vm/services/NAGIOS",
+      "ServiceInfo" : {
+        "cluster_name" : "vm",
+        "service_name" : "NAGIOS"
       },
-      "components": [
+      "components" : [
         {
-          "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/services/NAGIOS/components/NAGIOS_SERVER",
-          "ServiceComponentInfo": {
-            "cluster_name": "c1",
-            "component_name": "NAGIOS_SERVER",
-            "service_name": "NAGIOS",
-            "state": "STARTED",
-            "desired_configs": { }
+          "href" : "http://dev01:8080/api/v1/clusters/vm/services/NAGIOS/components/NAGIOS_SERVER",
+          "ServiceComponentInfo" : {
+            "cluster_name" : "vm",
+            "component_name" : "NAGIOS_SERVER",
+            "service_name" : "NAGIOS",
+            "state" : "STARTED",
+            "desired_configs" : { }
           },
-          "host_components": [
+          "host_components" : [
             {
-              "href": "http://dev01.hortonworks.com:8080/api/v1/clusters/c1/hosts/dev01.hortonworks.com/host_components/NAGIOS_SERVER",
-              "HostRoles": {
-                "cluster_name": "c1",
-                "component_name": "NAGIOS_SERVER",
-                "desired_stack_id": "HDP-2.0.3",
-                "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:15240]",
-                      "last_hard_state_change": "1375289689",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291189",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "0",
-                      "is_flapping": "0",
-                      "last_check": "1375291189",
-                      "service_type": "AMBARI"
-                    },
+              "href" : "http://dev01:8080/api/v1/clusters/vm/hosts/dev01.ambari.apache.org/host_components/NAGIOS_SERVER",
+              "HostRoles" : {
+                "cluster_name" : "vm",
+                "component_name" : "NAGIOS_SERVER",
+                "desired_stack_id" : "HDP-2.0.3",
+                "desired_state" : "STARTED",
+                "ha_status" : "passive",
+                "host_name" : "dev01.ambari.apache.org",
+                "nagios_alerts" : {
+                  "alerts" : [
                     {
-                      "service_description": "DataNode process down",
-                      "host_name": "dev01.hortonworks.com",
-                      "current_attempt": "1",
-                      "current_state": "0",
-                      "plugin_output": "TCP OK - 0.000 second response time on port 50075",
-                      "last_hard_state_change": "1375289692",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291252",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "0",
-                      "is_flapping": "0",
-                      "last_check": "1375291252",
-                      "service_type": "HDFS"
+                      "service_description" : "Check ambari-agent process",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "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 storage full",
-                      "host_name": "dev01.hortonworks.com",
-                      "current_attempt": "1",
-                      "current_state": "0",
-                      "plugin_output": "OK: Capacity:[52844687359], Remaining Capacity:[45343248384], percent_full:[14.195256609314]",
-                      "last_hard_state_change": "1375289695",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291195",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "0",
-                      "is_flapping": "0",
-                      "last_check": "1375291195",
-                      "service_type": "HDFS"
+                      "service_description" : "DataNode process down",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "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": "Ganglia Collector [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": "1375289698",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291273",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "0",
-                      "is_flapping": "0",
-                      "last_check": "1375291273",
-                      "service_type": "GANGLIA"
+                      "service_description" : "DataNode storage full",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "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 Collector [gmond] process down alert for History Server 2",
-                      "host_name": "dev01.hortonworks.com",
-                      "current_attempt": "1",
-                      "current_state": "0",
-                      "plugin_output": "TCP OK - 0.001 second response time on port 8666",
-                      "last_hard_state_change": "1375289701",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291276",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "0",
-                      "is_flapping": "0",
-                      "last_check": "1375291276",
-                      "service_type": "GANGLIA"
+                      "service_description" : "Ganglia Collector [gmond] process down alert for HBase Master",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "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 Collector [gmond] process down alert for JobTracker",
-                      "host_name": "dev01.hortonworks.com",
-                      "current_attempt": "4",
-                      "current_state": "2",
-                      "plugin_output": "Connection refused",
-                      "last_hard_state_change": "1375289749",
-                      "last_hard_state": "2",
-                      "last_time_ok": "0",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "1375291279",
-                      "is_flapping": "0",
-                      "last_check": "1375291279",
-                      "service_type": "GANGLIA"
+                      "service_description" : "Ganglia Collector [gmond] process down alert for History Server 2",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "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 Collector [gmond] process down alert for NameNode",
-                      "host_name": "dev01.hortonworks.com",
-                      "current_attempt": "1",
-                      "current_state": "0",
-                      "plugin_output": "TCP OK - 0.001 second response time on port 8661",
-                      "last_hard_state_change": "1375289707",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291282",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "0",
-                      "is_flapping": "0",
-                      "last_check": "1375291282",
-                      "service_type": "GANGLIA"
+                      "service_description" : "Ganglia Collector [gmond] process down alert for NameNode",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "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 Collector [gmond] process down alert for Node Manager",
-                      "host_name": "dev01.hortonworks.com",
-                      "current_attempt": "1",
-                      "current_state": "0",
-                      "plugin_output": "TCP OK - 0.000 second response time on port 8660",
-                      "last_hard_state_change": "1375289710",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291285",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "0",
-                      "is_flapping": "0",
-                      "last_check": "1375291285",
-                      "service_type": "GANGLIA"
+                      "service_description" : "Ganglia Collector [gmond] process down alert for Node Manager",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "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 Collector [gmond] process down alert for Resource Manager",
-                      "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": "1375289713",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291273",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "0",
-                      "is_flapping": "0",
-                      "last_check": "1375291273",
-                      "service_type": "GANGLIA"
+                      "service_description" : "Ganglia Collector [gmond] process down alert for Resource Manager",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "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 Collector [gmond] process down alert for slaves",
-                      "host_name": "dev01.hortonworks.com",
-                      "current_attempt": "1",
-                      "current_state": "0",
-                      "plugin_output": "TCP OK - 0.006 second response time on port 8660",
-                      "last_hard_state_change": "1375289716",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291276",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "0",
-                      "is_flapping": "0",
-                      "last_check": "1375291276",
-                      "service_type": "GANGLIA"
+                      "service_description" : "Ganglia Collector [gmond] process down alert for slaves",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "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.009 second response time on port 8651",
-                      "last_hard_state_change": "1375289719",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291279",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "0",
-                      "is_flapping": "0",
-                      "last_check": "1375291279",
-                      "service_type": "GANGLIA"
+                      "service_description" : "Ganglia [gmetad] process down",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "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:&lt;1&gt;, affected:&lt;0&gt;",
-                      "last_hard_state_change": "1375290292",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291282",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "1375290262",
-                      "is_flapping": "0",
-                      "last_check": "1375291282",
-                      "service_type": "HBASE"
+                      "service_description" : "Percent RegionServers down",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "current_attempt" : "1",
+                      "current_state" : "0",
+                      "plugin_output" : "OK: total:&lt;1&gt;, affected:&lt;0&gt;",
+                      "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 30.0% &lt; 200% : OK",
-                      "last_hard_state_change": "1375289724",
-                      "last_hard_state": "0",
-                      "last_time_ok": "1375291224",
-                      "last_time_warning": "0",
-                      "last_time_unknown": "0",
-                      "last_time_critical": "0",
-                      "is_flapping": "0",
-                      "last_check": "1375291224",
-                      "service_type": "HBASE"
+                      "service_description" : "HBase Master CPU utilization",
+                      "host_name" : "dev01.ambari.apache.org",
+                      "current_attempt" : "1",
+                      "current_state" : "0",
+                      "plugin_output" : "1 CPU, load 13.0% &lt; 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"

<TRUNCATED>