You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by ds...@apache.org on 2016/03/15 12:51:54 UTC

ambari git commit: AMBARI-15402 AMS fails to start with TTL for column family 0 must be positive after upgrade (dsen)

Repository: ambari
Updated Branches:
  refs/heads/trunk 3c37c38e6 -> 9bf7c6e22


AMBARI-15402 AMS fails to start with TTL for column family 0 must be positive after upgrade (dsen)


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

Branch: refs/heads/trunk
Commit: 9bf7c6e223d56d5cac4bd267e6ce3e6fb4e325fd
Parents: 3c37c38
Author: Dmytro Sen <ds...@apache.org>
Authored: Tue Mar 15 13:51:45 2016 +0200
Committer: Dmytro Sen <ds...@apache.org>
Committed: Tue Mar 15 13:51:45 2016 +0200

----------------------------------------------------------------------
 .../metrics/timeline/PhoenixHBaseAccessor.java  | 16 ++---
 .../timeline/ITPhoenixHBaseAccessor.java        |  6 +-
 .../server/upgrade/UpgradeCatalog222.java       | 76 ++------------------
 .../0.1.0/configuration/ams-site.xml            | 32 ++++-----
 .../stacks/HDP/2.0.6/services/stack_advisor.py  |  4 +-
 .../server/upgrade/UpgradeCatalog222Test.java   | 16 ++---
 .../stacks/2.2/common/test_stack_advisor.py     |  4 +-
 7 files changed, 45 insertions(+), 109 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/9bf7c6e2/ambari-metrics/ambari-metrics-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/metrics/timeline/PhoenixHBaseAccessor.java
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/metrics/timeline/PhoenixHBaseAccessor.java b/ambari-metrics/ambari-metrics-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/metrics/timeline/PhoenixHBaseAccessor.java
index eb48bb2..d6ee9d2 100644
--- a/ambari-metrics/ambari-metrics-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/metrics/timeline/PhoenixHBaseAccessor.java
+++ b/ambari-metrics/ambari-metrics-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/metrics/timeline/PhoenixHBaseAccessor.java
@@ -175,14 +175,14 @@ public class PhoenixHBaseAccessor {
       DEFAULT_OUT_OF_BAND_TIME_ALLOWANCE);
     this.skipBlockCacheForAggregatorsEnabled = metricsConf.getBoolean(AGGREGATORS_SKIP_BLOCK_CACHE, false);
 
-    tableTTL.put(METRICS_RECORD_TABLE_NAME, getDaysInSeconds(metricsConf.get(PRECISION_TABLE_TTL, "1")));                            //1 day
-    tableTTL.put(METRICS_AGGREGATE_MINUTE_TABLE_NAME, getDaysInSeconds(metricsConf.get(HOST_MINUTE_TABLE_TTL, "7")));                //7 days
-    tableTTL.put(METRICS_AGGREGATE_HOURLY_TABLE_NAME, getDaysInSeconds(metricsConf.get(HOST_HOUR_TABLE_TTL, "30")));                 //30 days
-    tableTTL.put(METRICS_AGGREGATE_DAILY_TABLE_NAME, getDaysInSeconds(metricsConf.get(HOST_DAILY_TABLE_TTL, "365")));                //1 year
-    tableTTL.put(METRICS_CLUSTER_AGGREGATE_TABLE_NAME, getDaysInSeconds(metricsConf.get(CLUSTER_SECOND_TABLE_TTL, "7")));            //7 days
-    tableTTL.put(METRICS_CLUSTER_AGGREGATE_MINUTE_TABLE_NAME, getDaysInSeconds(metricsConf.get(CLUSTER_MINUTE_TABLE_TTL, "30")));    //30 days
-    tableTTL.put(METRICS_CLUSTER_AGGREGATE_HOURLY_TABLE_NAME, getDaysInSeconds(metricsConf.get(CLUSTER_HOUR_TABLE_TTL, "365")));     //1 year
-    tableTTL.put(METRICS_CLUSTER_AGGREGATE_DAILY_TABLE_NAME, getDaysInSeconds(metricsConf.get(CLUSTER_DAILY_TABLE_TTL, "730")));     //2 years
+    tableTTL.put(METRICS_RECORD_TABLE_NAME, metricsConf.get(PRECISION_TABLE_TTL, String.valueOf(1 * 86400)));  // 1 day
+    tableTTL.put(METRICS_AGGREGATE_MINUTE_TABLE_NAME, metricsConf.get(HOST_MINUTE_TABLE_TTL, String.valueOf(7 * 86400))); //7 days
+    tableTTL.put(METRICS_AGGREGATE_HOURLY_TABLE_NAME, metricsConf.get(HOST_HOUR_TABLE_TTL, String.valueOf(30 * 86400))); //30 days
+    tableTTL.put(METRICS_AGGREGATE_DAILY_TABLE_NAME, metricsConf.get(HOST_DAILY_TABLE_TTL, String.valueOf(365 * 86400))); //1 year
+    tableTTL.put(METRICS_CLUSTER_AGGREGATE_TABLE_NAME, metricsConf.get(CLUSTER_SECOND_TABLE_TTL, String.valueOf(7 * 86400))); //7 days
+    tableTTL.put(METRICS_CLUSTER_AGGREGATE_MINUTE_TABLE_NAME, metricsConf.get(CLUSTER_MINUTE_TABLE_TTL, String.valueOf(30 * 86400))); //30 days
+    tableTTL.put(METRICS_CLUSTER_AGGREGATE_HOURLY_TABLE_NAME, metricsConf.get(CLUSTER_HOUR_TABLE_TTL, String.valueOf(365 * 86400))); //1 year
+    tableTTL.put(METRICS_CLUSTER_AGGREGATE_DAILY_TABLE_NAME, metricsConf.get(CLUSTER_DAILY_TABLE_TTL, String.valueOf(730 * 86400))); //2 years
   }
 
   private static TimelineMetric getLastTimelineMetricFromResultSet(ResultSet rs)

