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 2014/12/01 21:03:47 UTC

[19/22] ambari git commit: AMBARI-5707. Renaming a module. (swagle)

AMBARI-5707. Renaming a module. (swagle)


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

Branch: refs/heads/branch-metrics-dev
Commit: ba3d692614615ac7c409296f21cbccf3a02ce8d5
Parents: 11b9c23
Author: Siddharth Wagle <sw...@hortonworks.com>
Authored: Mon Dec 1 12:02:39 2014 -0800
Committer: Siddharth Wagle <sw...@hortonworks.com>
Committed: Mon Dec 1 12:02:39 2014 -0800

----------------------------------------------------------------------
 .../conf/unix/ambari-metrics-collector          |  269 ----
 .../conf/unix/ams-env.sh                        |   16 -
 .../conf/unix/ams-site.xml                      |   25 -
 .../conf/unix/log4j.properties                  |   31 -
 .../pom.xml                                     |  593 -------
 .../src/main/assemblies/ats.xml                 |   34 -
 .../src/main/assemblies/empty.xml               |   21 -
 .../src/main/assemblies/phoenix-client.xml      |   62 -
 .../phoenix-components-major-client.xml         |   53 -
 .../assemblies/phoenix-components-minimal.xml   |   71 -
 .../src/main/assemblies/phoenix-server.xml      |   46 -
 .../src/main/assemblies/simulator.xml           |   68 -
 .../main/conf/hbase-site-metrics-service.xml    |   80 -
 .../src/main/conf/simulator-log4j.xml           |   45 -
 .../ApplicationHistoryClientService.java        |  211 ---
 .../ApplicationHistoryManager.java              |   28 -
 .../ApplicationHistoryManagerImpl.java          |  250 ---
 .../ApplicationHistoryReader.java               |  117 --
 .../ApplicationHistoryServer.java               |  197 ---
 .../ApplicationHistoryStore.java                |   37 -
 .../ApplicationHistoryWriter.java               |  112 --
 .../FileSystemApplicationHistoryStore.java      |  784 ----------
 .../MemoryApplicationHistoryStore.java          |  274 ----
 .../NullApplicationHistoryStore.java            |  127 --
 .../metrics/loadsimulator/LoadRunner.java       |  160 --
 .../loadsimulator/MetricsLoadSimulator.java     |  120 --
 .../loadsimulator/MetricsSenderWorker.java      |   65 -
 .../metrics/loadsimulator/data/AppID.java       |   42 -
 .../metrics/loadsimulator/data/AppMetrics.java  |   48 -
 .../loadsimulator/data/ApplicationInstance.java |   59 -
 .../data/HostMetricsGenerator.java              |   63 -
 .../metrics/loadsimulator/data/Metric.java      |   71 -
 .../data/MetricsGeneratorConfigurer.java        |   95 --
 .../loadsimulator/net/MetricsSender.java        |   31 -
 .../loadsimulator/net/RestMetricsSender.java    |   95 --
 .../loadsimulator/net/StdOutMetricsSender.java  |   56 -
 .../metrics/loadsimulator/net/UrlService.java   |  101 --
 .../metrics/loadsimulator/util/Json.java        |   63 -
 .../util/RandomMetricsProvider.java             |   40 -
 .../loadsimulator/util/TimeStampProvider.java   |   52 -
 .../timeline/AbstractTimelineAggregator.java    |  229 ---
 .../metrics/timeline/Aggregator.java            |   60 -
 .../metrics/timeline/ConnectionProvider.java    |   30 -
 .../timeline/DefaultPhoenixDataSource.java      |   78 -
 .../timeline/HBaseTimelineMetricStore.java      |  192 ---
 .../metrics/timeline/MetricAggregate.java       |  110 --
 .../timeline/MetricClusterAggregate.java        |   74 -
 .../metrics/timeline/MetricHostAggregate.java   |   81 -
 .../MetricsInitializationException.java         |   42 -
 .../metrics/timeline/PhoenixHBaseAccessor.java  |  678 --------
 .../metrics/timeline/PhoenixTransactSQL.java    |  528 -------
 .../metrics/timeline/TimelineClusterMetric.java |   97 --
 .../timeline/TimelineMetricAggregator.java      |  144 --
 .../TimelineMetricAggregatorFactory.java        |   99 --
 .../TimelineMetricClusterAggregator.java        |  220 ---
 .../TimelineMetricClusterAggregatorHourly.java  |  173 --
 .../timeline/TimelineMetricConfiguration.java   |  115 --
 .../metrics/timeline/TimelineMetricStore.java   |   70 -
 .../records/ApplicationAttemptFinishData.java   |   95 --
 .../records/ApplicationAttemptHistoryData.java  |  171 --
 .../records/ApplicationAttemptStartData.java    |   82 -
 .../records/ApplicationFinishData.java          |   94 --
 .../records/ApplicationHistoryData.java         |  213 ---
 .../records/ApplicationStartData.java           |  106 --
 .../records/ContainerFinishData.java            |   90 --
 .../records/ContainerHistoryData.java           |  182 ---
 .../records/ContainerStartData.java             |   92 --
 .../pb/ApplicationAttemptFinishDataPBImpl.java  |  239 ---
 .../pb/ApplicationAttemptStartDataPBImpl.java   |  208 ---
 .../impl/pb/ApplicationFinishDataPBImpl.java    |  226 ---
 .../impl/pb/ApplicationStartDataPBImpl.java     |  229 ---
 .../impl/pb/ContainerFinishDataPBImpl.java      |  204 ---
 .../impl/pb/ContainerStartDataPBImpl.java       |  258 ---
 .../timeline/EntityIdentifier.java              |  100 --
 .../timeline/GenericObjectMapper.java           |  135 --
 .../timeline/LeveldbTimelineStore.java          | 1473 ------------------
 .../timeline/MemoryTimelineStore.java           |  360 -----
 .../timeline/NameValuePair.java                 |   59 -
 .../timeline/TimelineReader.java                |  155 --
 .../timeline/TimelineStore.java                 |   29 -
 .../timeline/TimelineWriter.java                |   46 -
 .../timeline/package-info.java                  |   20 -
 .../webapp/AHSController.java                   |   55 -
 .../webapp/AHSLogsPage.java                     |   55 -
 .../webapp/AHSView.java                         |   90 --
 .../webapp/AHSWebApp.java                       |   63 -
 .../webapp/AHSWebServices.java                  |  162 --
 .../webapp/AppAttemptPage.java                  |   69 -
 .../webapp/AppPage.java                         |   71 -
 .../webapp/ContainerPage.java                   |   41 -
 .../webapp/JAXBContextResolver.java             |   64 -
 .../webapp/NavBlock.java                        |   51 -
 .../webapp/TimelineWebServices.java             |  504 ------
 .../src/main/resources/metrics_def/DATANODE.dat |  101 --
 .../src/main/resources/metrics_def/HOST.dat     |   23 -
 .../main/resources/metrics_def/MASTER_HBASE.dat |   69 -
 .../src/main/resources/metrics_def/NAMENODE.dat |  205 ---
 .../main/resources/metrics_def/NODEMANAGER.dat  |   67 -
 .../resources/metrics_def/RESOURCEMANAGER.dat   |   88 --
 .../main/resources/metrics_def/SLAVE_HBASE.dat  |  178 ---
 .../src/main/resources/scripts/ams_query.py     |  209 ---
 .../src/main/resources/scripts/start.sh         |   30 -
 .../src/main/resources/scripts/start_slaves.sh  |   27 -
 .../src/main/resources/scripts/status_slaves.sh |   22 -
 .../src/main/resources/scripts/stop.sh          |   32 -
 .../src/main/resources/scripts/stop_slaves.sh   |   26 -
 .../src/test/conf/ams-site.xml                  |   29 -
 .../src/test/conf/hadoop-policy.xml             |  134 --
 .../src/test/conf/hbase-site.xml                |  230 ---
 .../ApplicationHistoryStoreTestUtils.java       |   84 -
 .../TestApplicationHistoryClientService.java    |  209 ---
 .../TestApplicationHistoryManagerImpl.java      |   76 -
 .../TestApplicationHistoryServer.java           |  217 ---
 .../TestFileSystemApplicationHistoryStore.java  |  233 ---
 .../TestMemoryApplicationHistoryStore.java      |  204 ---
 .../loadsimulator/data/TestAppMetrics.java      |  134 --
 .../metrics/loadsimulator/data/TestMetric.java  |   80 -
 .../net/TestRestMetricsSender.java              |   76 -
 .../net/TestStdOutMetricsSender.java            |   37 -
 .../util/TestRandomMetricsProvider.java         |   36 -
 .../util/TestTimeStampProvider.java             |   51 -
 .../timeline/AbstractMiniHBaseClusterTest.java  |  113 --
 .../AbstractPhoenixConnectionlessTest.java      |  111 --
 .../metrics/timeline/ITClusterAggregator.java   |  384 -----
 .../metrics/timeline/ITMetricAggregator.java    |  310 ----
 .../metrics/timeline/TestClusterSuite.java      |   30 -
 .../timeline/TestMetricHostAggregate.java       |   65 -
 .../timeline/TestPhoenixTransactSQL.java        |   43 -
 .../timeline/TestTimelineMetricStore.java       |   81 -
 .../timeline/TestGenericObjectMapper.java       |  102 --
 .../timeline/TestLeveldbTimelineStore.java      |  253 ---
 .../timeline/TestMemoryTimelineStore.java       |   83 -
 .../timeline/TimelineStoreTestUtils.java        |  789 ----------
 .../webapp/TestAHSWebApp.java                   |  183 ---
 .../webapp/TestAHSWebServices.java              |  303 ----
 .../webapp/TestTimelineWebServices.java         |  391 -----
 .../src/test/resources/hbase-default.xml        |   36 -
 .../4.2.0/phoenix-core-tests-4.2.0.jar          |  Bin 992828 -> 0 bytes
 .../4.2.0/phoenix-core-tests-4.2.0.pom          |    9 -
 .../phoenix-core-tests/maven-metadata-local.xml |   12 -
 .../src/main/assemblies/ats.xml                 |   34 +
 .../src/main/assemblies/empty.xml               |   21 +
 .../src/main/assemblies/phoenix-client.xml      |   62 +
 .../phoenix-components-major-client.xml         |   53 +
 .../assemblies/phoenix-components-minimal.xml   |   71 +
 .../src/main/assemblies/phoenix-server.xml      |   46 +
 .../src/main/assemblies/simulator.xml           |   68 +
 .../main/conf/hbase-site-metrics-service.xml    |   80 +
 .../src/main/conf/simulator-log4j.xml           |   45 +
 .../ApplicationHistoryClientService.java        |  211 +++
 .../ApplicationHistoryManager.java              |   28 +
 .../ApplicationHistoryManagerImpl.java          |  250 +++
 .../ApplicationHistoryReader.java               |  117 ++
 .../ApplicationHistoryServer.java               |  197 +++
 .../ApplicationHistoryStore.java                |   37 +
 .../ApplicationHistoryWriter.java               |  112 ++
 .../FileSystemApplicationHistoryStore.java      |  784 ++++++++++
 .../MemoryApplicationHistoryStore.java          |  274 ++++
 .../NullApplicationHistoryStore.java            |  127 ++
 .../metrics/loadsimulator/LoadRunner.java       |  160 ++
 .../loadsimulator/MetricsLoadSimulator.java     |  120 ++
 .../loadsimulator/MetricsSenderWorker.java      |   65 +
 .../metrics/loadsimulator/data/AppID.java       |   42 +
 .../metrics/loadsimulator/data/AppMetrics.java  |   48 +
 .../loadsimulator/data/ApplicationInstance.java |   59 +
 .../data/HostMetricsGenerator.java              |   63 +
 .../metrics/loadsimulator/data/Metric.java      |   71 +
 .../data/MetricsGeneratorConfigurer.java        |   95 ++
 .../loadsimulator/net/MetricsSender.java        |   31 +
 .../loadsimulator/net/RestMetricsSender.java    |   95 ++
 .../loadsimulator/net/StdOutMetricsSender.java  |   56 +
 .../metrics/loadsimulator/net/UrlService.java   |  101 ++
 .../metrics/loadsimulator/util/Json.java        |   63 +
 .../util/RandomMetricsProvider.java             |   40 +
 .../loadsimulator/util/TimeStampProvider.java   |   52 +
 .../timeline/AbstractTimelineAggregator.java    |  229 +++
 .../metrics/timeline/Aggregator.java            |   60 +
 .../metrics/timeline/ConnectionProvider.java    |   30 +
 .../timeline/DefaultPhoenixDataSource.java      |   78 +
 .../timeline/HBaseTimelineMetricStore.java      |  192 +++
 .../metrics/timeline/MetricAggregate.java       |  110 ++
 .../timeline/MetricClusterAggregate.java        |   74 +
 .../metrics/timeline/MetricHostAggregate.java   |   81 +
 .../MetricsInitializationException.java         |   42 +
 .../metrics/timeline/PhoenixHBaseAccessor.java  |  678 ++++++++
 .../metrics/timeline/PhoenixTransactSQL.java    |  528 +++++++
 .../metrics/timeline/TimelineClusterMetric.java |   97 ++
 .../timeline/TimelineMetricAggregator.java      |  144 ++
 .../TimelineMetricAggregatorFactory.java        |   99 ++
 .../TimelineMetricClusterAggregator.java        |  220 +++
 .../TimelineMetricClusterAggregatorHourly.java  |  173 ++
 .../timeline/TimelineMetricConfiguration.java   |  115 ++
 .../metrics/timeline/TimelineMetricStore.java   |   70 +
 .../records/ApplicationAttemptFinishData.java   |   95 ++
 .../records/ApplicationAttemptHistoryData.java  |  171 ++
 .../records/ApplicationAttemptStartData.java    |   82 +
 .../records/ApplicationFinishData.java          |   94 ++
 .../records/ApplicationHistoryData.java         |  213 +++
 .../records/ApplicationStartData.java           |  106 ++
 .../records/ContainerFinishData.java            |   90 ++
 .../records/ContainerHistoryData.java           |  182 +++
 .../records/ContainerStartData.java             |   92 ++
 .../pb/ApplicationAttemptFinishDataPBImpl.java  |  239 +++
 .../pb/ApplicationAttemptStartDataPBImpl.java   |  208 +++
 .../impl/pb/ApplicationFinishDataPBImpl.java    |  226 +++
 .../impl/pb/ApplicationStartDataPBImpl.java     |  229 +++
 .../impl/pb/ContainerFinishDataPBImpl.java      |  204 +++
 .../impl/pb/ContainerStartDataPBImpl.java       |  258 +++
 .../timeline/EntityIdentifier.java              |  100 ++
 .../timeline/GenericObjectMapper.java           |  135 ++
 .../timeline/LeveldbTimelineStore.java          | 1473 ++++++++++++++++++
 .../timeline/MemoryTimelineStore.java           |  360 +++++
 .../timeline/NameValuePair.java                 |   59 +
 .../timeline/TimelineReader.java                |  155 ++
 .../timeline/TimelineStore.java                 |   29 +
 .../timeline/TimelineWriter.java                |   46 +
 .../timeline/package-info.java                  |   20 +
 .../webapp/AHSController.java                   |   55 +
 .../webapp/AHSLogsPage.java                     |   55 +
 .../webapp/AHSView.java                         |   90 ++
 .../webapp/AHSWebApp.java                       |   63 +
 .../webapp/AHSWebServices.java                  |  162 ++
 .../webapp/AppAttemptPage.java                  |   69 +
 .../webapp/AppPage.java                         |   71 +
 .../webapp/ContainerPage.java                   |   41 +
 .../webapp/JAXBContextResolver.java             |   64 +
 .../webapp/NavBlock.java                        |   51 +
 .../webapp/TimelineWebServices.java             |  504 ++++++
 .../src/main/resources/metrics_def/DATANODE.dat |  101 ++
 .../src/main/resources/metrics_def/HOST.dat     |   23 +
 .../main/resources/metrics_def/MASTER_HBASE.dat |   69 +
 .../src/main/resources/metrics_def/NAMENODE.dat |  205 +++
 .../main/resources/metrics_def/NODEMANAGER.dat  |   67 +
 .../resources/metrics_def/RESOURCEMANAGER.dat   |   88 ++
 .../main/resources/metrics_def/SLAVE_HBASE.dat  |  178 +++
 .../src/main/resources/scripts/ams_query.py     |  209 +++
 .../src/main/resources/scripts/start.sh         |   30 +
 .../src/main/resources/scripts/start_slaves.sh  |   27 +
 .../src/main/resources/scripts/status_slaves.sh |   22 +
 .../src/main/resources/scripts/stop.sh          |   32 +
 .../src/main/resources/scripts/stop_slaves.sh   |   26 +
 .../src/test/conf/ams-site.xml                  |   29 +
 .../src/test/conf/hadoop-policy.xml             |  134 ++
 .../src/test/conf/hbase-site.xml                |  230 +++
 .../metrics/timeline/ITClusterAggregator.java   |  384 +++++
 .../metrics/timeline/ITMetricAggregator.java    |  310 ++++
 .../metrics/timeline/TestClusterSuite.java      |   30 +
 .../webapp/TestAHSWebApp.java                   |  183 +++
 .../webapp/TestAHSWebServices.java              |  303 ++++
 .../webapp/TestTimelineWebServices.java         |  391 +++++
 ambari-metrics/pom.xml                          |    2 +-
 251 files changed, 15961 insertions(+), 20029 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ambari-metrics-collector
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ambari-metrics-collector b/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ambari-metrics-collector
deleted file mode 100644
index 9aabbdc..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ambari-metrics-collector
+++ /dev/null
@@ -1,269 +0,0 @@
-#!/usr/bin/env bash
-
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#     http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific
-
-#JAVA_HOME=/usr/jdk64/jdk1.7.0_45
-PIDFILE=/var/run/ambari-metrics-collector/ambari-metrics-collector.pid
-OUTFILE=/var/log/ambari-metrics-collector/ambari-metrics-collector.out
-
-HBASE_ZK_PID=/var/run/ams-hbase/hbase-hbase-zookeeper.pid
-HBASE_MASTER_PID=/var/run/ams-hbase/hbase-hbase-master.pid
-HBASE_RS_PID=/var/run/ams-hbase/hbase-hbase-regionserver.pid
-
-HBASE_DIR=/usr/lib/ams-hbase
-
-DAEMON_NAME=timelineserver
-
-COLLECTOR_CONF_DIR=/etc/ambari-metrics-collector/conf
-HBASE_CONF_DIR=/etc/ams-hbase/conf
-
-METRIC_COLLECTOR=ambari-metrics-collector
-
-STOP_TIMEOUT=5
-
-function hbase_daemon
-{
-    local daemon=$1
-    local cmd=$2
-    local pid
-
-    case "${daemon}" in
-      "master")
-        pid=${HBASE_MASTER_PID}
-      ;;
-      "zookeeper")
-        pid=${HBASE_ZK_PID}
-      ;;
-      "regionserver")
-        pid=${HBASE_RS_PID}
-      ;;
-    esac
-
-    daemon_status "${pid}"
-    if [[ $? == 0  ]]; then
-        echo "${daemon} is running as process $(cat "${pid}"). Continuing"
-      else
-        # stale pid file, so just remove it and continue on
-        rm -f "${pid}" >/dev/null 2>&1
-    fi
-
-    ${HBASE_DIR}/bin/hbase-daemon.sh --config ${HBASE_CONF_DIR} ${cmd} ${daemon}
-
-
-
-}
-
-function write_pidfile
-{
-    local pidfile="$1"
-    echo $! > "${pidfile}" 2>/dev/null
-    if [[ $? -gt 0 ]]; then
-      echo "ERROR:  Cannot write pid ${pidfile}."
-      exit 1;
-    fi
-}
-
-function hadoop_java_setup
-{
-  # Bail if we did not detect it
-  if [[ -z "${JAVA_HOME}" ]]; then
-    echo "ERROR: JAVA_HOME is not set and could not be found."
-    exit 1
-  fi
-
-  if [[ ! -d "${JAVA_HOME}" ]]; then
-    echo "ERROR: JAVA_HOME ${JAVA_HOME} does not exist."
-    exit 1
-  fi
-
-  JAVA="${JAVA_HOME}/bin/java"
-
-  if [[ ! -x "$JAVA" ]]; then
-    echo "ERROR: $JAVA is not executable."
-    exit 1
-  fi
-  # shellcheck disable=SC2034
-  JAVA_HEAP_MAX=-Xmx1g
-  HADOOP_HEAPSIZE=${HADOOP_HEAPSIZE:-1024}
-
-  # check envvars which might override default args
-  if [[ -n "$HADOOP_HEAPSIZE" ]]; then
-    # shellcheck disable=SC2034
-    JAVA_HEAP_MAX="-Xmx${HADOOP_HEAPSIZE}m"
-  fi
-}
-
-function daemon_status()
-{
-  #
-  # LSB 4.1.0 compatible status command (1)
-  #
-  # 0 = program is running
-  # 1 = dead, but still a pid (2)
-  # 2 = (not used by us)
-  # 3 = not running
-  #
-  # 1 - this is not an endorsement of the LSB
-  #
-  # 2 - technically, the specification says /var/run/pid, so
-  #     we should never return this value, but we're giving
-  #     them the benefit of a doubt and returning 1 even if
-  #     our pid is not in in /var/run .
-  #
-
-  local pidfile="$1"
-  shift
-
-  local pid
-
-  if [[ -f "${pidfile}" ]]; then
-    pid=$(cat "${pidfile}")
-    if ps -p "${pid}" > /dev/null 2>&1; then
-      return 0
-    fi
-    return 1
-  fi
-  return 3
-}
-
-while [[ -z "${_ams_configs_done}" ]]; do
-  case $1 in
-    --config)
-      shift
-      confdir=$1
-      shift
-      if [[ -d "${confdir}" ]]; then
-        COLLECTOR_CONF_DIR="${confdir}"
-      elif [[ -z "${confdir}" ]]; then
-        echo "ERROR: No parameter provided for --config "
-        exit 1
-      else
-        echo "ERROR: Cannot find configuration directory \"${confdir}\""
-        exit 1
-      fi
-    ;;
-    *)
-      _ams_configs_done=true
-    ;;
-  esac
-done
-
-#execute ams-env.sh
-if [[ -f "${COLLECTOR_CONF_DIR}/ams-env.sh" ]]; then
-  . "${COLLECTOR_CONF_DIR}/ams-env.sh"
-else
-  echo "ERROR: Cannot execute ${COLLECTOR_CONF_DIR}/ams-env.sh." 2>&1
-  exit 1
-fi
-
-#TODO manage 3 hbase daemons for start/stop/status
-case "$1" in
-
-	start)
-		hadoop_java_setup
-
-		#hbase_daemon "zookeeper" "start"
-
-		hbase_daemon "master" "start"
-		#hbase_daemon "regionserver" "start"
-
-    sleep 30
-
-		CLASS='org.apache.hadoop.yarn.server.applicationhistoryservice.ApplicationHistoryServer'
-		# YARN_OPTS="${YARN_OPTS} ${YARN_TIMELINESERVER_OPTS}"
-		# if [[ -n "${YARN_TIMELINESERVER_HEAPSIZE}" ]]; then
-		#   JAVA_HEAP_MAX="-Xmx${YARN_TIMELINESERVER_HEAPSIZE}m"
-		# fi
-		
-		# check if this is needed?
-		# export PHOENIX_JAR_PATH=/usr/lib/ambari-metrics/timelineservice/phoenix-client.jar
-		# export HBASE_CONF_DIR=${HBASE_DIR}/conf
-
-    daemon_status "${PIDFILE}"
-    if [[ $? == 0  ]]; then
-        echo "AMS is running as process $(cat "${PIDFILE}"). Exiting"
-        exit 1
-    else
-        # stale pid file, so just remove it and continue on
-        rm -f "${PIDFILE}" >/dev/null 2>&1
-    fi
-
-    nohup "${JAVA}" "-cp" "/usr/lib/ambari-metrics-collector/*:${COLLECTOR_CONF_DIR}" "-Djava.net.preferIPv4Stack=true" "-Dproc_${DAEMON_NAME}" "${CLASS}" "$@" > $OUTFILE 2>&1 &
-    PID=$!
-    write_pidfile "${PIDFILE}"
-    sleep 2
-
-    echo "Verifying ${METRIC_COLLECTOR} process status..."
-    if [ -z "`ps ax -o pid | grep ${PID}`" ]; then
-      if [ -s ${OUTFILE} ]; then
-        echo "ERROR: ${METRIC_COLLECTOR} start failed. For more details, see ${OUTFILE}:"
-        echo "===================="
-        tail -n 10 ${OUTFILE}
-        echo "===================="
-      else
-        echo "ERROR: ${METRIC_COLLECTOR} start failed"
-        rm -f ${PIDFILE}
-      fi
-      echo "Collector out at: ${OUTFILE}"
-      exit -1
-    fi
-
-    echo "Collector successfully started."
-
-  ;;
-	stop)
-	    pidfile=${PIDFILE}
-
-	    if [[ -f "${pidfile}" ]]; then
-          pid=$(cat "$pidfile")
-
-          kill "${pid}" >/dev/null 2>&1
-          sleep "${STOP_TIMEOUT}"
-
-          if kill -0 "${pid}" > /dev/null 2>&1; then
-            echo "WARNING: ${METRIC_COLLECTOR} did not stop gracefully after ${STOP_TIMEOUT} seconds: Trying to kill with kill -9"
-            kill -9 "${pid}" >/dev/null 2>&1
-          fi
-
-          if ps -p "${pid}" > /dev/null 2>&1; then
-            echo "ERROR: Unable to kill ${pid}"
-          else
-            rm -f "${pidfile}" >/dev/null 2>&1
-          fi
-      fi
-
-      #stop hbase daemons
-      #hbase_daemon "zookeeper" "stop"
-      hbase_daemon "master" "stop"
-      #hbase_daemon "regionserver" "stop"
-
-
-    ;;
-	status)
-	    daemon_status "${PIDFILE}"
-	    if [[ $? == 0  ]]; then
-            echo "AMS is running as process $(cat "${PIDFILE}")."
-        else
-            echo "AMS is not running."
-        fi
-        #print embedded hbase daemons statuses?
-    ;;
-	restart)
-	;;
-
-esac
-
-
-

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ams-env.sh
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ams-env.sh b/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ams-env.sh
deleted file mode 100644
index 9928093..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ams-env.sh
+++ /dev/null
@@ -1,16 +0,0 @@
-# Licensed to the Apache Software Foundation (ASF) under one or more
-# contributor license agreements.  See the NOTICE file distributed with
-# this work for additional information regarding copyright ownership.
-# The ASF licenses this file to You under the Apache License, Version 2.0
-# (the "License"); you may not use this file except in compliance with
-# the License.  You may obtain a copy of the License at
-#
-#     http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-
-# Set environment variables here.

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ams-site.xml
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ams-site.xml b/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ams-site.xml
deleted file mode 100644
index c2dd100..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/ams-site.xml
+++ /dev/null
@@ -1,25 +0,0 @@
-<?xml version="1.0"?>
-
-<!--
-  ~ Licensed to the Apache Software Foundation (ASF) under one
-  ~ or more contributor license agreements.  See the NOTICE file
-  ~ distributed with this work for additional information
-  ~ regarding copyright ownership.  The ASF licenses this file
-  ~ to you under the Apache License, Version 2.0 (the
-  ~ "License"); you may not use this file except in compliance
-  ~ with the License.  You may obtain a copy of the License at
-  ~
-  ~     http://www.apache.org/licenses/LICENSE-2.0
-  ~
-  ~ Unless required by applicable law or agreed to in writing, software
-  ~ distributed under the License is distributed on an "AS IS" BASIS,
-  ~ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  ~ See the License for the specific language governing permissions and
-  ~ limitations under the License.
-  -->
-
-<configuration>
-
-  <!-- Site specific AMS configuration properties -->
-
-</configuration>

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/log4j.properties
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/log4j.properties b/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/log4j.properties
deleted file mode 100644
index 8a9e2c8..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/conf/unix/log4j.properties
+++ /dev/null
@@ -1,31 +0,0 @@
-#
-# Licensed to the Apache Software Foundation (ASF) under one
-# or more contributor license agreements.  See the NOTICE file
-# distributed with this work for additional information
-# regarding copyright ownership.  The ASF licenses this file
-# to you under the Apache License, Version 2.0 (the
-# "License"); you may not use this file except in compliance
-# with the License.  You may obtain a copy of the License at
-#
-#     http://www.apache.org/licenses/LICENSE-2.0
-#
-# Unless required by applicable law or agreed to in writing, software
-# distributed under the License is distributed on an "AS IS" BASIS,
-# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-# See the License for the specific language governing permissions and
-# limitations under the License.
-#
-
-# Define some default values that can be overridden by system properties
-# Root logger option
-log4j.rootLogger=INFO,file
-
-# Direct log messages to a log file
-log4j.appender.file=org.apache.log4j.RollingFileAppender
-log4j.appender.file.File=/var/log/ambari-metrics-collector/ambari-metrics-collector.log
-log4j.appender.file.MaxFileSize=80MB
-log4j.appender.file.MaxBackupIndex=60
-log4j.appender.file.layout=org.apache.log4j.PatternLayout
-log4j.appender.file.layout.ConversionPattern=%d{ABSOLUTE} %5p [%t] %c{1}:%L - %m%n
-
-

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/pom.xml
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/pom.xml b/ambari-metrics/ambari-metrics-hadoop-timelineservice/pom.xml
deleted file mode 100644
index 9bf0f51..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/pom.xml
+++ /dev/null
@@ -1,593 +0,0 @@
-<?xml version="1.0" encoding="UTF-8"?>
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one or more
-   contributor license agreements.  See the NOTICE file distributed with
-   this work for additional information regarding copyright ownership.
-   The ASF licenses this file to You under the Apache License, Version 2.0
-   (the "License"); you may not use this file except in compliance with
-   the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-   See the License for the specific language governing permissions and
-   limitations under the License.
--->
-<project xmlns="http://maven.apache.org/POM/4.0.0"
-         xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-         xsi:schemaLocation="http://maven.apache.org/POM/4.0.0
-                      http://maven.apache.org/xsd/maven-4.0.0.xsd">
-  <parent>
-    <artifactId>ambari-metrics</artifactId>
-    <groupId>org.apache.ambari</groupId>
-    <version>0.1.0-SNAPSHOT</version>
-  </parent>
-  <modelVersion>4.0.0</modelVersion>
-  <artifactId>ambari-metrics-hadoop-timelineservice</artifactId>
-  <version>0.1.0-SNAPSHOT</version>
-  <name>ambari-metrics-hadoop-timelineservice</name>
-  <packaging>jar</packaging>
-
-  <properties>
-    <!-- Needed for generating FindBugs warnings using parent pom -->
-    <!--<yarn.basedir>${project.parent.parent.basedir}</yarn.basedir>-->
-    <protobuf.version>2.5.0</protobuf.version>
-    <hadoop.version>2.4.0</hadoop.version>
-  </properties>
-
-  <repositories>
-    <repository>
-      <id>phoenix-core-tests</id>
-      <name>Phoenix Unit tests</name>
-      <url>file://${project.basedir}/src/test/resources/lib</url>
-    </repository>
-  </repositories>
-  <build>
-    <plugins>
-      <plugin>
-        <artifactId>maven-dependency-plugin</artifactId>
-        <executions>
-          <execution>
-            <phase>package</phase>
-            <goals>
-              <goal>copy-dependencies</goal>
-            </goals>
-            <configuration>
-              <outputDirectory>${project.build.directory}/lib</outputDirectory>
-              <includeScope>compile</includeScope>
-              <excludeScope>test</excludeScope>
-            </configuration>
-          </execution>
-        </executions>
-      </plugin>
-      <plugin>
-        <artifactId>maven-assembly-plugin</artifactId>
-        <executions>
-          <execution>
-            <configuration>
-              <descriptors>
-                <descriptor>src/main/assemblies/ats.xml</descriptor>
-              </descriptors>
-              <tarLongFileMode>gnu</tarLongFileMode>
-            </configuration>
-            <id>build-tarball</id>
-            <phase>none</phase>
-            <goals>
-              <goal>single</goal>
-            </goals>
-          </execution>
-
-        </executions>
-      </plugin>
-      <plugin>
-        <groupId>com.github.goldin</groupId>
-        <artifactId>copy-maven-plugin</artifactId>
-        <version>0.2.5</version>
-        <executions>
-          <execution>
-            <id>create-archive</id>
-            <phase>package</phase>
-            <goals>
-              <goal>copy</goal>
-            </goals>
-            <configuration>
-              <resources>
-                <resource>
-                  <targetPath>${project.build.directory}/embedded</targetPath>
-                  <file>${hbase.tar}</file>
-                  <unpack>true</unpack>
-                </resource>
-              </resources>
-            </configuration>
-          </execution>
-        </executions>
-      </plugin>
-      <plugin>
-        <groupId>org.codehaus.mojo</groupId>
-        <artifactId>rpm-maven-plugin</artifactId>
-        <version>2.0.1</version>
-        <executions>
-          <execution>
-            <!-- unbinds rpm creation from maven lifecycle -->
-            <phase>none</phase>
-            <goals>
-              <goal>rpm</goal>
-            </goals>
-          </execution>
-        </executions>
-        <configuration>
-          <name>ambari-metrics-collector</name>
-          <copyright>2012, Apache Software Foundation</copyright>
-          <group>Development</group>
-          <description>Maven Recipe: RPM Package.</description>
-          <autoRequires>false</autoRequires>
-          <requires>
-            <require>${python.ver}</require>
-          </requires>
-
-          <defaultFilemode>644</defaultFilemode>
-          <defaultDirmode>755</defaultDirmode>
-          <defaultUsername>root</defaultUsername>
-          <defaultGroupname>root</defaultGroupname>
-
-          <mappings>
-            <mapping>
-              <!--jars-->
-              <directory>/usr/lib/ambari-metrics-collector/</directory>
-              <sources>
-                <source>
-                  <location>target/lib</location>
-                </source>
-                <source>
-                  <location>${project.build.directory}/${project.artifactId}-${project.version}.jar</location>
-                </source>
-              </sources>
-            </mapping>
-            <mapping>
-              <!--embedded applications-->
-              <directory>/usr/lib/ams-hbase/</directory>
-              <sources>
-                <source>
-                  <location>target/embedded/${hbase.folder}</location>
-                  <excludes>
-                    <exclude>bin/**</exclude>
-                    <exclude>bin/*</exclude>
-                  </excludes>
-                </source>
-              </sources>
-            </mapping>
-            <mapping>
-              <directory>/usr/lib/ams-hbase/bin</directory>
-              <filemode>755</filemode>
-              <sources>
-                <source>
-                  <location>target/embedded/${hbase.folder}/bin</location>
-                </source>
-              </sources>
-            </mapping>
-            <mapping>
-              <directory>/usr/lib/ams-hbase/lib/</directory>
-              <sources>
-                <source>
-                  <location>target/lib</location>
-                  <includes>
-                    <include>phoenix*.jar</include>
-                    <include>antlr*.jar</include>
-                  </includes>
-                </source>
-              </sources>
-            </mapping>
-            <mapping>
-              <directory>/usr/sbin</directory>
-              <filemode>755</filemode>
-              <username>root</username>
-              <groupname>root</groupname>
-              <directoryIncluded>false</directoryIncluded>
-              <sources>
-                <source>
-                  <location>conf/unix/ambari-metrics-collector</location>
-                  <filter>false</filter>
-                </source>
-              </sources>
-            </mapping>
-            <mapping>
-              <directory>/etc/ambari-metrics-collector/conf</directory>
-              <configuration>true</configuration>
-              <sources>
-                <source>
-                  <location>conf/unix/ams-env.sh</location>
-                </source>
-                <source>
-                  <location>conf/unix/ams-site.xml</location>
-                </source>
-                <source>
-                  <location>conf/unix/log4j.properties</location>
-                </source>
-                <source>
-                  <location>target/embedded/${hbase.folder}/conf/hbase-site.xml</location>
-                </source>
-              </sources>
-            </mapping>
-            <mapping>
-              <directory>/etc/ams-hbase/conf</directory>
-              <configuration>true</configuration>
-              <sources>
-                <source>
-                  <location>target/embedded/${hbase.folder}/conf</location>
-                  <includes>
-                    <include>*.*</include>
-                  </includes>
-                </source>
-              </sources>
-            </mapping>
-            <mapping>
-              <directory>/var/run/ams-hbase</directory>
-            </mapping>
-            <mapping>
-              <directory>/var/run/ambari-metrics-collector</directory>
-            </mapping>
-            <mapping>
-              <directory>/var/log/ambari-metrics-collector</directory>
-            </mapping>
-            <mapping>
-              <directory>/var/lib/ambari-metrics-collector</directory>
-            </mapping>
-          </mappings>
-        </configuration>
-      </plugin>
-      <plugin>
-        <artifactId>maven-surefire-plugin</artifactId>
-        <configuration>
-          <redirectTestOutputToFile>true</redirectTestOutputToFile>
-          <forkMode>always</forkMode>
-        </configuration>
-      </plugin>
-    </plugins>
-  </build>
-
-  <dependencies>
-    <dependency>
-      <groupId>org.apache.phoenix</groupId>
-      <artifactId>phoenix-core</artifactId>
-      <version>4.2.0.2.2.0.0-2041</version>
-      <exclusions>
-        <exclusion>
-          <groupId>org.apache.hadoop</groupId>
-          <artifactId>hadoop-common</artifactId>
-        </exclusion>
-        <exclusion>
-          <groupId>org.apache.hadoop</groupId>
-          <artifactId>hadoop-annotations</artifactId>
-        </exclusion>
-      </exclusions>
-    </dependency>
-
-    <dependency>
-      <groupId>commons-lang</groupId>
-      <artifactId>commons-lang</artifactId>
-      <version>2.5</version>
-    </dependency>
-
-    <dependency>
-      <artifactId>ambari-metrics-hadoop-sink</artifactId>
-      <groupId>org.apache.ambari</groupId>
-      <version>0.1.0-SNAPSHOT</version>
-    </dependency>
-
-    <dependency>
-      <groupId>javax.servlet</groupId>
-      <artifactId>servlet-api</artifactId>
-      <version>2.5</version>
-    </dependency>
-    <!-- 'mvn dependency:analyze' fails to detect use of this dependency -->
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-common</artifactId>
-      <version>${hadoop.version}</version>
-      <scope>provided</scope>
-      <exclusions>
-        <exclusion>
-          <groupId>commons-el</groupId>
-          <artifactId>commons-el</artifactId>
-        </exclusion>
-        <exclusion>
-          <groupId>tomcat</groupId>
-          <artifactId>jasper-runtime</artifactId>
-        </exclusion>
-        <exclusion>
-          <groupId>tomcat</groupId>
-          <artifactId>jasper-compiler</artifactId>
-        </exclusion>
-        <exclusion>
-          <groupId>org.mortbay.jetty</groupId>
-          <artifactId>jsp-2.1-jetty</artifactId>
-        </exclusion>
-      </exclusions>
-    </dependency>
-
-    <!-- 'mvn dependency:analyze' fails to detect use of this dependency -->
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-annotations</artifactId>
-      <version>${hadoop.version}</version>
-    </dependency>
-    <dependency>
-      <groupId>org.mockito</groupId>
-      <artifactId>mockito-all</artifactId>
-      <version>1.8.5</version>
-      <scope>test</scope>
-    </dependency>
-    <!-- 'mvn dependency:analyze' fails to detect use of this dependency -->
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-common</artifactId>
-      <version>${hadoop.version}</version>
-      <type>test-jar</type>
-      <scope>test</scope>
-    </dependency>
-    <dependency>
-      <groupId>com.google.inject.extensions</groupId>
-      <artifactId>guice-servlet</artifactId>
-      <version>3.0</version>
-    </dependency>
-    <dependency>
-      <groupId>com.google.protobuf</groupId>
-      <artifactId>protobuf-java</artifactId>
-      <version>${protobuf.version}</version>
-    </dependency>
-    <dependency>
-      <groupId>junit</groupId>
-      <artifactId>junit</artifactId>
-      <scope>test</scope>
-      <version>4.10</version>
-    </dependency>
-    <!-- 'mvn dependency:analyze' fails to detect use of this dependency -->
-    <dependency>
-      <groupId>com.google.inject</groupId>
-      <artifactId>guice</artifactId>
-      <version>3.0</version>
-    </dependency>
-    <dependency>
-      <groupId>com.sun.jersey.jersey-test-framework</groupId>
-      <artifactId>jersey-test-framework-core</artifactId>
-      <version>1.11</version>
-      <scope>test</scope>
-    </dependency>
-    <dependency>
-      <groupId>com.sun.jersey</groupId>
-      <artifactId>jersey-json</artifactId>
-      <version>1.11</version>
-    </dependency>
-    <dependency>
-      <groupId>com.sun.jersey.contribs</groupId>
-      <artifactId>jersey-guice</artifactId>
-      <version>1.11</version>
-    </dependency>
-    <dependency>
-      <groupId>com.sun.jersey</groupId>
-      <artifactId>jersey-server</artifactId>
-      <version>1.11</version>
-    </dependency>
-    <!-- 'mvn dependency:analyze' fails to detect use of this dependency -->
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-yarn-common</artifactId>
-      <version>${hadoop.version}</version>
-      <type>test-jar</type>
-      <scope>test</scope>
-    </dependency>
-    <!-- 'mvn dependency:analyze' fails to detect use of this dependency -->
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-yarn-common</artifactId>
-      <version>${hadoop.version}</version>
-    </dependency>
-    <!-- 'mvn dependency:analyze' fails to detect use of this dependency -->
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-yarn-api</artifactId>
-      <version>${hadoop.version}</version>
-    </dependency>
-    <dependency>
-      <groupId>javax.xml.bind</groupId>
-      <artifactId>jaxb-api</artifactId>
-      <version>2.2.2</version>
-    </dependency>
-    <dependency>
-      <groupId>org.codehaus.jettison</groupId>
-      <artifactId>jettison</artifactId>
-      <version>1.1</version>
-    </dependency>
-    <dependency>
-      <groupId>com.sun.jersey</groupId>
-      <artifactId>jersey-core</artifactId>
-      <version>1.11</version>
-    </dependency>
-    <dependency>
-      <groupId>com.sun.jersey</groupId>
-      <artifactId>jersey-client</artifactId>
-      <version>1.11</version>
-    </dependency>
-    <dependency>
-      <groupId>com.google.guava</groupId>
-      <artifactId>guava</artifactId>
-      <version>14.0.1</version>
-    </dependency>
-    <dependency>
-      <groupId>commons-logging</groupId>
-      <artifactId>commons-logging</artifactId>
-      <version>1.1.1</version>
-    </dependency>
-
-    <!-- 'mvn dependency:analyze' fails to detect use of this dependency -->
-    <dependency>
-      <groupId>org.apache.hadoop</groupId>
-      <artifactId>hadoop-yarn-server-common</artifactId>
-      <version>${hadoop.version}</version>
-    </dependency>
-
-    <!-- 'mvn dependency:analyze' fails to detect use of this dependency -->
-    <dependency>
-      <groupId>com.sun.jersey.jersey-test-framework</groupId>
-      <artifactId>jersey-test-framework-grizzly2</artifactId>
-      <scope>test</scope>
-      <version>1.11</version>
-    </dependency>
-
-    <dependency>
-      <groupId>org.codehaus.jackson</groupId>
-      <artifactId>jackson-core-asl</artifactId>
-      <version>1.9.9</version>
-    </dependency>
-
-    <dependency>
-      <groupId>org.slf4j</groupId>
-      <artifactId>slf4j-api</artifactId>
-      <version>1.7.2</version>
-    </dependency>
-
-    <dependency>
-      <groupId>org.slf4j</groupId>
-      <artifactId>slf4j-log4j12</artifactId>
-      <version>1.7.2</version>
-    </dependency>
-
-    <dependency>
-      <groupId>org.codehaus.jackson</groupId>
-      <artifactId>jackson-mapper-asl</artifactId>
-      <version>1.9.13</version>
-    </dependency>
-
-    <dependency>
-      <groupId>commons-collections</groupId>
-      <artifactId>commons-collections</artifactId>
-      <version>3.2.1</version>
-    </dependency>
-
-    <dependency>
-      <groupId>org.fusesource.leveldbjni</groupId>
-      <artifactId>leveldbjni-all</artifactId>
-      <version>1.8</version>
-    </dependency>
-
-    <dependency>
-      <groupId>org.assertj</groupId>
-      <artifactId>assertj-core</artifactId>
-      <version>1.7.0</version>
-      <scope>test</scope>
-    </dependency>
-
-    <dependency>
-      <groupId>org.easymock</groupId>
-      <artifactId>easymock</artifactId>
-      <version>3.2</version>
-      <scope>test</scope>
-    </dependency>
-    <!-- for unit tests only -->
-    <dependency>
-      <groupId>org.apache.phoenix</groupId>
-      <artifactId>phoenix-core-tests</artifactId>
-      <version>4.2.0</version>
-      <scope>test</scope>
-    </dependency>
-    <dependency>
-      <groupId>org.apache.hbase</groupId>
-      <artifactId>hbase-it</artifactId>
-      <version>0.98.4-hadoop2</version>
-      <scope>test</scope>
-      <classifier>tests</classifier>
-    </dependency>
-      <dependency>
-        <groupId>org.apache.hbase</groupId>
-        <artifactId>hbase-testing-util</artifactId>
-        <version>0.98.4-hadoop2</version>
-        <scope>test</scope>
-        <optional>true</optional>
-        <exclusions>
-          <exclusion>
-            <groupId>org.jruby</groupId>
-            <artifactId>jruby-complete</artifactId>
-          </exclusion>
-        </exclusions>
-      </dependency>
-    <dependency>
-      <groupId>org.powermock</groupId>
-      <artifactId>powermock-module-junit4</artifactId>
-      <version>1.4.9</version>
-      <scope>test</scope>
-    </dependency>
-    <dependency>
-      <groupId>org.powermock</groupId>
-      <artifactId>powermock-api-mockito</artifactId>
-      <version>1.4.9</version>
-      <scope>test</scope>
-    </dependency>
-    <dependency>
-      <groupId>org.powermock</groupId>
-      <artifactId>powermock-api-easymock</artifactId>
-      <version>1.4.9</version>
-      <scope>test</scope>
-    </dependency>
-
-  </dependencies>
-
-  <profiles>
-    <profile>
-      <id>sim</id>
-      <build>
-
-        <plugins>
-          <plugin>
-            <artifactId>maven-assembly-plugin</artifactId>
-            <configuration>
-              <descriptors>
-                <descriptor>src/main/assemblies/simulator.xml</descriptor>
-              </descriptors>
-              <tarLongFileMode>gnu</tarLongFileMode>
-            </configuration>
-            <executions>
-              <execution>
-                <id>build-tarball</id>
-                <phase>package</phase>
-                <goals>
-                  <goal>single</goal>
-                </goals>
-              </execution>
-            </executions>
-          </plugin>
-
-          <plugin>
-            <artifactId>maven-jar-plugin</artifactId>
-            <version>2.3.1</version>
-            <!-- The configuration of the plugin -->
-            <configuration>
-              <!-- Configuration of the archiver -->
-              <finalName>${pom.artifactId}-simulator-${pom.version}</finalName>
-              <archive>
-                <!-- Manifest specific configuration -->
-                <manifest>
-                  <!-- Classpath is added to the manifest of the created jar file. -->
-                  <addClasspath>true</addClasspath>
-                  <!--
-                      Configures the classpath prefix. This configuration option is
-                      used to specify that all needed libraries are found under lib/
-                      directory.
-                  -->
-                  <classpathPrefix></classpathPrefix>
-                  <!-- Specifies the main class of the application -->
-                  <mainClass>
-                    org.apache.hadoop.yarn.server.applicationhistoryservice.metrics.loadsimulator.MetricsLoadSimulator
-                  </mainClass>
-                </manifest>
-              </archive>
-            </configuration>
-          </plugin>
-        </plugins>
-
-      </build>
-
-    </profile>
-  </profiles>
-</project>

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/ats.xml
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/ats.xml b/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/ats.xml
deleted file mode 100644
index 21a6b36..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/ats.xml
+++ /dev/null
@@ -1,34 +0,0 @@
-<?xml version="1.0"?>
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one or more
-   contributor license agreements.  See the NOTICE file distributed with
-   this work for additional information regarding copyright ownership.
-   The ASF licenses this file to You under the Apache License, Version 2.0
-   (the "License"); you may not use this file except in compliance with
-   the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-   See the License for the specific language governing permissions and
-   limitations under the License.
--->
-<assembly>
-  <!--This 'all' id is not appended to the produced bundle because we do this:
-    http://maven.apache.org/plugins/maven-assembly-plugin/faq.html#required-classifiers
-  -->
-  <id>dist</id>
-  <formats>
-    <format>dir</format>
-    <format>tar.gz</format>
-  </formats>
-  <includeBaseDirectory>false</includeBaseDirectory>
-  <files>
-    <file>
-      <source>${project.build.directory}/${artifact.artifactId}-${artifact.version}.jar</source>
-      <outputDirectory>ambari-metrics-${project.version}/lib/ambari-metrics</outputDirectory>
-    </file>
-  </files>
-</assembly>

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/empty.xml
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/empty.xml b/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/empty.xml
deleted file mode 100644
index 35738b1..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/empty.xml
+++ /dev/null
@@ -1,21 +0,0 @@
-<!--
-  Licensed to the Apache Software Foundation (ASF) under one
-  or more contributor license agreements.  See the NOTICE file
-  distributed with this work for additional information
-  regarding copyright ownership.  The ASF licenses this file
-  to you under the Apache License, Version 2.0 (the
-  "License"); you may not use this file except in compliance
-  with the License.  You may obtain a copy of the License at
-  
-       http://www.apache.org/licenses/LICENSE-2.0
-  
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS,
-  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  See the License for the specific language governing permissions and
-  limitations under the License.
--->
-<assembly>
-    <id>empty</id>
-    <formats/>
-</assembly>

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-client.xml
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-client.xml b/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-client.xml
deleted file mode 100644
index beca5bd..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-client.xml
+++ /dev/null
@@ -1,62 +0,0 @@
-<?xml version='1.0'?>
-<!--
-  ~ Licensed to the Apache Software Foundation (ASF) under one
-  ~ or more contributor license agreements.  See the NOTICE file
-  ~ distributed with this work for additional information
-  ~ regarding copyright ownership.  The ASF licenses this file
-  ~ to you under the Apache License, Version 2.0 (the
-  ~ "License"); you may not use this file except in compliance
-  ~ with the License.  You may obtain a copy of the License at
-  ~
-  ~     http://www.apache.org/licenses/LICENSE-2.0
-  ~
-  ~ Unless required by applicable law or agreed to in writing, software
-  ~ distributed under the License is distributed on an "AS IS" BASIS,
-  ~ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  ~ See the License for the specific language governing permissions and
-  ~ limitations under the License.
-  -->
-
-<assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.0"
-  xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-  xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.0 http://maven.apache.org/xsd/assembly-1.1.0.xsd">
-  <id>client</id>
-  <!-- All the dependencies (unpacked) necessary to run phoenix from a single, stand-alone jar -->
-  <formats>
-    <format>jar</format>
-  </formats>
-  <includeBaseDirectory>false</includeBaseDirectory>
-
-  <componentDescriptors>
-    <componentDescriptor>src/main/assemblies/phoenix-components-minimal.xml</componentDescriptor>
-    <componentDescriptor>src/main/assemblies/phoenix-components-major-client.xml</componentDescriptor>
-  </componentDescriptors>
-
-  <dependencySets>
-    <dependencySet>
-      <!-- Unpack all the dependencies to class files, since java doesn't support
-        jar of jars for running -->
-      <unpack>true</unpack>
-      <!-- save these dependencies to the top-level -->
-      <outputDirectory>/</outputDirectory>
-      <includes>
-        <include>jline:jline</include>
-        <include>sqlline:sqlline</include>
-        <include>org.apache.hbase:hbase*</include>
-        <include>org.cloudera.htrace:htrace-core</include>
-        <include>io.netty:netty</include>
-        <include>commons-codec:commons-codec</include>
-      </includes>
-    </dependencySet>
-
-    <!-- Make sure we get all the components, not just the minimal client ones (e.g.
-      phoenix-flume, phoenix-pig, etc) -->
-    <dependencySet>
-      <outputDirectory>/</outputDirectory>
-      <unpack>true</unpack>
-      <includes>
-        <include>org.apache.phoenix:phoenix-*</include>
-      </includes>
-    </dependencySet>
-  </dependencySets>
-</assembly>

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-components-major-client.xml
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-components-major-client.xml b/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-components-major-client.xml
deleted file mode 100644
index 13692fe..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-components-major-client.xml
+++ /dev/null
@@ -1,53 +0,0 @@
-<?xml version='1.0'?>
-<!--
-  ~ Licensed to the Apache Software Foundation (ASF) under one
-  ~ or more contributor license agreements.  See the NOTICE file
-  ~ distributed with this work for additional information
-  ~ regarding copyright ownership.  The ASF licenses this file
-  ~ to you under the Apache License, Version 2.0 (the
-  ~ "License"); you may not use this file except in compliance
-  ~ with the License.  You may obtain a copy of the License at
-  ~
-  ~     http://www.apache.org/licenses/LICENSE-2.0
-  ~
-  ~ Unless required by applicable law or agreed to in writing, software
-  ~ distributed under the License is distributed on an "AS IS" BASIS,
-  ~ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  ~ See the License for the specific language governing permissions and
-  ~ limitations under the License.
-  -->
-
-<component>
-  <!-- Components that the client needs (except for HBase) -->
-  <dependencySets>
-    <dependencySet>
-      <!-- Unpack all the dependencies to class files, since java doesn't support
-        jar of jars for running -->
-      <unpack>true</unpack>
-      <!-- save these dependencies to the top-level -->
-      <outputDirectory>/</outputDirectory>
-      <!-- Maybe a blacklist is easier? -->
-      <includes>
-        <!-- We use a newer version of guava than HBase - this might be an issue? -->
-        <include>com.google.guava:guava</include>
-        <!-- HBase also pulls in these dependencies on its own, should we include-them? -->
-        <include>com.google.protobuf:protobuf-java</include>
-        <include>org.slf4j:slf4j-api</include>
-        <include>org.slf4j:slf4j-log4j12</include>
-        <include>org.apache.zookeeper:zookeeper</include>
-        <include>log4j:log4j</include>
-        <include>org.apache.hadoop:hadoop*</include>
-        <include>commons-configuration:commons-configuration</include>
-        <include>commons-io:commons-io</include>
-        <include>commons-logging:commons-logging</include>
-        <include>commons-lang:commons-lang</include>
-        <include>commons-cli:commons-cli</include>
-        <include>org.apache.commons:commons-csv</include>
-        <include>org.codehaus.jackson:jackson-mapper-asl</include>
-        <include>org.codehaus.jackson:jackson-core-asl</include>
-        <include>org.xerial.snappy:snappy-java</include>
-        <include>commons-collections:commons-collections</include>
-      </includes>
-    </dependencySet>
-  </dependencySets>
-</component>

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-components-minimal.xml
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-components-minimal.xml b/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-components-minimal.xml
deleted file mode 100644
index bf7de85..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-components-minimal.xml
+++ /dev/null
@@ -1,71 +0,0 @@
-<?xml version='1.0'?>
-<!--
-  ~ Licensed to the Apache Software Foundation (ASF) under one
-  ~ or more contributor license agreements.  See the NOTICE file
-  ~ distributed with this work for additional information
-  ~ regarding copyright ownership.  The ASF licenses this file
-  ~ to you under the Apache License, Version 2.0 (the
-  ~ "License"); you may not use this file except in compliance
-  ~ with the License.  You may obtain a copy of the License at
-  ~
-  ~     http://www.apache.org/licenses/LICENSE-2.0
-  ~
-  ~ Unless required by applicable law or agreed to in writing, software
-  ~ distributed under the License is distributed on an "AS IS" BASIS,
-  ~ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  ~ See the License for the specific language governing permissions and
-  ~ limitations under the License.
-  -->
-
-<component>
-  <!-- Just the basic components that Phoenix pulls in, that is not a transitive dependency from Hadoop/HBase/Pig -->
-  <dependencySets>
-    <dependencySet>
-      <!-- Unpack all the dependencies to class files, since java doesn't support
-        jar of jars for running -->
-      <unpack>true</unpack>
-      <!-- save these dependencies to the top-level -->
-      <outputDirectory>/</outputDirectory>
-      <!-- Just include the extra things that phoenix needs -->
-      <includes>
-        <include>org.antlr:antlr*</include>
-      </includes>
-    </dependencySet>
-
-    <dependencySet>
-      <outputDirectory>/</outputDirectory>
-      <unpack>true</unpack>
-      <includes>
-        <include>org.apache.phoenix:phoenix-*</include>
-      </includes>
-      <excludes>
-        <exclude>org.apache.phoenix:phoenix-flume</exclude>
-        <exclude>org.apache.phoenix:phoenix-pig</exclude>
-      </excludes>
-    </dependencySet>
-  </dependencySets>
-
-  <fileSets>
-    <fileSet>
-      <!--Get misc project files -->
-      <directory>${project.basedir}/..</directory>
-      <outputDirectory>/</outputDirectory>
-      <includes>
-        <include>*.txt*</include>
-        <include>*.md</include>
-        <include>NOTICE*</include>
-      </includes>
-      <excludes>
-        <exclude>build.txt</exclude>
-      </excludes>
-    </fileSet>
-    <fileSet>
-      <!--Get map-red-config properties files -->
-      <directory>${project.basedir}/../config</directory>
-      <outputDirectory>/</outputDirectory>
-      <includes>
-        <include>csv-bulk-load-config.properties</include>
-      </includes>
-    </fileSet>
-  </fileSets>
-</component>

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-server.xml
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-server.xml b/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-server.xml
deleted file mode 100644
index be8a516..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/phoenix-server.xml
+++ /dev/null
@@ -1,46 +0,0 @@
-<?xml version='1.0'?>
-<!--
-  ~ Licensed to the Apache Software Foundation (ASF) under one
-  ~ or more contributor license agreements.  See the NOTICE file
-  ~ distributed with this work for additional information
-  ~ regarding copyright ownership.  The ASF licenses this file
-  ~ to you under the Apache License, Version 2.0 (the
-  ~ "License"); you may not use this file except in compliance
-  ~ with the License.  You may obtain a copy of the License at
-  ~
-  ~     http://www.apache.org/licenses/LICENSE-2.0
-  ~
-  ~ Unless required by applicable law or agreed to in writing, software
-  ~ distributed under the License is distributed on an "AS IS" BASIS,
-  ~ WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  ~ See the License for the specific language governing permissions and
-  ~ limitations under the License.
-  -->
-
-<assembly xmlns="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.0"
-          xmlns:xsi="http://www.w3.org/2001/XMLSchema-instance"
-          xsi:schemaLocation="http://maven.apache.org/plugins/maven-assembly-plugin/assembly/1.1.0 http://maven.apache.org/xsd/assembly-1.1.0.xsd">
-  <!-- build the phoenix server side jar, that includes phoenix-hadoopX-compat, phoenix-hadoop-compat and antlr -->
-  <id>server</id>
-  <formats>
-    <format>jar</format>
-  </formats>
-  <includeBaseDirectory>false</includeBaseDirectory>
-  <dependencySets>
-    <dependencySet>
-      <outputDirectory>/</outputDirectory>
-      <unpack>true</unpack>
-      <includes>
-        <include>org.apache.phoenix:phoenix-core</include>
-        <include>org.apache.phoenix:phoenix-hadoop*</include>
-      </includes>
-    </dependencySet>
-    <dependencySet>
-      <unpack>true</unpack>
-      <outputDirectory>/</outputDirectory>
-      <includes>
-        <include>org.antlr:antlr*</include>
-      </includes>
-    </dependencySet>
-  </dependencySets>
-</assembly>

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/simulator.xml
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/simulator.xml b/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/simulator.xml
deleted file mode 100644
index 0f77976..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/assemblies/simulator.xml
+++ /dev/null
@@ -1,68 +0,0 @@
-<?xml version="1.0"?>
-<!--
-   Licensed to the Apache Software Foundation (ASF) under one or more
-   contributor license agreements.  See the NOTICE file distributed with
-   this work for additional information regarding copyright ownership.
-   The ASF licenses this file to You under the Apache License, Version 2.0
-   (the "License"); you may not use this file except in compliance with
-   the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-   Unless required by applicable law or agreed to in writing, software
-   distributed under the License is distributed on an "AS IS" BASIS,
-   WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-   See the License for the specific language governing permissions and
-   limitations under the License.
--->
-<assembly>
-  <id>dist</id>
-  <formats>
-    <format>dir</format>
-    <format>tar.gz</format>
-  </formats>
-  <includeBaseDirectory>false</includeBaseDirectory>
-  <files>
-    <file>
-      <source>${project.build.directory}/${artifact.artifactId}-simulator-${artifact.version}.jar</source>
-      <outputDirectory>ambari-metrics-${project.version}/lib/ambari-metrics</outputDirectory>
-    </file>
-  </files>
-  <fileSets>
-    <!--
-        Adds startup scripts to the root directory of zip package. The startup
-        scripts are located to src/main/scripts directory as stated by Maven
-        conventions.
-    -->
-    <fileSet>
-      <directory>${basedir}/src/main/resources/scripts</directory>
-      <outputDirectory>ambari-metrics-${project.version}/bin</outputDirectory>
-      <includes>
-        <include>*.sh</include>
-      </includes>
-      <fileMode>0755</fileMode>
-    </fileSet>
-    <!-- adds jar package to the root directory of zip package -->
-<!--    <fileSet>
-      <directory>${project.build.directory}</directory>
-      <outputDirectory></outputDirectory>
-      <includes>
-        <include>*.jar</include>
-      </includes>
-    </fileSet>-->
-  </fileSets>
-
-
-  <dependencySets>
-    <dependencySet>
-      <outputDirectory>ambari-metrics-${project.version}/lib/ambari-metrics</outputDirectory>
-<!--
-      <useProjectArtifact>false</useProjectArtifact>
--->
-      <unpack>false</unpack>
-      <scope>compile</scope>
-
-    </dependencySet>
-  </dependencySets>
-
-</assembly>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/conf/hbase-site-metrics-service.xml
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/conf/hbase-site-metrics-service.xml b/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/conf/hbase-site-metrics-service.xml
deleted file mode 100644
index dabef50..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/conf/hbase-site-metrics-service.xml
+++ /dev/null
@@ -1,80 +0,0 @@
-<?xml version="1.0"?>
-<?xml-stylesheet type="text/xsl" href="configuration.xsl"?>
-<!--
-/**
- *
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
--->
-<configuration>
-  <property>
-    <name>hbase.rootdir</name>
-    <value>file:///grid/0/hbase</value>
-  </property>
-  <property>
-    <name>hbase.tmp.dir</name>
-    <value>/grid/0/hbase-tmp</value>
-  </property>
-  <property>
-    <name>hbase.cluster.distributed</name>
-    <value>true</value>
-  </property>
-  <property>
-    <name>hbase.master.wait.on.regionservers.mintostart</name>
-    <value>1</value>
-  </property>
-  <property>
-    <name>hbase.zookeeper.quorum</name>
-    <value>localhost</value>
-  </property>
-  <property>
-    <name>phoenix.query.spoolThresholdBytes</name>
-    <value>12582912</value>
-  </property>
-  <property>
-    <name>hbase.zookeeper.property.dataDir</name>
-    <value>/grid/0/zookeeper</value>
-  </property>
-  <property>
-    <name>hbase.client.scanner.caching</name>
-    <value>10000</value>
-  </property>
-  <property>
-    <name>hfile.block.cache.size</name>
-    <value>0.3</value>
-  </property>
-  <property>
-    <name>hbase.regionserver.global.memstore.upperLimit</name>
-    <value>0.5</value>
-  </property>
-  <property>
-    <name>hbase.regionserver.global.memstore.lowerLimit</name>
-    <value>0.4</value>
-  </property>
-  <property>
-    <name>phoenix.groupby.maxCacheSize</name>
-    <value>307200000</value>
-  </property>
-  <property>
-    <name>hbase.hregion.memstore.block.multiplier</name>
-    <value>4</value>
-  </property>
-  <property>
-    <name>hbase.hstore.flusher.count</name>
-    <value>2</value>
-  </property>
-</configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/conf/simulator-log4j.xml
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/conf/simulator-log4j.xml b/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/conf/simulator-log4j.xml
deleted file mode 100644
index ac505f6..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/conf/simulator-log4j.xml
+++ /dev/null
@@ -1,45 +0,0 @@
-<?xml version="1.0"?>
-<!--
-  Licensed to the Apache Software Foundation (ASF) under one
-  or more contributor license agreements.  See the NOTICE file
-  distributed with this work for additional information
-  regarding copyright ownership.  The ASF licenses this file
-  to you under the Apache License, Version 2.0 (the
-  "License"); you may not use this file except in compliance
-  with the License.  You may obtain a copy of the License at
-
-       http://www.apache.org/licenses/LICENSE-2.0
-
-  Unless required by applicable law or agreed to in writing, software
-  distributed under the License is distributed on an "AS IS" BASIS,
-  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-  See the License for the specific language governing permissions and
-  limitations under the License.
--->
-<!DOCTYPE log4j:configuration SYSTEM "log4j.dtd">
-
-<log4j:configuration debug="false">
-
-    <appender name="console" class="org.apache.log4j.ConsoleAppender">
-        <param name="target" value="System.out" />
-        <param name="threshold" value="debug" />
-        <layout class="org.apache.log4j.PatternLayout">
-            <param name="ConversionPattern" value="%d{ISO8601} %-5p [%c{1}] - %m%n" />
-        </layout>
-    </appender>
-
-    <appender name="fileAppender" class="org.apache.log4j.RollingFileAppender">
-        <param name="Threshold" value="INFO" />
-        <param name="File" value="loadsimulator.log"/>
-        <layout class="org.apache.log4j.PatternLayout">
-            <param name="ConversionPattern" value="%d %-5p [%c{1}] %m %n" />
-        </layout>
-    </appender>
-
-    <root>
-        <priority value ="info" />
-        <!-- we may want async appender-->
-        <appender-ref ref="fileAppender" />
-    </root>
-
-</log4j:configuration>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/ApplicationHistoryClientService.java
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/ApplicationHistoryClientService.java b/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/ApplicationHistoryClientService.java
deleted file mode 100644
index e15198b..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/ApplicationHistoryClientService.java
+++ /dev/null
@@ -1,211 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.hadoop.yarn.server.applicationhistoryservice;
-
-import java.io.IOException;
-import java.net.InetSocketAddress;
-import java.util.ArrayList;
-
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-import org.apache.hadoop.classification.InterfaceAudience.Private;
-import org.apache.hadoop.conf.Configuration;
-import org.apache.hadoop.ipc.Server;
-import org.apache.hadoop.service.AbstractService;
-import org.apache.hadoop.yarn.api.ApplicationHistoryProtocol;
-import org.apache.hadoop.yarn.api.protocolrecords.CancelDelegationTokenRequest;
-import org.apache.hadoop.yarn.api.protocolrecords.CancelDelegationTokenResponse;
-import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptReportRequest;
-import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptReportResponse;
-import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptsRequest;
-import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationAttemptsResponse;
-import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportRequest;
-import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationReportResponse;
-import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsRequest;
-import org.apache.hadoop.yarn.api.protocolrecords.GetApplicationsResponse;
-import org.apache.hadoop.yarn.api.protocolrecords.GetContainerReportRequest;
-import org.apache.hadoop.yarn.api.protocolrecords.GetContainerReportResponse;
-import org.apache.hadoop.yarn.api.protocolrecords.GetContainersRequest;
-import org.apache.hadoop.yarn.api.protocolrecords.GetContainersResponse;
-import org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenRequest;
-import org.apache.hadoop.yarn.api.protocolrecords.GetDelegationTokenResponse;
-import org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenRequest;
-import org.apache.hadoop.yarn.api.protocolrecords.RenewDelegationTokenResponse;
-import org.apache.hadoop.yarn.api.records.ApplicationAttemptReport;
-import org.apache.hadoop.yarn.api.records.ApplicationId;
-import org.apache.hadoop.yarn.api.records.ApplicationReport;
-import org.apache.hadoop.yarn.api.records.ContainerReport;
-import org.apache.hadoop.yarn.conf.YarnConfiguration;
-import org.apache.hadoop.yarn.exceptions.ApplicationAttemptNotFoundException;
-import org.apache.hadoop.yarn.exceptions.ApplicationNotFoundException;
-import org.apache.hadoop.yarn.exceptions.ContainerNotFoundException;
-import org.apache.hadoop.yarn.exceptions.YarnException;
-import org.apache.hadoop.yarn.ipc.YarnRPC;
-
-public class ApplicationHistoryClientService extends AbstractService {
-  private static final Log LOG = LogFactory
-    .getLog(ApplicationHistoryClientService.class);
-  private ApplicationHistoryManager history;
-  private ApplicationHistoryProtocol protocolHandler;
-  private Server server;
-  private InetSocketAddress bindAddress;
-
-  public ApplicationHistoryClientService(ApplicationHistoryManager history) {
-    super("ApplicationHistoryClientService");
-    this.history = history;
-    this.protocolHandler = new ApplicationHSClientProtocolHandler();
-  }
-
-  protected void serviceStart() throws Exception {
-    Configuration conf = getConfig();
-    YarnRPC rpc = YarnRPC.create(conf);
-    InetSocketAddress address =
-        conf.getSocketAddr(YarnConfiguration.TIMELINE_SERVICE_ADDRESS,
-          YarnConfiguration.DEFAULT_TIMELINE_SERVICE_ADDRESS,
-          YarnConfiguration.DEFAULT_TIMELINE_SERVICE_PORT);
-
-    server =
-        rpc.getServer(ApplicationHistoryProtocol.class, protocolHandler,
-          address, conf, null, conf.getInt(
-            YarnConfiguration.TIMELINE_SERVICE_HANDLER_THREAD_COUNT,
-            YarnConfiguration.DEFAULT_TIMELINE_SERVICE_CLIENT_THREAD_COUNT));
-
-    server.start();
-    this.bindAddress =
-        conf.updateConnectAddr(YarnConfiguration.TIMELINE_SERVICE_ADDRESS,
-          server.getListenerAddress());
-    LOG.info("Instantiated ApplicationHistoryClientService at "
-        + this.bindAddress);
-
-    super.serviceStart();
-  }
-
-  @Override
-  protected void serviceStop() throws Exception {
-    if (server != null) {
-      server.stop();
-    }
-    super.serviceStop();
-  }
-
-  @Private
-  public ApplicationHistoryProtocol getClientHandler() {
-    return this.protocolHandler;
-  }
-
-  @Private
-  public InetSocketAddress getBindAddress() {
-    return this.bindAddress;
-  }
-
-  private class ApplicationHSClientProtocolHandler implements
-      ApplicationHistoryProtocol {
-
-    @Override
-    public CancelDelegationTokenResponse cancelDelegationToken(
-        CancelDelegationTokenRequest request) throws YarnException, IOException {
-      // TODO Auto-generated method stub
-      return null;
-    }
-
-    @Override
-    public GetApplicationAttemptReportResponse getApplicationAttemptReport(
-        GetApplicationAttemptReportRequest request) throws YarnException,
-        IOException {
-      try {
-        GetApplicationAttemptReportResponse response =
-            GetApplicationAttemptReportResponse.newInstance(history
-              .getApplicationAttempt(request.getApplicationAttemptId()));
-        return response;
-      } catch (IOException e) {
-        throw new ApplicationAttemptNotFoundException(e.getMessage());
-      }
-    }
-
-    @Override
-    public GetApplicationAttemptsResponse getApplicationAttempts(
-        GetApplicationAttemptsRequest request) throws YarnException,
-        IOException {
-      GetApplicationAttemptsResponse response =
-          GetApplicationAttemptsResponse
-            .newInstance(new ArrayList<ApplicationAttemptReport>(history
-              .getApplicationAttempts(request.getApplicationId()).values()));
-      return response;
-    }
-
-    @Override
-    public GetApplicationReportResponse getApplicationReport(
-        GetApplicationReportRequest request) throws YarnException, IOException {
-      try {
-        ApplicationId applicationId = request.getApplicationId();
-        GetApplicationReportResponse response =
-            GetApplicationReportResponse.newInstance(history
-              .getApplication(applicationId));
-        return response;
-      } catch (IOException e) {
-        throw new ApplicationNotFoundException(e.getMessage());
-      }
-    }
-
-    @Override
-    public GetApplicationsResponse getApplications(
-        GetApplicationsRequest request) throws YarnException, IOException {
-      GetApplicationsResponse response =
-          GetApplicationsResponse.newInstance(new ArrayList<ApplicationReport>(
-            history.getAllApplications().values()));
-      return response;
-    }
-
-    @Override
-    public GetContainerReportResponse getContainerReport(
-        GetContainerReportRequest request) throws YarnException, IOException {
-      try {
-        GetContainerReportResponse response =
-            GetContainerReportResponse.newInstance(history.getContainer(request
-              .getContainerId()));
-        return response;
-      } catch (IOException e) {
-        throw new ContainerNotFoundException(e.getMessage());
-      }
-    }
-
-    @Override
-    public GetContainersResponse getContainers(GetContainersRequest request)
-        throws YarnException, IOException {
-      GetContainersResponse response =
-          GetContainersResponse.newInstance(new ArrayList<ContainerReport>(
-            history.getContainers(request.getApplicationAttemptId()).values()));
-      return response;
-    }
-
-    @Override
-    public GetDelegationTokenResponse getDelegationToken(
-        GetDelegationTokenRequest request) throws YarnException, IOException {
-      // TODO Auto-generated method stub
-      return null;
-    }
-
-    @Override
-    public RenewDelegationTokenResponse renewDelegationToken(
-        RenewDelegationTokenRequest request) throws YarnException, IOException {
-      // TODO Auto-generated method stub
-      return null;
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/ba3d6926/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/ApplicationHistoryManager.java
----------------------------------------------------------------------
diff --git a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/ApplicationHistoryManager.java b/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/ApplicationHistoryManager.java
deleted file mode 100644
index db25d29..0000000
--- a/ambari-metrics/ambari-metrics-hadoop-timelineservice/src/main/java/org/apache/hadoop/yarn/server/applicationhistoryservice/ApplicationHistoryManager.java
+++ /dev/null
@@ -1,28 +0,0 @@
-/**
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-package org.apache.hadoop.yarn.server.applicationhistoryservice;
-
-import org.apache.hadoop.classification.InterfaceAudience;
-import org.apache.hadoop.classification.InterfaceStability;
-import org.apache.hadoop.yarn.server.api.ApplicationContext;
-
-@InterfaceAudience.Public
-@InterfaceStability.Unstable
-public interface ApplicationHistoryManager extends ApplicationContext {
-}