You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by sw...@apache.org on 2015/06/10 18:53:52 UTC

[1/3] ambari git commit: AMBARI-11824. Views: Tez View should automatically work out of the box in Ambari 2.1. (swagle)

Repository: ambari
Updated Branches:
  refs/heads/trunk 1df38e6de -> 0f7130749


AMBARI-11824. Views: Tez View should automatically work out of the box in Ambari 2.1. (swagle)


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

Branch: refs/heads/trunk
Commit: 614fd801fc489fe27cbb0ea6f1ac4a09ebd75477
Parents: 1df38e6
Author: Siddharth Wagle <sw...@hortonworks.com>
Authored: Tue Jun 9 17:56:18 2015 -0700
Committer: Siddharth Wagle <sw...@hortonworks.com>
Committed: Wed Jun 10 09:42:52 2015 -0700

----------------------------------------------------------------------
 .../server/api/services/AmbariMetaInfo.java     |  9 +++++
 .../commands/StackAdvisorCommand.java           | 12 +++++++
 .../stacks/HDP/2.1/services/stack_advisor.py    |  1 +
 .../stacks/HDP/2.3/services/stack_advisor.py    | 36 ++++++++++++++++++++
 .../src/main/resources/stacks/stack_advisor.py  |  7 +++-
 .../commands/StackAdvisorCommandTest.java       | 22 ++++++++++++
 6 files changed, 86 insertions(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/614fd801/ambari-server/src/main/java/org/apache/ambari/server/api/services/AmbariMetaInfo.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AmbariMetaInfo.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AmbariMetaInfo.java
index a8afcf4..a77f7b1 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/AmbariMetaInfo.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/AmbariMetaInfo.java
@@ -206,6 +206,8 @@ public class AmbariMetaInfo {
    */
   private StackManager stackManager;
 
+  private Configuration conf;
+
   /**
    * Ambari Meta Info Object
    *
@@ -214,6 +216,7 @@ public class AmbariMetaInfo {
    */
   @Inject
   public AmbariMetaInfo(Configuration conf) throws Exception {
+    this.conf = conf;
     String stackPath = conf.getMetadataPath();
     stackRoot = new File(stackPath);
 
@@ -1283,4 +1286,10 @@ public class AmbariMetaInfo {
     return kerberosServiceDescriptors;
   }
 
+  /* Return ambari.properties from configuration API. This is to avoid
+  changing interface impls that do not use injection or use partial
+  injection like Stack Advisor Commands */
+  public Map<String, String> getAmbariServerProperties() {
+    return conf.getAmbariProperties();
+  }
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/614fd801/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommand.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommand.java b/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommand.java
index 505ea17..00c8696 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommand.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommand.java
@@ -46,6 +46,7 @@ import org.apache.ambari.server.api.services.stackadvisor.StackAdvisorRunner;
 import org.apache.ambari.server.controller.spi.Resource;
 import org.apache.commons.collections.CollectionUtils;
 import org.apache.commons.io.FileUtils;
+import org.apache.commons.lang.StringUtils;
 import org.apache.commons.logging.Log;
 import org.apache.commons.logging.LogFactory;
 import org.codehaus.jackson.JsonNode;
@@ -87,6 +88,7 @@ public abstract class StackAdvisorCommand<T extends StackAdvisorResponse> extend
   private static final String COMPONENT_HOSTNAMES_PROPERTY = "hostnames";
   private static final String CONFIGURATIONS_PROPERTY = "configurations";
   private static final String CHANGED_CONFIGURATIONS_PROPERTY = "changed-configurations";
+  private static final String AMBARI_SERVER_CONFIGURATIONS_PROPERTY = "ambari-server-properties";
 
   private File recommendationsDir;
   private String stackAdvisorScript;
@@ -148,6 +150,7 @@ public abstract class StackAdvisorCommand<T extends StackAdvisorResponse> extend
       populateComponentHostsMap(root, request.getComponentHostsMap());
       populateConfigurations(root, request);
       populateConfigGroups(root, request);
+      populateAmbariServerInfo(root);
       data.servicesJSON = mapper.writeValueAsString(root);
     } catch (Exception e) {
       // should not happen
@@ -159,6 +162,15 @@ public abstract class StackAdvisorCommand<T extends StackAdvisorResponse> extend
     return data;
   }
 
+  protected void populateAmbariServerInfo(ObjectNode root) throws StackAdvisorException {
+    Map<String, String> serverProperties = metaInfo.getAmbariServerProperties();
+
+    if (serverProperties != null && !serverProperties.isEmpty()) {
+      JsonNode serverPropertiesNode = mapper.convertValue(serverProperties, JsonNode.class);
+      root.put(AMBARI_SERVER_CONFIGURATIONS_PROPERTY, serverPropertiesNode);
+    }
+  }
+
   private void populateConfigurations(ObjectNode root,
                                       StackAdvisorRequest request) {
     Map<String, Map<String, Map<String, String>>> configurations =

http://git-wip-us.apache.org/repos/asf/ambari/blob/614fd801/ambari-server/src/main/resources/stacks/HDP/2.1/services/stack_advisor.py
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.1/services/stack_advisor.py b/ambari-server/src/main/resources/stacks/HDP/2.1/services/stack_advisor.py
index 44595be..1607287 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.1/services/stack_advisor.py
+++ b/ambari-server/src/main/resources/stacks/HDP/2.1/services/stack_advisor.py
@@ -54,6 +54,7 @@ class HDP21StackAdvisor(HDP206StackAdvisor):
                    "-server -Xmx" + str(int(0.8 * clusterData["amMemory"]))
                    + "m -Djava.net.preferIPv4Stack=true -XX:+UseNUMA -XX:+UseParallelGC")
 
+
   def getNotPreferableOnServerComponents(self):
     return ['STORM_UI_SERVER', 'DRPC_SERVER', 'STORM_REST_API', 'NIMBUS', 'GANGLIA_SERVER']
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/614fd801/ambari-server/src/main/resources/stacks/HDP/2.3/services/stack_advisor.py
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.3/services/stack_advisor.py b/ambari-server/src/main/resources/stacks/HDP/2.3/services/stack_advisor.py
index e65736e..0838e4a 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.3/services/stack_advisor.py
+++ b/ambari-server/src/main/resources/stacks/HDP/2.3/services/stack_advisor.py
@@ -16,6 +16,9 @@ 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.
 """
+import os
+import fnmatch
+import socket
 
 class HDP23StackAdvisor(HDP22StackAdvisor):
 
@@ -45,6 +48,39 @@ class HDP23StackAdvisor(HDP22StackAdvisor):
       if services["configurations"]["tez-site"]["properties"]["tez.runtime.sorter.class"] == "LEGACY":
         putTezAttribute = self.putPropertyAttribute(configurations, "tez-site")
         putTezAttribute("tez.runtime.io.sort.mb", "maximum", 2047)
+    pass
+
+    serverProperties = services["ambari-server-properties"]
+    latest_tez_jar_version = None
+
+    server_host = socket.getfqdn()
+    server_port = '8080'
+    views_dir = '/var/lib/ambari-server/resources/views/'
+
+    if serverProperties:
+      if 'client.api.port' in serverProperties:
+        server_port = serverProperties['client.api.port']
+      if 'views.dir' in serverProperties:
+        views_dir = serverProperties['views.dir']
+
+      if os.path.exists(views_dir) and os.path.isdir(views_dir):
+        last_version = '0.0.0'
+        for file in os.listdir(views_dir):
+          if fnmatch.fnmatch(file, 'tez-view*.jar'):
+            current_version = file.lstrip("tez-view-")[:-4] # E.g.: tez-view-2.1.0.2043.jar
+            if self.versionCompare(current_version, last_version) >= 0:
+              latest_tez_jar_version = current_version
+              last_version = current_version
+            pass
+        pass
+      pass
+    pass
+
+
+    if latest_tez_jar_version:
+      tez_url = 'http://{0}:{1}/views/TEZ/{2}/TEZ_CLUSTER_INSTANCE'.format(server_host, server_port, latest_tez_jar_version)
+      putTezProperty("tez.tez-ui.history-url.base", tez_url)
+    pass
 
   def recommendHBASEConfigurations(self, configurations, clusterData, services, hosts):
     super(HDP23StackAdvisor, self).recommendHBASEConfigurations(configurations, clusterData, services, hosts)

http://git-wip-us.apache.org/repos/asf/ambari/blob/614fd801/ambari-server/src/main/resources/stacks/stack_advisor.py
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/stack_advisor.py b/ambari-server/src/main/resources/stacks/stack_advisor.py
index 767e565..0ef953d 100644
--- a/ambari-server/src/main/resources/stacks/stack_advisor.py
+++ b/ambari-server/src/main/resources/stacks/stack_advisor.py
@@ -20,7 +20,6 @@ limitations under the License.
 import socket
 import re
 
-
 class StackAdvisor(object):
   """
   Abstract class implemented by all stack advisors. Stack advisors advise on stack specific questions. 
@@ -756,3 +755,9 @@ class DefaultStackAdvisor(StackAdvisor):
               dependencies.append(dependency)
 
     return  dependencies
+
+  def versionCompare(self, version1, version2):
+    def normalize(v):
+      return [int(x) for x in re.sub(r'(\.0+)*$','', v).split(".")]
+    return cmp(normalize(version1), normalize(version2))
+  pass
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/614fd801/ambari-server/src/test/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommandTest.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommandTest.java b/ambari-server/src/test/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommandTest.java
index 3f21bce..263bbe1 100644
--- a/ambari-server/src/test/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommandTest.java
+++ b/ambari-server/src/test/java/org/apache/ambari/server/api/services/stackadvisor/commands/StackAdvisorCommandTest.java
@@ -35,6 +35,7 @@ import java.io.IOException;
 import java.util.Arrays;
 import java.util.Collections;
 import java.util.Iterator;
+import java.util.Map;
 
 import javax.ws.rs.WebApplicationException;
 
@@ -213,6 +214,27 @@ public class StackAdvisorCommandTest {
   }
 
   @Test
+  public void testPopulateAmbariServerProperties() throws Exception {
+    File file = mock(File.class);
+    StackAdvisorRunner stackAdvisorRunner = mock(StackAdvisorRunner.class);
+    AmbariMetaInfo ambariMetaInfo = mock(AmbariMetaInfo.class);
+    StackAdvisorCommand<TestResource> cmd = new TestStackAdvisorCommand(file, "test", 1,
+      stackAdvisorRunner, ambariMetaInfo);
+    ObjectNode objectNode = (ObjectNode) cmd.mapper.readTree("{\"Versions\": " +
+      "{\"stack_name\": \"stack\", \"stack_version\":\"1.0.0\"}}");
+
+    Map<String, String> props = Collections.singletonMap("a", "b");
+
+    doReturn(props).when(ambariMetaInfo).getAmbariServerProperties();
+
+    cmd.populateAmbariServerInfo(objectNode);
+
+    JsonNode serverProperties = objectNode.get("ambari-server-properties");
+    assertNotNull(serverProperties);
+    assertEquals("b", serverProperties.iterator().next().getTextValue());
+  }
+
+  @Test
   public void testPopulateStackHierarchy_noParents() throws Exception {
     File file = mock(File.class);
     StackAdvisorRunner stackAdvisorRunner = mock(StackAdvisorRunner.class);


[2/3] ambari git commit: AMBARI-11844. HBase service: Open Connections and Request Handlers widgets does not display with HDP 2.2 stack deployment.

Posted by sw...@apache.org.
http://git-wip-us.apache.org/repos/asf/ambari/blob/0f713074/ambari-server/src/main/resources/stacks/HDP/2.3/services/HBASE/metrics.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.3/services/HBASE/metrics.json b/ambari-server/src/main/resources/stacks/HDP/2.3/services/HBASE/metrics.json
new file mode 100644
index 0000000..a309ec7
--- /dev/null
+++ b/ambari-server/src/main/resources/stacks/HDP/2.3/services/HBASE/metrics.json
@@ -0,0 +1,9410 @@
+{
+  "HBASE_REGIONSERVER": {
+    "Component": [
+      {
+        "type": "ganglia",
+        "metrics": {
+          "default": {
+            "metrics/cpu/cpu_idle":{
+              "metric":"cpu_idle",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/cpu/cpu_nice":{
+              "metric":"cpu_nice",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/cpu/cpu_system":{
+              "metric":"cpu_system",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/cpu/cpu_user":{
+              "metric":"cpu_user",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/cpu/cpu_wio":{
+              "metric":"cpu_wio",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/disk/disk_free":{
+              "metric":"disk_free",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/disk/disk_total":{
+              "metric":"disk_total",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/disk/read_bps":{
+              "metric":"read_bps",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/disk/write_bps":{
+              "metric":"write_bps",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/load/load_fifteen":{
+              "metric":"load_fifteen",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/load/load_five":{
+              "metric":"load_five",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/load/load_one":{
+              "metric":"load_one",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/memory/mem_buffers":{
+              "metric":"mem_buffers",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/memory/mem_cached":{
+              "metric":"mem_cached",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/memory/mem_free":{
+              "metric":"mem_free",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/memory/mem_shared":{
+              "metric":"mem_shared",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/memory/mem_total":{
+              "metric":"mem_total",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/memory/swap_free":{
+              "metric":"swap_free",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/memory/swap_total":{
+              "metric":"swap_total",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/network/bytes_in":{
+              "metric":"bytes_in",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/network/bytes_out":{
+              "metric":"bytes_out",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/network/pkts_in":{
+              "metric":"pkts_in",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/network/pkts_out":{
+              "metric":"pkts_out",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/process/proc_run":{
+              "metric":"proc_run",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/process/proc_total":{
+              "metric":"proc_total",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/disk/read_count":{
+              "metric":"read_count",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/disk/write_count":{
+              "metric":"write_count",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/disk/read_bytes":{
+              "metric":"read_bytes",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/disk/write_bytes":{
+              "metric":"write_bytes",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/disk/read_time":{
+              "metric":"read_time",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/disk/write_time":{
+              "metric":"write_time",
+              "pointInTime":true,
+              "temporal":true
+            },
+            "metrics/hbase/regionserver/mutationsWithoutWALSize": {
+              "metric": "regionserver.Server.mutationsWithoutWALSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/slowAppendCount": {
+              "metric": "regionserver.Server.slowAppendCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/disk/part_max_used": {
+              "metric": "part_max_used",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheCount": {
+              "metric": "regionserver.Server.blockCacheCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/ugi/loginSuccess_num_ops": {
+              "metric": "ugi.UgiMetrics.LoginSuccessNumOps",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/memHeapCommittedM": {
+              "metric": "jvm.JvmMetrics.MemHeapCommittedM",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/threadsRunnable": {
+              "metric": "jvm.JvmMetrics.ThreadsRunnable",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_min": {
+              "metric": "regionserver.Server.Delete_min",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/jvm/threadsNew": {
+              "metric": "jvm.JvmMetrics.ThreadsNew",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/rpc/rpcAuthorizationFailures": {
+              "metric": "regionserver.RegionServer.authorizationFailures",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/rpc/RpcQueueTime_avg_time": {
+              "metric": "regionserver.RegionServer.QueueCallTime_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/boottime": {
+              "metric": "boottime",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/writeRequestsCount": {
+              "metric": "regionserver.Server.writeRequestCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/getRequestLatency_min": {
+              "metric": "regionserver.Server.Get_min",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/rpc/RpcProcessingTime_num_ops": {
+              "metric": "regionserver.RegionServer.ProcessCallTime_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/logError": {
+              "metric": "jvm.JvmMetrics.LogError",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_75th_percentile": {
+              "metric": "regionserver.Server.Mutate_75th_percentile",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheHitCount": {
+              "metric": "regionserver.Server.blockCacheHitCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/slowPutCount": {
+              "metric": "regionserver.Server.slowPutCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/rpc/regionServerStartup_avg_time": {
+              "metric": "regionserver.Server.regionServerStartTime",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheSize": {
+              "metric": "regionserver.Server.blockCacheSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/jvm/threadsBlocked": {
+              "metric": "jvm.JvmMetrics.ThreadsBlocked",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_median": {
+              "metric": "regionserver.Server.Mutate_median",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/readRequestsCount": {
+              "metric": "regionserver.Server.readRequestCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_min": {
+              "metric": "regionserver.Server.Mutate_min",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/storefileIndexSizeMB": {
+              "metric": "regionserver.Server.storeFileIndexSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_median": {
+              "metric": "regionserver.Server.Delete_median",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/Get_num_ops": {
+              "metric": "regionserver.Server.Get_num_ops",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/ScanNext_num_ops": {
+              "metric": "regionserver.Server.ScanNext_num_ops",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/Append_num_ops": {
+              "metric": "regionserver.Server.Append_num_ops",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/Delete_num_ops": {
+              "metric": "regionserver.Server.Delete_num_ops",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/Mutate_num_ops": {
+              "metric": "regionserver.Server.Mutate_num_ops",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/Increment_num_ops": {
+              "metric": "regionserver.Server.Increment_num_ops",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/Get_95th_percentile": {
+              "metric": "regionserver.Server.Get_95th_percentile",
+              "unit": "ms",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/ScanNext_95th_percentile": {
+              "metric": "regionserver.Server.ScanNext_95th_percentile",
+              "unit": "ms",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/Mutate_95th_percentile": {
+              "metric": "regionserver.Server.Mutate_95th_percentile",
+              "unit": "ms",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/Increment_95th_percentile": {
+              "metric": "regionserver.Server.Increment_95th_percentile",
+              "unit": "ms",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/Append_95th_percentile": {
+              "metric": "regionserver.Server.Append_95th_percentile",
+              "unit": "ms",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/Delete_95th_percentile": {
+              "metric": "regionserver.Server.Delete_95th_percentile",
+              "unit": "ms",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/percentFilesLocal": {
+              "metric": "regionserver.Server.percentFilesLocal",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/Server/updatesBlockedTime": {
+              "metric": "regionserver.Server.updatesBlockedTime",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/ipc/IPC/numOpenConnections": {
+              "metric": "regionserver.RegionServer.numOpenConnections",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/ipc/IPC/numActiveHandler": {
+              "metric": "regionserver.RegionServer.numActiveHandler",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/ipc/IPC/numCallsInGeneralQueue": {
+              "metric": "regionserver.RegionServer.numCallsInGeneralQueue",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_mean": {
+              "metric": "regionserver.Server.Mutate_mean",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/rpc/RpcProcessingTime_avg_time": {
+              "metric": "regionserver.RegionServer.ProcessCallTime_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+           "metrics/rpc/rpcAuthenticationFailures": {
+              "metric": "regionserver.RegionServer.authenticationFailures",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheHitRatio": {
+              "metric": "regionserver.Server.blockCacheCountHitPercent",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheHitPercent": {
+              "metric": "regionserver.Server.blockCountHitPercent",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheEvictedCount": {
+              "metric": "regionserver.Server.blockCacheEvictionCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_99th_percentile": {
+              "metric": "regionserver.Server.Mutate_99th_percentile",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/getRequestLatency_max": {
+              "metric": "regionserver.Server.Get_max",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/ugi/loginFailure_avg_time": {
+              "metric": "ugi.UgiMetrics.LoginFailureAvgTime",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/logFatal": {
+              "metric": "jvm.JvmMetrics.LogFatal",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/getRequestLatency_99th_percentile": {
+              "metric": "regionserver.Server.Get_99th_percentile",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/ugi/loginSuccess_avg_time": {
+              "metric": "ugi.UgiMetrics.LoginSuccessAvgTime",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_99th_percentile": {
+              "metric": "regionserver.Server.Delete_99th_percentile",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/jvm/memNonHeapUsedM": {
+              "metric": "jvm.JvmMetrics.MemNonHeapUsedM",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/slowIncrementCount": {
+              "metric": "regionserver.Server.slowIncrementCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/compactionQueueSize": {
+              "metric": "regionserver.Server.compactionQueueLength",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/flushTime_num_ops": {
+              "metric": "regionserver.Server.FlushTime_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/getRequestLatency_75th_percentile": {
+              "metric": "regionserver.Server.Get_75th_percentile",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/jvm/memNonHeapCommittedM": {
+              "metric": "jvm.JvmMetrics.MemNonHeapCommittedM",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/stores": {
+              "metric": "regionserver.Server.storeCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/ugi/loginFailure_num_ops": {
+              "metric": "ugi.UgiMetrics.LoginFailureNumOps",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/rpc/rpcAuthenticationSuccesses": {
+              "metric": "regionserver.RegionServer.authenticationSuccesses",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/rpc/ReceivedBytes": {
+              "metric": "regionserver.RegionServer.receivedBytes",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/gcTimeMillis": {
+              "metric": "jvm.JvmMetrics.GcTimeMillis",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/threadsTerminated": {
+              "metric": "jvm.JvmMetrics.ThreadsTerminated",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_max": {
+              "metric": "regionserver.Server.Mutate_max",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/getRequestLatency_mean": {
+              "metric": "regionserver.Server.Get_mean",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/regions": {
+              "metric": "regionserver.Server.regionCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheFree": {
+              "metric": "regionserver.Server.blockCacheFreeSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheMissCount": {
+              "metric": "regionserver.Server.blockCacheMissCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/flushQueueSize": {
+              "metric": "regionserver.Server.flushQueueLength",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/rpc/RpcQueueTime_num_ops": {
+              "metric": "regionserver.RegionServer.QueueCallTime_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_mean": {
+              "metric": "regionserver.Server.Delete_mean",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/cpu/cpu_aidle": {
+              "metric": "cpu_aidle",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/totalStaticIndexSizeKB": {
+              "metric": "regionserver.Server.staticIndexSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/mutationsWithoutWALCount": {
+              "metric": "regionserver.Server.mutationsWithoutWALCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/getRequestLatency_median": {
+              "metric": "regionserver.Server.Get_median",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/cpu/cpu_speed": {
+              "metric": "cpu_speed",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_max": {
+              "metric": "regionserver.Server.Delete_max",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/rpc/SentBytes": {
+              "metric": "regionserver.RegionServer.sentBytes",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/logWarn": {
+              "metric": "jvm.JvmMetrics.LogWarn",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/maxMemoryM": {
+              "metric": "jvm.metrics.maxMemoryM",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/threadsTimedWaiting": {
+              "metric": "jvm.JvmMetrics.ThreadsTimedWaiting",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/gcCount": {
+              "metric": "jvm.JvmMetrics.GcCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/flushTime_avg_time": {
+              "metric": "regionserver.Server.FlushTime_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/memHeapUsedM": {
+              "metric": "jvm.JvmMetrics.MemHeapUsedM",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/threadsWaiting": {
+              "metric": "jvm.JvmMetrics.ThreadsWaiting",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/slowGetCount": {
+              "metric": "regionserver.Server.slowGetCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/requests": {
+              "metric": "regionserver.Server.totalRequestCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/storefiles": {
+              "metric": "regionserver.Server.storeFileCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/slowDeleteCount": {
+              "metric": "regionserver.Server.slowDeleteCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/jvm/logInfo": {
+              "metric": "jvm.JvmMetrics.LogInfo",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/hlogFileCount": {
+              "metric": "regionserver.Server.hlogFileCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_95th_percentile": {
+              "metric": "regionserver.Server.Delete_95th_percentile",
+              "unit": "ms",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/memstoreSize": {
+              "metric": "regionserver.Server.memStoreSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_75th_percentile": {
+              "metric": "regionserver.Server.Delete_75th_percentile",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/rpc/rpcAuthorizationSuccesses": {
+              "metric": "regionserver.RegionServer.authorizationSuccesses",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/totalStaticBloomSizeKB": {
+              "metric": "regionserver.Server.staticBloomSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/rpc/increment_avg_time": {
+              "metric": "regionserver.Server.Increment_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/JvmMetrics/GcCountConcurrentMarkSweep": {
+              "metric": "jvm.JvmMetrics.GcCountConcurrentMarkSweep",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/JvmMetrics/GcCountParNew": {
+              "metric": "jvm.JvmMetrics.GcCountParNew",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/JvmMetrics/GcTimeMillisConcurrentMarkSweep": {
+              "metric": "jvm.JvmMetrics.GcTimeMillisConcurrentMarkSweep",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/JvmMetrics/GcTimeMillisParNew": {
+              "metric": "jvm.JvmMetrics.GcTimeMillisParNew",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/JvmMetrics/MemHeapMaxM": {
+              "metric": "jvm.JvmMetrics.MemHeapMaxM",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/JvmMetrics/MemMaxM": {
+              "metric": "jvm.JvmMetrics.MemMaxM",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/JvmMetrics/MemNonHeapMaxM": {
+              "metric": "jvm.JvmMetrics.MemNonHeapMaxM",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/DroppedPubAll": {
+              "metric": "metricssystem.MetricsSystem.DroppedPubAll",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/NumActiveSinks": {
+              "metric": "metricssystem.MetricsSystem.NumActiveSinks",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/NumActiveSources": {
+              "metric": "metricssystem.MetricsSystem.NumActiveSources",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/NumAllSinks": {
+              "metric": "metricssystem.MetricsSystem.NumAllSinks",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/NumAllSources": {
+              "metric": "metricssystem.MetricsSystem.NumAllSources",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/PublishAvgTime": {
+              "metric": "metricssystem.MetricsSystem.PublishAvgTime",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/PublishNumOps": {
+              "metric": "metricssystem.MetricsSystem.PublishNumOps",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/Sink_timelineAvgTime": {
+              "metric": "metricssystem.MetricsSystem.Sink_timelineAvgTime",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/Sink_timelineDropped": {
+              "metric": "metricssystem.MetricsSystem.Sink_timelineDropped",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/Sink_timelineNumOps": {
+              "metric": "metricssystem.MetricsSystem.Sink_timelineNumOps",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/Sink_timelineQsize": {
+              "metric": "metricssystem.MetricsSystem.Sink_timelineQsize",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/SnapshotAvgTime": {
+              "metric": "metricssystem.MetricsSystem.SnapshotAvgTime",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/metricssystem/MetricsSystem/SnapshotNumOps": {
+              "metric": "metricssystem.MetricsSystem.SnapshotNumOps",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/numCallsInPriorityQueue": {
+              "metric": "regionserver.RegionServer.numCallsInPriorityQueue",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/numCallsInReplicationQueue": {
+              "metric": "regionserver.RegionServer.numCallsInReplicationQueue",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/ProcessCallTime_75th_percentile": {
+              "metric": "regionserver.RegionServer.ProcessCallTime_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/ProcessCallTime_95th_percentile": {
+              "metric": "regionserver.RegionServer.ProcessCallTime_95th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/ProcessCallTime_99th_percentile": {
+              "metric": "regionserver.RegionServer.ProcessCallTime_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/ProcessCallTime_max": {
+              "metric": "regionserver.RegionServer.ProcessCallTime_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/ProcessCallTime_mean": {
+              "metric": "regionserver.RegionServer.ProcessCallTime_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/ProcessCallTime_min": {
+              "metric": "regionserver.RegionServer.ProcessCallTime_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/QueueCallTime_75th_percentile": {
+              "metric": "regionserver.RegionServer.QueueCallTime_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/QueueCallTime_95th_percentile": {
+              "metric": "regionserver.RegionServer.QueueCallTime_95th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/QueueCallTime_99th_percentile": {
+              "metric": "regionserver.RegionServer.QueueCallTime_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/QueueCallTime_max": {
+              "metric": "regionserver.RegionServer.QueueCallTime_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/QueueCallTime_mean": {
+              "metric": "regionserver.RegionServer.QueueCallTime_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/QueueCallTime_min": {
+              "metric": "regionserver.RegionServer.QueueCallTime_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/queueSize": {
+              "metric": "regionserver.RegionServer.queueSize",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/TotalCallTime_75th_percentile": {
+              "metric": "regionserver.RegionServer.TotalCallTime_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/TotalCallTime_95th_percentile": {
+              "metric": "regionserver.RegionServer.TotalCallTime_95th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/TotalCallTime_99th_percentile": {
+              "metric": "regionserver.RegionServer.TotalCallTime_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/TotalCallTime_max": {
+              "metric": "regionserver.RegionServer.TotalCallTime_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/TotalCallTime_mean": {
+              "metric": "regionserver.RegionServer.TotalCallTime_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/TotalCallTime_median": {
+              "metric": "regionserver.RegionServer.TotalCallTime_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/TotalCallTime_min": {
+              "metric": "regionserver.RegionServer.TotalCallTime_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/RegionServer/TotalCallTime_num_ops": {
+              "metric": "regionserver.RegionServer.TotalCallTime_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Replication/sink/ageOfLastAppliedOp": {
+              "metric": "regionserver.Replication.sink.ageOfLastAppliedOp",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Replication/sink/appliedBatches": {
+              "metric": "regionserver.Replication.sink.appliedBatches",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Replication/sink/appliedOps": {
+              "metric": "regionserver.Replication.sink.appliedOps",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Append_75th_percentile": {
+              "metric": "regionserver.Server.Append_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Append_99th_percentile": {
+              "metric": "regionserver.Server.Append_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Append_max": {
+              "metric": "regionserver.Server.Append_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Append_mean": {
+              "metric": "regionserver.Server.Append_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Append_median": {
+              "metric": "regionserver.Server.Append_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Append_min": {
+              "metric": "regionserver.Server.Append_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/blockCacheExpressHitPercent": {
+              "metric": "regionserver.Server.blockCacheExpressHitPercent",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/blockedRequestCount": {
+              "metric": "regionserver.Server.blockedRequestCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/checkMutateFailedCount": {
+              "metric": "regionserver.Server.checkMutateFailedCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/checkMutatePassedCount": {
+              "metric": "regionserver.Server.checkMutatePassedCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/compactedCellsCount": {
+              "metric": "regionserver.Server.compactedCellsCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/compactedCellsSize": {
+              "metric": "regionserver.Server.compactedCellsSize",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/flushedCellsCount": {
+              "metric": "regionserver.Server.flushedCellsCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/flushedCellsSize": {
+              "metric": "regionserver.Server.flushedCellsSize",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/FlushTime_75th_percentile": {
+              "metric": "regionserver.Server.FlushTime_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/FlushTime_95th_percentile": {
+              "metric": "regionserver.Server.FlushTime_95th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/FlushTime_99th_percentile": {
+              "metric": "regionserver.Server.FlushTime_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/FlushTime_max": {
+              "metric": "regionserver.Server.FlushTime_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/FlushTime_mean": {
+              "metric": "regionserver.Server.FlushTime_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/FlushTime_min": {
+              "metric": "regionserver.Server.FlushTime_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/hlogFileSize": {
+              "metric": "regionserver.Server.hlogFileSize",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Increment_75th_percentile": {
+              "metric": "regionserver.Server.Increment_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Increment_99th_percentile": {
+              "metric": "regionserver.Server.Increment_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Increment_max": {
+              "metric": "regionserver.Server.Increment_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Increment_mean": {
+              "metric": "regionserver.Server.Increment_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Increment_min": {
+              "metric": "regionserver.Server.Increment_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/majorCompactedCellsCount": {
+              "metric": "regionserver.Server.majorCompactedCellsCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/majorCompactedCellsSize": {
+              "metric": "regionserver.Server.majorCompactedCellsSize",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/percentFilesLocalSecondaryRegions": {
+              "metric": "regionserver.Server.percentFilesLocalSecondaryRegions",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Replay_75th_percentile": {
+              "metric": "regionserver.Server.Replay_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Replay_95th_percentile": {
+              "metric": "regionserver.Server.Replay_95th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Replay_99th_percentile": {
+              "metric": "regionserver.Server.Replay_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Replay_max": {
+              "metric": "regionserver.Server.Replay_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Replay_mean": {
+              "metric": "regionserver.Server.Replay_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Replay_median": {
+              "metric": "regionserver.Server.Replay_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Replay_min": {
+              "metric": "regionserver.Server.Replay_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/Replay_num_ops": {
+              "metric": "regionserver.Server.Replay_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/ScanNext_75th_percentile": {
+              "metric": "regionserver.Server.ScanNext_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/ScanNext_99th_percentile": {
+              "metric": "regionserver.Server.ScanNext_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/ScanNext_max": {
+              "metric": "regionserver.Server.ScanNext_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/ScanNext_mean": {
+              "metric": "regionserver.Server.ScanNext_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/ScanNext_median": {
+              "metric": "regionserver.Server.ScanNext_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/ScanNext_min": {
+              "metric": "regionserver.Server.ScanNext_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/splitQueueLength": {
+              "metric": "regionserver.Server.splitQueueLength",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/splitRequestCount": {
+              "metric": "regionserver.Server.splitRequestCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/splitSuccessCount": {
+              "metric": "regionserver.Server.splitSuccessCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/SplitTime_75th_percentile": {
+              "metric": "regionserver.Server.SplitTime_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/SplitTime_95th_percentile": {
+              "metric": "regionserver.Server.SplitTime_95th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/SplitTime_99th_percentile": {
+              "metric": "regionserver.Server.SplitTime_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/SplitTime_max": {
+              "metric": "regionserver.Server.SplitTime_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/SplitTime_mean": {
+              "metric": "regionserver.Server.SplitTime_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/SplitTime_median": {
+              "metric": "regionserver.Server.SplitTime_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/SplitTime_min": {
+              "metric": "regionserver.Server.SplitTime_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/SplitTime_num_ops": {
+              "metric": "regionserver.Server.SplitTime_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/Server/storeFileSize": {
+              "metric": "regionserver.Server.storeFileSize",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/appendCount": {
+              "metric": "regionserver.WAL.appendCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendSize_75th_percentile": {
+              "metric": "regionserver.WAL.AppendSize_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendSize_95th_percentile": {
+              "metric": "regionserver.WAL.AppendSize_95th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendSize_99th_percentile": {
+              "metric": "regionserver.WAL.AppendSize_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendSize_max": {
+              "metric": "regionserver.WAL.AppendSize_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendSize_mean": {
+              "metric": "regionserver.WAL.AppendSize_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendSize_median": {
+              "metric": "regionserver.WAL.AppendSize_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendSize_min": {
+              "metric": "regionserver.WAL.AppendSize_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendSize_num_ops": {
+              "metric": "regionserver.WAL.AppendSize_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendTime_75th_percentile": {
+              "metric": "regionserver.WAL.AppendTime_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendTime_95th_percentile": {
+              "metric": "regionserver.WAL.AppendTime_95th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendTime_99th_percentile": {
+              "metric": "regionserver.WAL.AppendTime_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendTime_max": {
+              "metric": "regionserver.WAL.AppendTime_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendTime_mean": {
+              "metric": "regionserver.WAL.AppendTime_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendTime_median": {
+              "metric": "regionserver.WAL.AppendTime_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendTime_min": {
+              "metric": "regionserver.WAL.AppendTime_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/AppendTime_num_ops": {
+              "metric": "regionserver.WAL.AppendTime_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/lowReplicaRollRequest": {
+              "metric": "regionserver.WAL.lowReplicaRollRequest",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/rollRequest": {
+              "metric": "regionserver.WAL.rollRequest",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/slowAppendCount": {
+              "metric": "regionserver.WAL.slowAppendCount",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/SyncTime_75th_percentile": {
+              "metric": "regionserver.WAL.SyncTime_75th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/SyncTime_95th_percentile": {
+              "metric": "regionserver.WAL.SyncTime_95th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/SyncTime_99th_percentile": {
+              "metric": "regionserver.WAL.SyncTime_99th_percentile",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/SyncTime_max": {
+              "metric": "regionserver.WAL.SyncTime_max",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/SyncTime_mean": {
+              "metric": "regionserver.WAL.SyncTime_mean",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/SyncTime_median": {
+              "metric": "regionserver.WAL.SyncTime_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/SyncTime_min": {
+              "metric": "regionserver.WAL.SyncTime_min",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/regionserver/WAL/SyncTime_num_ops": {
+              "metric": "regionserver.WAL.SyncTime_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/ugi/UgiMetrics/GetGroupsAvgTime": {
+              "metric": "ugi.UgiMetrics.GetGroupsAvgTime",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/ugi/UgiMetrics/GetGroupsNumOps": {
+              "metric": "ugi.UgiMetrics.GetGroupsNumOps",
+              "pointInTime": true,
+              "temporal": true
+            }
+          }
+        }
+      },
+      {
+        "type": "jmx",
+        "metrics": {
+          "default": {
+            "metrics/hbase/regionserver/slowPutCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.slowPutCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/percentFilesLocal": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.percentFilesLocal",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_min": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Delete_min",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/blockCacheFree": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.blockCacheFreeSize",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/mutationsWithoutWALSize": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.mutationsWithoutWALSize",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/blockCacheMissCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.blockCacheMissCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/flushQueueSize": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.flushQueueLength",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_99th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Delete_99th_percentile",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/getRequestLatency_num_ops": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Get_num_ops",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/ScanNext_num_ops": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.ScanNext_num_ops",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/Increment_num_ops": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Increment_num_ops",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/Append_num_ops": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Append_num_ops",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/ScanNext_95th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.ScanNext_95th_percentile",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/Append_95th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Append_95th_percentile",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/Increment_95th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Increment_95th_percentile",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/updatesBlockedTime": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.updatesBlockedTime",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/IPC/numActiveHandler": {
+              "metric": "Hadoop:service=HBase,name=IPC,sub=IPC.numActiveHandler",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/IPC/numCallsInGeneralQueue": {
+              "metric": "Hadoop:service=HBase,name=IPC,sub=IPC.numCallsInGeneralQueue",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/IPC/numOpenConnections": {
+              "metric": "Hadoop:service=HBase,name=IPC,sub=IPC.numOpenConnections",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/slowAppendCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.slowAppendCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/blockCacheSize": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.blockCacheSize",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/putRequestLatency_num_ops": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Mutate_num_ops",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/slowIncrementCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.slowIncrementCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/blockCacheEvictedCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.blockCacheEvictionCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/putRequestLatency_95th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Mutate_95th_percentile",
+              "unit": "ms",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/compactionQueueSize": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.compactionQueueLength",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/putRequestLatency_median": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Mutate_median",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_mean": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Delete_mean",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/slowGetCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.slowGetCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/blockCacheCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.blockCacheCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/getRequestLatency_75th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Get_75th_percentile",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/readRequestsCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.readRequestCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/putRequestLatency_min": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Mutate_min",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/storefileIndexSizeMB": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.storeFileIndexSize",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_median": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Delete_median",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/putRequestLatency_max": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Mutate_max",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/totalStaticIndexSizeKB": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.staticIndexSize",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_num_ops": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Delete_num_ops",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/putRequestLatency_mean": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Mutate_mean",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/requests": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.totalRequestCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/storefiles": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.storeFileCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/mutationsWithoutWALCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.mutationsWithoutWALCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/writeRequestsCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.writeRequestCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/getRequestLatency_median": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Get_median",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/slowDeleteCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.slowDeleteCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/putRequestLatency_99th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Mutate_99th_percentile",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/stores": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.storeCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/getRequestLatency_min": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Get_min",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/getRequestLatency_95th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Get_95th_percentile",
+              "unit": "ms",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_95th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Delete_95th_percentile",
+              "unit": "ms",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/memstoreSize": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.memStoreSize",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/getRequestLatency_max": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Get_max",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/getRequestLatency_mean": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Get_mean",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_75th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Delete_75th_percentile",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_max": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Delete_max",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/putRequestLatency_75th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Mutate_75th_percentile",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/regions": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.regionCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/totalStaticBloomSizeKB": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.staticBloomSize",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/blockCacheHitCount": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.blockCacheHitCount",
+              "pointInTime": true,
+              "temporal": false
+            },
+            "metrics/hbase/regionserver/getRequestLatency_99th_percentile": {
+              "metric": "Hadoop:service=HBase,name=RegionServer,sub=Server.Get_99th_percentile",
+              "pointInTime": true,
+              "temporal": false
+            }
+          }
+        }
+      }
+    ],
+    "HostComponent": [
+      {
+        "type": "ganglia",
+        "metrics": {
+          "default": {
+            "metrics/cpu/cpu_idle":{
+              "metric":"cpu_idle",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/cpu/cpu_nice":{
+              "metric":"cpu_nice",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/cpu/cpu_system":{
+              "metric":"cpu_system",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/cpu/cpu_user":{
+              "metric":"cpu_user",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/cpu/cpu_wio":{
+              "metric":"cpu_wio",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/disk/disk_free":{
+              "metric":"disk_free",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/disk/disk_total":{
+              "metric":"disk_total",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/disk/read_bps":{
+              "metric":"read_bps",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/disk/write_bps":{
+              "metric":"write_bps",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/load/load_fifteen":{
+              "metric":"load_fifteen",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/load/load_five":{
+              "metric":"load_five",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/load/load_one":{
+              "metric":"load_one",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/memory/mem_buffers":{
+              "metric":"mem_buffers",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/memory/mem_cached":{
+              "metric":"mem_cached",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/memory/mem_free":{
+              "metric":"mem_free",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/memory/mem_shared":{
+              "metric":"mem_shared",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/memory/mem_total":{
+              "metric":"mem_total",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/memory/swap_free":{
+              "metric":"swap_free",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/memory/swap_total":{
+              "metric":"swap_total",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/network/bytes_in":{
+              "metric":"bytes_in",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/network/bytes_out":{
+              "metric":"bytes_out",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/network/pkts_in":{
+              "metric":"pkts_in",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/network/pkts_out":{
+              "metric":"pkts_out",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/process/proc_run":{
+              "metric":"proc_run",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/process/proc_total":{
+              "metric":"proc_total",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/disk/read_count":{
+              "metric":"read_count",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/disk/write_count":{
+              "metric":"write_count",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/disk/read_bytes":{
+              "metric":"read_bytes",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/disk/write_bytes":{
+              "metric":"write_bytes",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/disk/read_time":{
+              "metric":"read_time",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/disk/write_time":{
+              "metric":"write_time",
+              "pointInTime":true,
+              "temporal":true,
+              "amsHostMetric":true
+            },
+            "metrics/hbase/regionserver/mutationsWithoutWALSize": {
+              "metric": "regionserver.Server.mutationsWithoutWALSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/ugi/loginSuccess_avg_time": {
+              "metric": "ugi.UgiMetrics.LoginSuccessAvgTime",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_99th_percentile": {
+              "metric": "regionserver.Server.Delete_99th_percentile",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/slowAppendCount": {
+              "metric": "regionserver.Server.slowAppendCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/jvm/memNonHeapUsedM": {
+              "metric": "jvm.JvmMetrics.MemNonHeapUsedM",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/slowIncrementCount": {
+              "metric": "regionserver.Server.slowIncrementCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_95th_percentile": {
+              "metric": "regionserver.Server.Mutate_95th_percentile",
+              "unit": "ms",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/compactionQueueSize": {
+              "metric": "regionserver.Server.compactionQueueLength",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/disk/part_max_used": {
+              "metric": "part_max_used",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/flushTime_num_ops": {
+              "metric": "regionserver.Server.FlushTime_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheCount": {
+              "metric": "regionserver.Server.blockCacheCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/ugi/loginSuccess_num_ops": {
+              "metric": "ugi.UgiMetrics.LoginSuccessNumOps",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/getRequestLatency_75th_percentile": {
+              "metric": "regionserver.Server.Get_75th_percentile",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/jvm/memNonHeapCommittedM": {
+              "metric": "jvm.JvmMetrics.MemNonHeapCommittedM",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/stores": {
+              "metric": "regionserver.Server.storeCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/ugi/loginFailure_num_ops": {
+              "metric": "ugi.UgiMetrics.LoginFailureNumOps",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/rpc/rpcAuthenticationSuccesses": {
+              "metric": "regionserver.RegionServer.authenticationSuccesses",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/jvm/memHeapCommittedM": {
+              "metric": "jvm.JvmMetrics.MemHeapCommittedM",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/threadsRunnable": {
+              "metric": "jvm.JvmMetrics.ThreadsRunnable",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/threadsNew": {
+              "metric": "jvm.JvmMetrics.ThreadsNew",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_min": {
+              "metric": "regionserver.Server.Delete_min",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/rpc/rpcAuthorizationFailures": {
+              "metric": "regionserver.RegionServer.authorizationFailures",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/rpc/RpcQueueTime_avg_time": {
+              "metric": "regionserver.RegionServer.QueueCallTime_median",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/getRequestLatency_num_ops": {
+              "metric": "regionserver.Server.Get_num_ops",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/rpc/ReceivedBytes": {
+              "metric": "regionserver.RegionServer.receivedBytes",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/rpc/NumOpenConnections": {
+              "metric": "regionserver.RegionServer.NumOpenConnections",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/gcTimeMillis": {
+              "metric": "jvm.JvmMetrics.GcTimeMillis",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/jvm/threadsTerminated": {
+              "metric": "jvm.JvmMetrics.ThreadsTerminated",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_max": {
+              "metric": "regionserver.Server.Mutate_max",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_num_ops": {
+              "metric": "regionserver.Server.Delete_num_ops",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/boottime": {
+              "metric": "boottime",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/writeRequestsCount": {
+              "metric": "regionserver.Server.writeRequestCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/getRequestLatency_min": {
+              "metric": "regionserver.Server.Get_min",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/rpc/RpcProcessingTime_num_ops": {
+              "metric": "regionserver.RegionServer.ProcessCallTime_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/getRequestLatency_mean": {
+              "metric": "regionserver.Server.Get_mean",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/jvm/logError": {
+              "metric": "jvm.JvmMetrics.LogError",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_75th_percentile": {
+              "metric": "regionserver.Server.Mutate_75th_percentile",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/regions": {
+              "metric": "regionserver.Server.regionCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheHitCount": {
+              "metric": "regionserver.Server.blockCacheHitCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/slowPutCount": {
+              "metric": "regionserver.Server.slowPutCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheFree": {
+              "metric": "regionserver.Server.blockCacheFreeSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheMissCount": {
+              "metric": "regionserver.Server.blockCacheMissCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/flushQueueSize": {
+              "metric": "regionserver.Server.flushQueueLength",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/blockCacheSize": {
+              "metric": "regionserver.Server.blockCacheSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_num_ops": {
+              "metric": "regionserver.Server.Mutate_num_ops",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/jvm/threadsBlocked": {
+              "metric": "jvm.JvmMetrics.ThreadsBlocked",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/rpc/RpcQueueTime_num_ops": {
+              "metric": "regionserver.RegionServer.QueueCallTime_num_ops",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_median": {
+              "metric": "regionserver.Server.Mutate_median",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_mean": {
+              "metric": "regionserver.Server.Delete_mean",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/cpu/cpu_aidle": {
+              "metric": "cpu_aidle",
+              "pointInTime": true,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/readRequestsCount": {
+              "metric": "regionserver.Server.readRequestCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_min": {
+              "metric": "regionserver.Server.Mutate_min",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/storefileIndexSizeMB": {
+              "metric": "regionserver.Server.storeFileIndexSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_median": {
+              "metric": "regionserver.Server.Delete_median",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/totalStaticIndexSizeKB": {
+              "metric": "regionserver.Server.staticIndexSize",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/putRequestLatency_mean": {
+              "metric": "regionserver.Server.Mutate_mean",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/mutationsWithoutWALCount": {
+              "metric": "regionserver.Server.mutationsWithoutWALCount",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/getRequestLatency_median": {
+              "metric": "regionserver.Server.Get_median",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/hbase/regionserver/deleteRequestLatency_max": {
+              "metric": "regionserver.Server.Delete_max",
+              "pointInTime": false,
+              "temporal": true
+            },
+            "metrics/cpu/cp

<TRUNCATED>

[3/3] ambari git commit: AMBARI-11844. HBase service: Open Connections and Request Handlers widgets does not display with HDP 2.2 stack deployment.

Posted by sw...@apache.org.
AMBARI-11844. HBase service: Open Connections and Request Handlers widgets does not display with HDP 2.2 stack deployment.


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

Branch: refs/heads/trunk
Commit: 0f71307494d982d6bad1825c2a5295e4e0ce7b64
Parents: 614fd80
Author: Siddharth Wagle <sw...@hortonworks.com>
Authored: Wed Jun 10 09:53:36 2015 -0700
Committer: Siddharth Wagle <sw...@hortonworks.com>
Committed: Wed Jun 10 09:53:36 2015 -0700

----------------------------------------------------------------------
 .../HBASE/0.96.0.2.0/metrics.json               |    6 +-
 .../stacks/HDP/2.3/services/HBASE/metrics.json  | 9410 ++++++++++++++++++
 2 files changed, 9413 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/0f713074/ambari-server/src/main/resources/common-services/HBASE/0.96.0.2.0/metrics.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/common-services/HBASE/0.96.0.2.0/metrics.json b/ambari-server/src/main/resources/common-services/HBASE/0.96.0.2.0/metrics.json
index a309ec7..ae15651 100644
--- a/ambari-server/src/main/resources/common-services/HBASE/0.96.0.2.0/metrics.json
+++ b/ambari-server/src/main/resources/common-services/HBASE/0.96.0.2.0/metrics.json
@@ -372,17 +372,17 @@
               "temporal": true
             },
             "metrics/hbase/ipc/IPC/numOpenConnections": {
-              "metric": "regionserver.RegionServer.numOpenConnections",
+              "metric": "ipc.IPC.numOpenConnections",
               "pointInTime": false,
               "temporal": true
             },
             "metrics/hbase/ipc/IPC/numActiveHandler": {
-              "metric": "regionserver.RegionServer.numActiveHandler",
+              "metric": "ipc.IPC.numActiveHandler",
               "pointInTime": false,
               "temporal": true
             },
             "metrics/hbase/ipc/IPC/numCallsInGeneralQueue": {
-              "metric": "regionserver.RegionServer.numCallsInGeneralQueue",
+              "metric": "ipc.IPC.numCallsInGeneralQueue",
               "pointInTime": false,
               "temporal": true
             },