http://git-wip-us.apache.org/repos/asf/ambari/blob/9bf7c6e2/ambari-metrics/ambari-metrics-timelineservice/src/test/java/org/apache/hadoop/yarn/server/applicationhistoryservice/metrics/timeline/ITPhoenixHBaseAccessor.java
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-timelineservice/src/test/java/org/apache/hadoop/yarn/server/applicationhistoryservice/metrics/timeline/ITPhoenixHBaseAccessor.java b/ambari-metrics/ambari-metrics-timelineservice/src/test/java/org/apache/hadoop/yarn/server/applicationhistoryservice/metrics/timeline/ITPhoenixHBaseAccessor.java
index 93ba770..89f3fbe 100644
--- a/ambari-metrics/ambari-metrics-timelineservice/src/test/java/org/apache/hadoop/yarn/server/applicationhistoryservice/metrics/timeline/ITPhoenixHBaseAccessor.java
+++ b/ambari-metrics/ambari-metrics-timelineservice/src/test/java/org/apache/hadoop/yarn/server/applicationhistoryservice/metrics/timeline/ITPhoenixHBaseAccessor.java
@@ -353,13 +353,13 @@ public class ITPhoenixHBaseAccessor extends AbstractMiniHBaseClusterTest {
           precisionTtl = family.getValue("TTL");
         }
       }
-      Assert.assertEquals("Precision TTL value.", hdb.getDaysInSeconds("1"), precisionTtl);
+      Assert.assertEquals("Precision TTL value.", "86400", precisionTtl);
     }
 
     Field f = PhoenixHBaseAccessor.class.getDeclaredField("tableTTL");
     f.setAccessible(true);
     Map<String, String> precisionValues = (Map<String, String>) f.get(hdb);
-    precisionValues.put(METRICS_RECORD_TABLE_NAME, hdb.getDaysInSeconds("2"));
+    precisionValues.put(METRICS_RECORD_TABLE_NAME, String.valueOf(2 * 86400));
     f.set(hdb, precisionValues);
 
     hdb.initPoliciesAndTTL();
@@ -389,7 +389,7 @@ public class ITPhoenixHBaseAccessor extends AbstractMiniHBaseClusterTest {
 
     Assert.assertTrue("Normalizer enabled.", normalizerEnabled);
     Assert.assertEquals("FIFO compaction policy is set.", FIFO_COMPACTION_POLICY_CLASS, compactionPolicy);
-    Assert.assertEquals("Precision TTL value not changed.", hdb.getDaysInSeconds("2"), precisionTtl);
+    Assert.assertEquals("Precision TTL value not changed.", String.valueOf(2 * 86400), precisionTtl);
 
     hBaseAdmin.close();
   }

http://git-wip-us.apache.org/repos/asf/ambari/blob/9bf7c6e2/ambari-server/src/main/java/org/apache/ambari/server/upgrade/UpgradeCatalog222.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/upgrade/UpgradeCatalog222.java b/ambari-server/src/main/java/org/apache/ambari/server/upgrade/UpgradeCatalog222.java
index b79d778..8267d5d 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/upgrade/UpgradeCatalog222.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/upgrade/UpgradeCatalog222.java
@@ -49,11 +49,9 @@ import java.io.File;
 import java.io.FileReader;
 import java.lang.reflect.Type;
 import java.sql.SQLException;
-import java.util.Arrays;
 import java.util.HashMap;
 import java.util.List;
 import java.util.Map;
-import java.util.concurrent.TimeUnit;
 
 /**
  * Upgrade catalog for version 2.2.2.
@@ -85,13 +83,8 @@ public class UpgradeCatalog222 extends AbstractUpgradeCatalog {
   private static final String TIMELINE_METRICS_SERVICE_WATCHER_DISBALED = "timeline.metrics.service.watcher.disabled";
   private static final String AMS_MODE = "timeline.metrics.service.operation.mode";
   public static final String PRECISION_TABLE_TTL = "timeline.metrics.host.aggregator.ttl";
-  public static final String HOST_MINUTE_TABLE_TTL = "timeline.metrics.host.aggregator.minute.ttl";
-  public static final String HOST_HOUR_TABLE_TTL = "timeline.metrics.host.aggregator.hourly.ttl";
-  public static final String HOST_DAILY_TABLE_TTL = "timeline.metrics.host.aggregator.daily.ttl";
   public static final String CLUSTER_SECOND_TABLE_TTL = "timeline.metrics.cluster.aggregator.second.ttl";
   public static final String CLUSTER_MINUTE_TABLE_TTL = "timeline.metrics.cluster.aggregator.minute.ttl";
-  public static final String CLUSTER_HOUR_TABLE_TTL = "timeline.metrics.cluster.aggregator.hourly.ttl";
-  public static final String CLUSTER_DAILY_TABLE_TTL = "timeline.metrics.cluster.aggregator.daily.ttl";
 
   private static final String[] HDFS_WIDGETS_TO_UPDATE = new String[] {
     "NameNode RPC", "NN Connection Load" };
@@ -283,50 +276,22 @@ public class UpgradeCatalog222 extends AbstractUpgradeCatalog {
 
             if (amsSiteProperties.containsKey(PRECISION_TABLE_TTL)) {
               String oldTtl = amsSiteProperties.get(PRECISION_TABLE_TTL);
-              String newTtl = convertToDaysIfInSeconds(oldTtl);
+              String newTtl = oldTtl;
               if (isDistributed) {
                 if ("86400".equals(oldTtl)) {
-                  newTtl = "7.0"; // 7 days
+                  newTtl = String.valueOf(7 * 86400); // 7 days
                 }
               }
               newProperties.put(PRECISION_TABLE_TTL, newTtl);
               LOG.info("Setting value of " + PRECISION_TABLE_TTL + " : " + newTtl);
             }
 
-            if (amsSiteProperties.containsKey(HOST_MINUTE_TABLE_TTL)) {
-              String oldTtl = amsSiteProperties.get(HOST_MINUTE_TABLE_TTL);
-              String newTtl = convertToDaysIfInSeconds(oldTtl);
-              newProperties.put(HOST_MINUTE_TABLE_TTL, newTtl);
-              LOG.info("Setting value of " + HOST_MINUTE_TABLE_TTL + " : " + newTtl);
-            }
-
-            if (amsSiteProperties.containsKey(HOST_MINUTE_TABLE_TTL)) {
-              String oldTtl = amsSiteProperties.get(HOST_MINUTE_TABLE_TTL);
-              String newTtl = convertToDaysIfInSeconds(oldTtl);
-              newProperties.put(HOST_MINUTE_TABLE_TTL, newTtl);
-              LOG.info("Setting value of " + HOST_MINUTE_TABLE_TTL + " : " + newTtl);
-            }
-
-            if (amsSiteProperties.containsKey(HOST_HOUR_TABLE_TTL)) {
-              String oldTtl = amsSiteProperties.get(HOST_HOUR_TABLE_TTL);
-              String newTtl = convertToDaysIfInSeconds(oldTtl);
-              newProperties.put(HOST_HOUR_TABLE_TTL, newTtl);
-              LOG.info("Setting value of " + HOST_HOUR_TABLE_TTL + " : " + newTtl);
-            }
-
-            if (amsSiteProperties.containsKey(HOST_DAILY_TABLE_TTL)) {
-              String oldTtl = amsSiteProperties.get(HOST_DAILY_TABLE_TTL);
-              String newTtl = convertToDaysIfInSeconds(oldTtl);
-              newProperties.put(HOST_DAILY_TABLE_TTL, newTtl);
-              LOG.info("Setting value of " + HOST_DAILY_TABLE_TTL + " : " + newTtl);
-            }
-
             if (amsSiteProperties.containsKey(CLUSTER_SECOND_TABLE_TTL)) {
               String oldTtl = amsSiteProperties.get(CLUSTER_SECOND_TABLE_TTL);
-              String newTtl = convertToDaysIfInSeconds(oldTtl);
+              String newTtl = oldTtl;
 
               if ("2592000".equals(oldTtl)) {
-                newTtl = "7.0"; // 7 days
+                newTtl = String.valueOf(7 * 86400); // 7 days
               }
 
               newProperties.put(CLUSTER_SECOND_TABLE_TTL, newTtl);
@@ -335,30 +300,16 @@ public class UpgradeCatalog222 extends AbstractUpgradeCatalog {
 
             if (amsSiteProperties.containsKey(CLUSTER_MINUTE_TABLE_TTL)) {
               String oldTtl = amsSiteProperties.get(CLUSTER_MINUTE_TABLE_TTL);
-              String newTtl = convertToDaysIfInSeconds(oldTtl);
+              String newTtl = oldTtl;
 
               if ("7776000".equals(oldTtl)) {
-                newTtl = "30.0"; // 30 days
+                newTtl = String.valueOf(30 * 86400); // 30 days
               }
 
               newProperties.put(CLUSTER_MINUTE_TABLE_TTL, newTtl);
               LOG.info("Setting value of " + CLUSTER_MINUTE_TABLE_TTL + " : " + newTtl);
             }
 
-            if (amsSiteProperties.containsKey(CLUSTER_HOUR_TABLE_TTL)) {
-              String oldTtl = amsSiteProperties.get(CLUSTER_HOUR_TABLE_TTL);
-              String newTtl = convertToDaysIfInSeconds(oldTtl);
-              newProperties.put(CLUSTER_HOUR_TABLE_TTL, newTtl);
-              LOG.info("Setting value of " + CLUSTER_HOUR_TABLE_TTL + " : " + newTtl);
-            }
-
-            if (amsSiteProperties.containsKey(CLUSTER_DAILY_TABLE_TTL)) {
-              String oldTtl = amsSiteProperties.get(CLUSTER_DAILY_TABLE_TTL);
-              String newTtl = convertToDaysIfInSeconds(oldTtl);
-              newProperties.put(CLUSTER_DAILY_TABLE_TTL, newTtl);
-              LOG.info("Setting value of " + CLUSTER_DAILY_TABLE_TTL + " : " + newTtl);
-            }
-
             updateConfigurationPropertiesForCluster(cluster, AMS_SITE, newProperties, true, true);
           }
 
@@ -495,19 +446,4 @@ public class UpgradeCatalog222 extends AbstractUpgradeCatalog {
     ));
   }
 
-  private String convertToDaysIfInSeconds(String secondsString) {
-
-    int seconds = Integer.valueOf(secondsString);
-    double days = 0.0;
-
-    if (seconds >= 86400) {
-      days += TimeUnit.SECONDS.toDays(seconds);
-    }
-
-    days += ((float)seconds % 86400.0) / 86400.0;
-    days = Math.round(days * 100.0)/100.0;
-
-    return String.valueOf(days);
-  }
-
 }

http://git-wip-us.apache.org/repos/asf/ambari/blob/9bf7c6e2/ambari-server/src/main/resources/common-services/AMBARI_METRICS/0.1.0/configuration/ams-site.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/common-services/AMBARI_METRICS/0.1.0/configuration/ams-site.xml b/ambari-server/src/main/resources/common-services/AMBARI_METRICS/0.1.0/configuration/ams-site.xml
index 0022607..99e97f7 100644
--- a/ambari-server/src/main/resources/common-services/AMBARI_METRICS/0.1.0/configuration/ams-site.xml
+++ b/ambari-server/src/main/resources/common-services/AMBARI_METRICS/0.1.0/configuration/ams-site.xml
@@ -283,58 +283,58 @@
   </property>
   <property>
     <name>timeline.metrics.host.aggregator.daily.ttl</name>
-    <value>365</value>
+    <value>31536000</value>
     <description>
-      Host based daily resolution data purge interval. Default is 1 year.
+      Host based daily resolution data purge interval in seconds. Default is 1 year.
     </description>
   </property>
   <property>
     <name>timeline.metrics.host.aggregator.hourly.ttl</name>
-    <value>30</value>
+    <value>2592000</value>
     <description>
-      Host based hourly resolution data purge interval. Default is 30 days.
+      Host based hourly resolution data purge interval in seconds. Default is 30 days.
     </description>
   </property>
   <property>
     <name>timeline.metrics.host.aggregator.minute.ttl</name>
-    <value>7</value>
+    <value>604800</value>
     <description>
-      Host based minute resolution data purge interval. Default is 7 days.
+      Host based minute resolution data purge interval in seconds. Default is 7 days.
     </description>
   </property>
   <property>
     <name>timeline.metrics.cluster.aggregator.second.ttl</name>
-    <value>7</value>
+    <value>604800</value>
     <description>
-      Cluster wide second resolution data purge interval. Default is 7 days.
+      Cluster wide second resolution data purge interval in seconds. Default is 7 days.
     </description>
   </property>
   <property>
     <name>timeline.metrics.cluster.aggregator.minute.ttl</name>
-    <value>30</value>
+    <value>2592000</value>
     <description>
-      Cluster wide minute resolution data purge interval. Default is 30 days.
+      Cluster wide minute resolution data purge interval in seconds. Default is 30 days.
     </description>
   </property>
   <property>
     <name>timeline.metrics.cluster.aggregator.hourly.ttl</name>
-    <value>365</value>
+    <value>31536000</value>
     <description>
-      Cluster wide hourly resolution data purge interval. Default is 1 year.
+      Cluster wide hourly resolution data purge interval in seconds. Default is 1 year.
     </description>
   </property>
   <property>
     <name>timeline.metrics.cluster.aggregator.daily.ttl</name>
-    <value>730</value>
+    <value>63072000</value>
     <description>
-      Cluster wide daily resolution data purge interval. Default is 2 years.
+      Cluster wide daily resolution data purge interval in seconds. Default is 2 years.
     </description>
   </property>
   <property>
     <name>timeline.metrics.host.aggregator.ttl</name>
-    <value>1</value>
+    <value>86400</value>
     <description>
-      1 minute resolution data purge interval. Default is 1 day for embedded mode and 7 days for Distributed mode.
+      1 minute resolution data purge interval in seconds. Default is 1 day for embedded mode and 7 days for Distributed mode.
     </description>
     <depends-on>
       <property>

http://git-wip-us.apache.org/repos/asf/ambari/blob/9bf7c6e2/ambari-server/src/main/resources/stacks/HDP/2.0.6/services/stack_advisor.py
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.0.6/services/stack_advisor.py b/ambari-server/src/main/resources/stacks/HDP/2.0.6/services/stack_advisor.py
index 0de54bc..8c18421 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.0.6/services/stack_advisor.py
+++ b/ambari-server/src/main/resources/stacks/HDP/2.0.6/services/stack_advisor.py
@@ -509,11 +509,11 @@ class HDP206StackAdvisor(DefaultStackAdvisor):
 
     if operatingMode == "distributed":
       putAmsSiteProperty("timeline.metrics.service.watcher.disabled", 'true')
-      putAmsSiteProperty("timeline.metrics.host.aggregator.ttl", 7)
+      putAmsSiteProperty("timeline.metrics.host.aggregator.ttl", 604800)
       putAmsHbaseSiteProperty("hbase.cluster.distributed", 'true')
     else:
       putAmsSiteProperty("timeline.metrics.service.watcher.disabled", 'false')
-      putAmsSiteProperty("timeline.metrics.host.aggregator.ttl", 1)
+      putAmsSiteProperty("timeline.metrics.host.aggregator.ttl", 86400)
       putAmsHbaseSiteProperty("hbase.cluster.distributed", 'false')
 
     rootDir = "file:///var/lib/ambari-metrics-collector/hbase"

http://git-wip-us.apache.org/repos/asf/ambari/blob/9bf7c6e2/ambari-server/src/test/java/org/apache/ambari/server/upgrade/UpgradeCatalog222Test.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/java/org/apache/ambari/server/upgrade/UpgradeCatalog222Test.java b/ambari-server/src/test/java/org/apache/ambari/server/upgrade/UpgradeCatalog222Test.java
index cae6d96..f5fbd55 100644
--- a/ambari-server/src/test/java/org/apache/ambari/server/upgrade/UpgradeCatalog222Test.java
+++ b/ambari-server/src/test/java/org/apache/ambari/server/upgrade/UpgradeCatalog222Test.java
@@ -299,14 +299,14 @@ public class UpgradeCatalog222Test {
         put("timeline.metrics.host.aggregator.daily.checkpointCutOffMultiplier", String.valueOf(2));
         put("timeline.metrics.cluster.aggregator.daily.checkpointCutOffMultiplier", String.valueOf(2));
         put("timeline.metrics.service.watcher.disabled", String.valueOf(false));
-        put("timeline.metrics.host.aggregator.ttl", String.valueOf(7.0));
-        put("timeline.metrics.host.aggregator.minute.ttl", String.valueOf(7.0));
-        put("timeline.metrics.host.aggregator.hourly.ttl", String.valueOf(30.0));
-        put("timeline.metrics.host.aggregator.daily.ttl", String.valueOf(365.0));
-        put("timeline.metrics.cluster.aggregator.second.ttl", String.valueOf(0.25));
-        put("timeline.metrics.cluster.aggregator.minute.ttl", String.valueOf(30.0));
-        put("timeline.metrics.cluster.aggregator.hourly.ttl", String.valueOf(365.0));
-        put("timeline.metrics.cluster.aggregator.daily.ttl", String.valueOf(730.0));
+        put("timeline.metrics.host.aggregator.ttl", String.valueOf(7 * 86400));
+        put("timeline.metrics.host.aggregator.minute.ttl", String.valueOf(7 * 86400));
+        put("timeline.metrics.host.aggregator.hourly.ttl", String.valueOf(30 * 86400));
+        put("timeline.metrics.host.aggregator.daily.ttl", String.valueOf(365 * 86400));
+        put("timeline.metrics.cluster.aggregator.second.ttl", String.valueOf(21600));
+        put("timeline.metrics.cluster.aggregator.minute.ttl", String.valueOf(30 * 86400));
+        put("timeline.metrics.cluster.aggregator.hourly.ttl", String.valueOf(365 * 86400));
+        put("timeline.metrics.cluster.aggregator.daily.ttl", String.valueOf(730 * 86400));
         put("timeline.metrics.service.operation.mode", "distributed");
       }
     };

http://git-wip-us.apache.org/repos/asf/ambari/blob/9bf7c6e2/ambari-server/src/test/python/stacks/2.2/common/test_stack_advisor.py
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.2/common/test_stack_advisor.py b/ambari-server/src/test/python/stacks/2.2/common/test_stack_advisor.py
index 6f6e6d8..9070c0a 100644
--- a/ambari-server/src/test/python/stacks/2.2/common/test_stack_advisor.py
+++ b/ambari-server/src/test/python/stacks/2.2/common/test_stack_advisor.py
@@ -2067,7 +2067,7 @@ class TestHDP22StackAdvisor(TestCase):
         "properties": {
           "timeline.metrics.cluster.aggregate.splitpoints": " ",
           "timeline.metrics.host.aggregate.splitpoints": " ",
-          "timeline.metrics.host.aggregator.ttl": "1",
+          "timeline.metrics.host.aggregator.ttl": "86400",
           "timeline.metrics.service.handler.thread.count": "20",
           'timeline.metrics.service.watcher.disabled': 'false'
         }
@@ -2247,7 +2247,7 @@ class TestHDP22StackAdvisor(TestCase):
     expected['ams-hbase-env']['properties']['hbase_regionserver_heapsize'] = '512'
     expected["ams-hbase-env"]['properties']['hbase_master_xmn_size'] = '102'
     expected['ams-hbase-env']['properties']['regionserver_xmn_size'] = '384'
-    expected['ams-site']['properties']['timeline.metrics.host.aggregator.ttl'] = '7'
+    expected['ams-site']['properties']['timeline.metrics.host.aggregator.ttl'] = '604800'
     expected['ams-site']['properties']['timeline.metrics.service.watcher.disabled'] = 'true'
     self.stackAdvisor.recommendAmsConfigurations(configurations, clusterData, services, hosts)
     self.assertEquals(configurations, expected)