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 2014/05/14 16:02:19 UTC

[11/15] AMBARI-5747 Remove facter-1.6.10, Ruby, Puppet dependencies from pom.xml and src (dsen)

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/master-conn.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/master-conn.pp b/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/master-conn.pp
deleted file mode 100644
index f9c5d36..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/master-conn.pp
+++ /dev/null
@@ -1,24 +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.
-#
-#
-class hdp-hbase::master-conn($hbase_master_hosts)
-{
-  Hdp-Hbase::Configfile<||>{hbase_master_hosts => $hbase_master_hosts}
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/master.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/master.pp b/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/master.pp
deleted file mode 100644
index c16b1af..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/master.pp
+++ /dev/null
@@ -1,66 +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.
-#
-#
-class hdp-hbase::master(
-  $service_state = $hdp::params::cluster_service_state,
-  $opts = {}
-) inherits hdp-hbase::params 
-{
-
-  if ($service_state == 'no_op') {
-  } elsif ($service_state in ['running','stopped','installed_and_configured','uninstalled']) {    
-    $hdp::params::service_exists['hdp-hbase::master'] = true
-
-    if ( ($service_state == 'installed_and_configured') and
-         ($security_enabled == true) and ($kerberos_install_type == "AMBARI_SET_KERBEROS") ) {
-       $masterHost = $kerberos_adminclient_host[0]
-       hdp::download_keytab { 'hbase_master_service_keytab' :
-         masterhost => $masterHost,
-         keytabdst => "${$keytab_path}/hm.service.keytab",
-         keytabfile => 'hm.service.keytab',
-         owner => $hdp::params::hbase_user
-       }
-    }
-  
-    #adds package, users, directories, and common configs
-    class { 'hdp-hbase': 
-      type          => 'master',
-      service_state => $service_state
-    }
-
-    Hdp-hbase::Configfile<||>{hbase_master_hosts => $hdp::params::host_address}
-  
-    hdp-hbase::service{ 'master':
-      ensure => $service_state
-    }
-
-    #top level does not need anchors
-    Class['hdp-hbase'] -> Hdp-hbase::Service['master'] 
-    } else {
-    hdp_fail("TODO not implemented yet: service_state = ${service_state}")
-  }
-}
-
-#assumes that master and regionserver will not be on same machine
-class hdp-hbase::master::enable-ganglia()
-{
-  Hdp-hbase::Configfile<|title  == $metric-prop-file-name |>{template_tag => 'GANGLIA-MASTER'}
-}
-

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/params.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/params.pp b/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/params.pp
deleted file mode 100644
index 4eb5ad0..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/params.pp
+++ /dev/null
@@ -1,110 +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.
-#
-#
-class hdp-hbase::params() inherits hdp::params 
-{
-  
-  ####### users
-  $hbase_user = $hdp::params::hbase_user
-  
-  ### hbase-env
-  $hadoop_conf_dir = hdp_default("hadoop_conf_dir")
-  $conf_dir = $hdp::params::hbase_conf_dir
-
-  $hbase_log_dir = hdp_default("hbase_log_dir","/var/log/hbase")
-
-  $hbase_master_heapsize = hdp_default("hbase_master_heapsize","1000m")
-
-  $hbase_pid_dir = hdp_default("hbase_pid_dir","/var/run/hbase")
-
-  $hbase_regionserver_heapsize = hdp_default("hbase_regionserver_heapsize","1000m")
-
-  $hbase_regionserver_xmn_size = hdp_calc_xmn_from_xms("$hbase_regionserver_heapsize","0.2","512")
-
-  ### hbase-site.xml
-  $hbase_tmp_dir = hdp_default("hbase-site/hbase.tmp.dir","$hbase_log_dir")
-
-
-  #TODO: check if any of these 'hdfs' vars need to be euated with vars in hdp-hadoop
-  $hdfs_enable_shortcircuit_read = hdp_default("hbase-site/hdfs.enable.shortcircuit.read",true)
-
-  $hdfs_enable_shortcircuit_skipchecksum = hdp_default("hbase-site/hdfs.enable.shortcircuit.skipchecksum",false)
-
-  $hdfs_support_append = hdp_default("hbase-site/hdfs.support.append",true)
-
-  $hfile_blockcache_size = hdp_default("hbase-site/hfile.blockcache.size","0.25")
-
-  $hfile_max_keyvalue_size = hdp_default("hbase-site/hfile.max.keyvalue.size",10485760)
-
-  $zookeeper_sessiontimeout = hdp_default("hbase-site/zookeeper.sessiontimeout",60000)
-
-  $client_scannercaching = hdp_default("hbase-site/client.scannercaching",100)
-
-  $hstore_blockingstorefiles = hdp_default("hbase-site/hstore.blockingstorefiles",7)
-
-  $hstore_compactionthreshold = hdp_default("hbase-site/hstore.compactionthreshold",3)
-
-  $hstorefile_maxsize = hdp_default("hbase-site/hstorefile.maxsize",1073741824)
-
-  $hregion_blockmultiplier = hdp_default("hbase-site/hregion.blockmultiplier",2)
-
-  $hregion_memstoreflushsize = hdp_default("hbase-site/hregion.memstoreflushsize",134217728)
-
-  $regionserver_handlers = hdp_default("hbase-site/regionserver.handlers", 30)
-
-  $hregion_majorcompaction = hdp_default("hbase-site/hregion.majorcompaction", 86400000)
-
-  $preloaded_mastercoprocessor_classes = hdp_default("hbase-site/preloaded.mastercoprocessor.classes")
-
-  $preloaded_regioncoprocessor_classes = hdp_default("hbase-site/preloaded.regioncoprocessor.classes")
-
-  $regionserver_memstore_lab = hdp_default("hbase-site/regionserver.memstore.lab",true)
-
-  $regionserver_memstore_lowerlimit = hdp_default("hbase-site/regionserver.memstore.lowerlimit","0.35")
-
-  $regionserver_memstore_upperlimit = hdp_default("hbase-site/regionserver.memstore.upperlimit","0.4")
-
-  $keytab_path = hdp_default("keytab_path","/etc/security/keytabs")
-  $hbase_client_jaas_config_file = hdp_default("hbase_client_jaas_config_file", "${conf_dir}/hbase_client_jaas.conf")
-  $hbase_master_jaas_config_file = hdp_default("hbase_master_jaas_config_file", "${conf_dir}/hbase_master_jaas.conf")
-  $hbase_regionserver_jaas_config_file = hdp_default("hbase_regionserver_jaas_config_file", "${conf_dir}/hbase_regionserver_jaas.conf")
-
-  $hbase_master_keytab_path = hdp_default("hbase-site/hbase.master.keytab.file", "${keytab_path}/hbase.service.keytab")
-  $hbase_master_principal = hdp_default("hbase-site/hbase.master.kerberos.principal", "hbase/_HOST@${kerberos_domain}")
-  $hbase_regionserver_keytab_path = hdp_default("hbase-site/hbase.regionserver.keytab.file", "${keytab_path}/hbase.service.keytab")
-  $hbase_regionserver_principal = hdp_default("hbase-site/hbase.regionserver.kerberos.principal", "hbase/_HOST@${kerberos_domain}")
-
-  $hbase_primary_name = hdp_default("hbase_primary_name", "hbase")
-  $hostname = $hdp::params::hostname
-  if ($use_hostname_in_principal) {
-    $hbase_master_jaas_princ = "${hbase_master_primary_name}/${hostname}@${kerberos_domain}"
-    $hbase_regionserver_jaas_princ = "${hbase_regionserver_primary_name}/${hostname}@${kerberos_domain}"
-  } else {
-    $hbase_master_jaas_princ = "${hbase_master_principal_name}@${kerberos_domain}"
-    $hbase_regionserver_jaas_princ = "${hbase_regionserver_primary_name}@${kerberos_domain}"
-  }
-
-  if (hdp_get_major_stack_version($hdp::params::stack_version) >= 2) {
-    $metric-prop-file-name = "hadoop-metrics2-hbase.properties"
-  } else {
-    $metric-prop-file-name = "hadoop-metrics.properties"
-  }
-  $smokeuser_permissions = hdp_default("smokeuser_permissions", "RWXCA")
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/regionserver.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/regionserver.pp b/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/regionserver.pp
deleted file mode 100644
index 434f4f1..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/regionserver.pp
+++ /dev/null
@@ -1,73 +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.
-#
-#
-class hdp-hbase::regionserver(
-  $service_state = $hdp::params::cluster_service_state,
-  $opts = {}
-) inherits hdp-hbase::params
-{
-
-  if ($service_state == 'no_op') {
-  } elsif ($service_state in ['running','stopped','installed_and_configured','uninstalled']) {    
-    $hdp::params::service_exists['hdp-hbase::regionserver'] = true       
-
-    if ( ($service_state == 'installed_and_configured') and
-         ($security_enabled == true) and ($kerberos_install_type == "AMBARI_SET_KERBEROS") ) {
-       $masterHost = $kerberos_adminclient_host[0]
-       hdp::download_keytab { 'hbase_rs_service_keytab' :
-         masterhost => $masterHost,
-         keytabdst => "${$keytab_path}/rs.service.keytab",
-         keytabfile => 'rs.service.keytab',
-         owner => $hdp::params::hbase_user
-       }
-    }
-
-    if ($hdp::params::service_exists['hdp-hbase::master'] != true) {
-      #adds package, users, directories, and common configs
-      class { 'hdp-hbase': 
-        type          => 'regionserver',
-        service_state => $service_state
-      } 
-      $create_pid_dir = true
-      $create_conf_dir = true
-    } else {
-      $create_pid_dir = false
-      $create_conf_dir = false
-    }
-
-
-    hdp-hbase::service{ 'regionserver':
-      ensure         => $service_state,
-      create_pid_dir => $create_pid_dir,
-      create_conf_dir => $create_conf_dir
-    }
-
-    #top level does not need anchors
-    Class['hdp-hbase'] ->  Hdp-hbase::Service['regionserver']
-  } else {
-    hdp_fail("TODO not implemented yet: service_state = ${service_state}")
-  }
-}
-
-#assumes that master and regionserver will not be on same machine
-class hdp-hbase::regionserver::enable-ganglia()
-{
-  Hdp-hbase::Configfile<|title  == $metric-prop-file-name |>{template_tag => 'GANGLIA-RS'}
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/service.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/service.pp b/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/service.pp
deleted file mode 100644
index 8ab9645..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/service.pp
+++ /dev/null
@@ -1,82 +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 hdp-hbase::service(
-  $ensure = 'running',
-  $create_pid_dir = true,
-  $create_conf_dir = true,
-  $initial_wait = undef)
-{
-  include hdp-hbase::params
-
-  $role = $name
-  $user = $hdp-hbase::params::hbase_user
-
-  $conf_dir = $hdp::params::hbase_conf_dir
-  $hbase_daemon = $hdp::params::hbase_daemon_script
-  $cmd = "$hbase_daemon --config ${conf_dir}"
-  $pid_dir = $hdp-hbase::params::hbase_pid_dir
-  $pid_file = "${pid_dir}/hbase-hbase-${role}.pid"
-  $hbase_log_dir = $hdp-hbase::params::hbase_log_dir
-  $hbase_tmp_dir = $hdp-hbase::params::hbase_tmp_dir
-
-  if ($ensure == 'running') {
-    $daemon_cmd = "su - ${user} -c  '${cmd} start ${role}'"
-    $no_op_test = "ls ${pid_file} >/dev/null 2>&1 && ps `cat ${pid_file}` >/dev/null 2>&1"
-  } elsif ($ensure == 'stopped') {
-    $daemon_cmd = "su - ${user} -c  '${cmd} stop ${role}' && rm -f ${pid_file}"
-    $no_op_test = undef
-  } else {
-    $daemon_cmd = undef
-  }
-
-  $tag = "hbase_service-${name}"
-  
-  if ($create_pid_dir == true) {
-    hdp::directory_recursive_create { $pid_dir: 
-      owner => $user,
-      tag   => $tag,
-      service_state => $ensure,
-      force => true
-    }
-  }
-  if ($create_conf_dir == true) {
-   # To avoid duplicate resource definitions
-    $hbase_conf_dirs = hdp_set_from_comma_list("${hbase_tmp_dir},${hbase_log_dir}")
-
-    hdp::directory_recursive_create_ignore_failure { $hbase_conf_dirs:
-      owner => $user,
-      context_tag => 'hbase_service',
-      service_state => $ensure,
-      force => true
-    }
-  }
-
-  if ($daemon_cmd != undef) { 
-    hdp::exec { $daemon_cmd:
-      command      => $daemon_cmd,
-      unless       => $no_op_test,
-      initial_wait => $initial_wait
-    }
-    anchor{"hdp-hbase::service::${name}::begin":} -> Hdp::Directory_recursive_create<|tag == $tag|> -> Hdp::Exec[$daemon_cmd] -> anchor{"hdp-hbase::service::${name}::end":}
-  } else {
-    anchor{"hdp-hbase::service::${name}::begin":} -> Hdp::Directory_recursive_create<|tag == $tag|> -> anchor{"hdp-hbase::service::${name}::end":}  
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/zk-conn.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/zk-conn.pp b/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/zk-conn.pp
deleted file mode 100644
index 6c67cd4..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/zk-conn.pp
+++ /dev/null
@@ -1,26 +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.
-#
-#
-class hdp-hbase::zk-conn(
- $zookeeper_hosts
-)
-{
-  Hdp::Configfile<||>{zookeeper_hosts => $zookeeper_hosts}
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties-GANGLIA-MASTER.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties-GANGLIA-MASTER.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties-GANGLIA-MASTER.erb
deleted file mode 100644
index f3988d9..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties-GANGLIA-MASTER.erb
+++ /dev/null
@@ -1,50 +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.
-
-# See http://wiki.apache.org/hadoop/GangliaMetrics
-#
-# Make sure you know whether you are using ganglia 3.0 or 3.1.
-# If 3.1, you will have to patch your hadoop instance with HADOOP-4675
-# And, yes, this file is named hadoop-metrics.properties rather than
-# hbase-metrics.properties because we're leveraging the hadoop metrics
-# package and hadoop-metrics.properties is an hardcoded-name, at least
-# for the moment.
-#
-# See also http://hadoop.apache.org/hbase/docs/current/metrics.html
-
-# HBase-specific configuration to reset long-running stats (e.g. compactions)
-# If this variable is left out, then the default is no expiration.
-hbase.extendedperiod = 3600
-
-# Configuration of the "hbase" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# hbase.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-hbase.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-hbase.period=10
-hbase.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8663
-
-# Configuration of the "jvm" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# jvm.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-jvm.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-jvm.period=10
-jvm.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8663
-
-# Configuration of the "rpc" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# rpc.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-rpc.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-rpc.period=10
-rpc.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8663

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties-GANGLIA-RS.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties-GANGLIA-RS.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties-GANGLIA-RS.erb
deleted file mode 100644
index 386376d..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties-GANGLIA-RS.erb
+++ /dev/null
@@ -1,50 +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.
-
-# See http://wiki.apache.org/hadoop/GangliaMetrics
-#
-# Make sure you know whether you are using ganglia 3.0 or 3.1.
-# If 3.1, you will have to patch your hadoop instance with HADOOP-4675
-# And, yes, this file is named hadoop-metrics.properties rather than
-# hbase-metrics.properties because we're leveraging the hadoop metrics
-# package and hadoop-metrics.properties is an hardcoded-name, at least
-# for the moment.
-#
-# See also http://hadoop.apache.org/hbase/docs/current/metrics.html
-
-# HBase-specific configuration to reset long-running stats (e.g. compactions)
-# If this variable is left out, then the default is no expiration.
-hbase.extendedperiod = 3600
-
-# Configuration of the "hbase" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# hbase.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-hbase.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-hbase.period=10
-hbase.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8660
-
-# Configuration of the "jvm" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# jvm.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-jvm.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-jvm.period=10
-jvm.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8660
-
-# Configuration of the "rpc" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# rpc.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-rpc.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-rpc.period=10
-rpc.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8660

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties.erb
deleted file mode 100644
index f3988d9..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics.properties.erb
+++ /dev/null
@@ -1,50 +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.
-
-# See http://wiki.apache.org/hadoop/GangliaMetrics
-#
-# Make sure you know whether you are using ganglia 3.0 or 3.1.
-# If 3.1, you will have to patch your hadoop instance with HADOOP-4675
-# And, yes, this file is named hadoop-metrics.properties rather than
-# hbase-metrics.properties because we're leveraging the hadoop metrics
-# package and hadoop-metrics.properties is an hardcoded-name, at least
-# for the moment.
-#
-# See also http://hadoop.apache.org/hbase/docs/current/metrics.html
-
-# HBase-specific configuration to reset long-running stats (e.g. compactions)
-# If this variable is left out, then the default is no expiration.
-hbase.extendedperiod = 3600
-
-# Configuration of the "hbase" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# hbase.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-hbase.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-hbase.period=10
-hbase.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8663
-
-# Configuration of the "jvm" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# jvm.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-jvm.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-jvm.period=10
-jvm.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8663
-
-# Configuration of the "rpc" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# rpc.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-rpc.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-rpc.period=10
-rpc.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8663

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics2-hbase.properties-GANGLIA-MASTER.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics2-hbase.properties-GANGLIA-MASTER.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics2-hbase.properties-GANGLIA-MASTER.erb
deleted file mode 100644
index 3a05d5e..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics2-hbase.properties-GANGLIA-MASTER.erb
+++ /dev/null
@@ -1,62 +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.
-
-# See http://wiki.apache.org/hadoop/GangliaMetrics
-#
-# Make sure you know whether you are using ganglia 3.0 or 3.1.
-# If 3.1, you will have to patch your hadoop instance with HADOOP-4675
-# And, yes, this file is named hadoop-metrics.properties rather than
-# hbase-metrics.properties because we're leveraging the hadoop metrics
-# package and hadoop-metrics.properties is an hardcoded-name, at least
-# for the moment.
-#
-# See also http://hadoop.apache.org/hbase/docs/current/metrics.html
-
-# HBase-specific configuration to reset long-running stats (e.g. compactions)
-# If this variable is left out, then the default is no expiration.
-hbase.extendedperiod = 3600
-
-# Configuration of the "hbase" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# hbase.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-hbase.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-hbase.period=10
-hbase.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8663
-
-# Configuration of the "jvm" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# jvm.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-jvm.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-jvm.period=10
-jvm.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8663
-
-# Configuration of the "rpc" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# rpc.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-rpc.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-rpc.period=10
-rpc.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8663
-
-#Ganglia following hadoop example
-hbase.sink.ganglia.class=org.apache.hadoop.metrics2.sink.ganglia.GangliaSink31
-hbase.sink.ganglia.period=10
-
-# default for supportsparse is false
-*.sink.ganglia.supportsparse=true
-
-.sink.ganglia.slope=jvm.metrics.gcCount=zero,jvm.metrics.memHeapUsedM=both
-.sink.ganglia.dmax=jvm.metrics.threadsBlocked=70,jvm.metrics.memHeapUsedM=40
-
-hbase.sink.ganglia.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8663

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics2-hbase.properties-GANGLIA-RS.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics2-hbase.properties-GANGLIA-RS.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics2-hbase.properties-GANGLIA-RS.erb
deleted file mode 100644
index 2d74c16..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hadoop-metrics2-hbase.properties-GANGLIA-RS.erb
+++ /dev/null
@@ -1,62 +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.
-
-# See http://wiki.apache.org/hadoop/GangliaMetrics
-#
-# Make sure you know whether you are using ganglia 3.0 or 3.1.
-# If 3.1, you will have to patch your hadoop instance with HADOOP-4675
-# And, yes, this file is named hadoop-metrics.properties rather than
-# hbase-metrics.properties because we're leveraging the hadoop metrics
-# package and hadoop-metrics.properties is an hardcoded-name, at least
-# for the moment.
-#
-# See also http://hadoop.apache.org/hbase/docs/current/metrics.html
-
-# HBase-specific configuration to reset long-running stats (e.g. compactions)
-# If this variable is left out, then the default is no expiration.
-hbase.extendedperiod = 3600
-
-# Configuration of the "hbase" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# hbase.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-hbase.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-hbase.period=10
-hbase.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8660
-
-# Configuration of the "jvm" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# jvm.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-jvm.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-jvm.period=10
-jvm.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8660
-
-# Configuration of the "rpc" context for ganglia
-# Pick one: Ganglia 3.0 (former) or Ganglia 3.1 (latter)
-# rpc.class=org.apache.hadoop.metrics.ganglia.GangliaContext
-rpc.class=org.apache.hadoop.metrics.ganglia.GangliaContext31
-rpc.period=10
-rpc.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8660
-
-#Ganglia following hadoop example
-hbase.sink.ganglia.class=org.apache.hadoop.metrics2.sink.ganglia.GangliaSink31
-hbase.sink.ganglia.period=10
-
-# default for supportsparse is false
-*.sink.ganglia.supportsparse=true
-
-.sink.ganglia.slope=jvm.metrics.gcCount=zero,jvm.metrics.memHeapUsedM=both
-.sink.ganglia.dmax=jvm.metrics.threadsBlocked=70,jvm.metrics.memHeapUsedM=40
-
-hbase.sink.ganglia.servers=<%=scope.function_hdp_host("ganglia_server_host")%>:8660

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase-env.sh.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase-env.sh.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase-env.sh.erb
deleted file mode 100644
index ea19d23..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase-env.sh.erb
+++ /dev/null
@@ -1,83 +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.
-
-# The java implementation to use. Java 1.6 required.
-export JAVA_HOME=<%=scope.function_hdp_template_var("::hdp::params::java64_home")%>
-
-# HBase Configuration directory
-export HBASE_CONF_DIR=${HBASE_CONF_DIR:-<%=scope.function_hdp_template_var("hbase_conf_dir")%>}
-
-# Extra Java CLASSPATH elements. Optional.
-export HBASE_CLASSPATH=${HBASE_CLASSPATH}
-
-# The maximum amount of heap to use, in MB. Default is 1000.
-# export HBASE_HEAPSIZE=1000
-
-# Extra Java runtime options.
-# Below are what we set by default. May only work with SUN JVM.
-# For more on why as well as other possible settings,
-# see http://wiki.apache.org/hadoop/PerformanceTuning
-export HBASE_OPTS="-XX:+UseConcMarkSweepGC -XX:ErrorFile=<%=scope.function_hdp_template_var("hbase_log_dir")%>/hs_err_pid%p.log"
-export SERVER_GC_OPTS="-verbose:gc -XX:+PrintGCDetails -XX:+PrintGCDateStamps -Xloggc:<%=scope.function_hdp_template_var("hbase_log_dir")%>/gc.log-`date +'%Y%m%d%H%M'`"
-# Uncomment below to enable java garbage collection logging.
-# export HBASE_OPTS="$HBASE_OPTS -verbose:gc -XX:+PrintGCDetails -XX:+PrintGCDateStamps -Xloggc:$HBASE_HOME/logs/gc-hbase.log"
-
-# Uncomment and adjust to enable JMX exporting
-# See jmxremote.password and jmxremote.access in $JRE_HOME/lib/management to configure remote password access.
-# More details at: http://java.sun.com/javase/6/docs/technotes/guides/management/agent.html
-#
-# export HBASE_JMX_BASE="-Dcom.sun.management.jmxremote.ssl=false -Dcom.sun.management.jmxremote.authenticate=false"
-export HBASE_MASTER_OPTS="-Xmx<%=scope.function_hdp_template_var("hbase_master_heapsize")%>"
-export HBASE_REGIONSERVER_OPTS="-Xmn<%=scope.function_hdp_template_var("hbase_regionserver_xmn_size")%> -XX:CMSInitiatingOccupancyFraction=70  -Xms<%=scope.function_hdp_template_var("hbase_regionserver_heapsize")%> -Xmx<%=scope.function_hdp_template_var("hbase_regionserver_heapsize")%>"
-# export HBASE_THRIFT_OPTS="$HBASE_JMX_BASE -Dcom.sun.management.jmxremote.port=10103"
-# export HBASE_ZOOKEEPER_OPTS="$HBASE_JMX_BASE -Dcom.sun.management.jmxremote.port=10104"
-
-# File naming hosts on which HRegionServers will run. $HBASE_HOME/conf/regionservers by default.
-export HBASE_REGIONSERVERS=${HBASE_CONF_DIR}/regionservers
-
-# Extra ssh options. Empty by default.
-# export HBASE_SSH_OPTS="-o ConnectTimeout=1 -o SendEnv=HBASE_CONF_DIR"
-
-# Where log files are stored. $HBASE_HOME/logs by default.
-export HBASE_LOG_DIR=<%=scope.function_hdp_template_var("hbase_log_dir")%>
-
-# A string representing this instance of hbase. $USER by default.
-# export HBASE_IDENT_STRING=$USER
-
-# The scheduling priority for daemon processes. See 'man nice'.
-# export HBASE_NICENESS=10
-
-# The directory where pid files are stored. /tmp by default.
-export HBASE_PID_DIR=<%=scope.function_hdp_template_var("hbase_pid_dir")%>
-
-# Seconds to sleep between slave commands. Unset by default. This
-# can be useful in large clusters, where, e.g., slave rsyncs can
-# otherwise arrive faster than the master can service them.
-# export HBASE_SLAVE_SLEEP=0.1
-
-# Tell HBase whether it should manage it's own instance of Zookeeper or not.
-export HBASE_MANAGES_ZK=false
-
-
-<% if scope.function_hdp_template_var("::hdp::params::security_enabled") == true %>
-export HBASE_OPTS="$HBASE_OPTS -Djava.security.auth.login.config=<%=scope.function_hdp_template_var("::hdp-hbase::params::hbase_client_jaas_config_file")%>"
-export HBASE_MASTER_OPTS="$HBASE_MASTER_OPTS -Djava.security.auth.login.config=<%=scope.function_hdp_template_var("::hdp-hbase::params::hbase_master_jaas_config_file")%>"
-export HBASE_REGIONSERVER_OPTS="$HBASE_REGIONSERVER_OPTS -Djava.security.auth.login.config=<%=scope.function_hdp_template_var("::hdp-hbase::params::hbase_regionserver_jaas_config_file")%>"
-<% end %>

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase-smoke.sh.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase-smoke.sh.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase-smoke.sh.erb
deleted file mode 100644
index 827717b..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase-smoke.sh.erb
+++ /dev/null
@@ -1,26 +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.
-#
-#
-disable 'ambarismoketest'
-drop 'ambarismoketest'
-create 'ambarismoketest','family'
-put 'ambarismoketest','row01','family:col01','<%=scope.function_hdp_template_var("::hdp-hbase::hbase::service_check::serviceCheckData")%>'
-scan 'ambarismoketest'
-exit
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_client_jaas.conf.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_client_jaas.conf.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_client_jaas.conf.erb
deleted file mode 100644
index 696718e..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_client_jaas.conf.erb
+++ /dev/null
@@ -1,5 +0,0 @@
-Client {
-com.sun.security.auth.module.Krb5LoginModule required
-useKeyTab=false
-useTicketCache=true;
-};

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_grant_permissions.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_grant_permissions.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_grant_permissions.erb
deleted file mode 100644
index e8f3d1d..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_grant_permissions.erb
+++ /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.
-#
-#
-grant '<%=scope.function_hdp_template_var("::hdp::params::smokeuser")%>', '<%=scope.function_hdp_template_var("::hdp-hbase::params::smokeuser_permissions")%>'
-exit
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_master_jaas.conf.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_master_jaas.conf.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_master_jaas.conf.erb
deleted file mode 100644
index 68bf733..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_master_jaas.conf.erb
+++ /dev/null
@@ -1,8 +0,0 @@
-Client {
-com.sun.security.auth.module.Krb5LoginModule required
-useKeyTab=true
-storeKey=true
-useTicketCache=false
-keyTab="<%=scope.function_hdp_template_var("::hdp-hbase::params::hbase_master_keytab_path")%>"
-principal="<%=scope.function_hdp_template_var("::hdp-hbase::params::hbase_master_jaas_princ")%>";
-};

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_regionserver_jaas.conf.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_regionserver_jaas.conf.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_regionserver_jaas.conf.erb
deleted file mode 100644
index 87838ca..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/hbase_regionserver_jaas.conf.erb
+++ /dev/null
@@ -1,8 +0,0 @@
-Client {
-com.sun.security.auth.module.Krb5LoginModule required
-useKeyTab=true
-storeKey=true
-useTicketCache=false
-keyTab="<%=scope.function_hdp_template_var("::hdp-hbase::params::hbase_regionserver_keytab_path")%>"
-principal="<%=scope.function_hdp_template_var("::hdp-hbase::params::hbase_regionserver_jaas_princ")%>";
-};

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/regionservers.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/regionservers.erb b/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/regionservers.erb
deleted file mode 100644
index 159a2f6..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hbase/templates/regionservers.erb
+++ /dev/null
@@ -1,3 +0,0 @@
-<%h=scope.function_hdp_host("hbase_rs_hosts"); (h.kind_of?(Array) ? h : []).each do |host|-%>
-<%= host %>
-<%end-%>

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hcat/files/hcatSmoke.sh
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hcat/files/hcatSmoke.sh b/ambari-agent/src/main/puppet/modules/hdp-hcat/files/hcatSmoke.sh
deleted file mode 100644
index 695d56a..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hcat/files/hcatSmoke.sh
+++ /dev/null
@@ -1,35 +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.
-#
-#
-export tablename=$1
-
-case "$2" in
-
-prepare)
-  hcat -e "show tables"
-  hcat -e "drop table IF EXISTS ${tablename}"
-  hcat -e "create table ${tablename} ( id INT, name string ) stored as rcfile ;"
-;;
-
-cleanup)
-  hcat -e "drop table IF EXISTS ${tablename}"
-;;
-
-esac
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hcat/files/pigSmoke.sh
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hcat/files/pigSmoke.sh b/ambari-agent/src/main/puppet/modules/hdp-hcat/files/pigSmoke.sh
deleted file mode 100644
index 2e90ac0..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hcat/files/pigSmoke.sh
+++ /dev/null
@@ -1,18 +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
-
-A = load 'passwd' using PigStorage(':');
-B = foreach A generate \$0 as id;
-store B into 'pigsmoke.out';

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/hcat/service_check.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/hcat/service_check.pp b/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/hcat/service_check.pp
deleted file mode 100644
index f2aabb0..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/hcat/service_check.pp
+++ /dev/null
@@ -1,73 +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.
-#
-#
-class hdp-hcat::hcat::service_check() 
-{
-  include hdp-hcat::params
-  $unique = hdp_unique_id_and_date()
-  $smoke_test_user = $hdp::params::smokeuser
-  $output_file = "/apps/hive/warehouse/hcatsmoke${unique}"
-  $security_enabled=$hdp::params::security_enabled
-  $smoke_user_keytab = $hdp::params::smokeuser_keytab
-
-  if ($security_enabled == true) {
-    $smoke_user_kinitcmd="${hdp::params::kinit_path_local} -kt ${smoke_user_keytab} ${smoke_test_user}; "
-  } else {
-    $smoke_user_kinitcmd=""
-  }
-
-  $test_cmd = "fs -test -e ${output_file}" 
-  
-  anchor { 'hdp-hcat::hcat::service_check::begin':}
-
-  file { '/tmp/hcatSmoke.sh':
-    ensure => present,
-    source => "puppet:///modules/hdp-hcat/hcatSmoke.sh",
-    mode => '0755',
-  }
-
-  exec { 'hcatSmoke.sh prepare':
-    command   => "su - ${smoke_test_user} -c '${smoke_user_kinitcmd}sh /tmp/hcatSmoke.sh hcatsmoke${unique} prepare'",
-    tries     => 3,
-    try_sleep => 5,
-    require   => File['/tmp/hcatSmoke.sh'],
-    path      => '/usr/sbin:/sbin:/usr/local/bin:/bin:/usr/bin',
-    notify    => Hdp-hadoop::Exec-hadoop['hcat::service_check::test'],
-    logoutput => "true"
-  }
-
-  hdp-hadoop::exec-hadoop { 'hcat::service_check::test':
-    command     => $test_cmd,
-    refreshonly => true,
-    require     => Exec['hcatSmoke.sh prepare'],
-  }
-
-  exec { 'hcatSmoke.sh cleanup':
-    command   => "su - ${smoke_test_user} -c '${smoke_user_kinitcmd}sh /tmp/hcatSmoke.sh hcatsmoke${unique} cleanup'",
-    tries     => 3,
-    try_sleep => 5,
-    path      => '/usr/sbin:/sbin:/usr/local/bin:/bin:/usr/bin',
-    require   => Hdp-hadoop::Exec-hadoop['hcat::service_check::test'],
-    before    => Anchor['hdp-hcat::hcat::service_check::end'],
-    logoutput => "true"
-  }
-  
-  anchor{ 'hdp-hcat::hcat::service_check::end':}
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/init.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/init.pp b/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/init.pp
deleted file mode 100644
index 1fb0ced..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/init.pp
+++ /dev/null
@@ -1,88 +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.
-#
-#
-class hdp-hcat(
-  $service_state = $hdp::params::cluster_client_state
-) inherits hdp-hcat::params
-{
-  $hcat_config_dir = $hdp-hcat::params::hcat_conf_dir
-  $hcat_pid_dir = $hdp-hcat::params::hcat_pid_dir
-
-  if ($hdp::params::use_32_bits_on_slaves == false) {
-    $size = 64
-  } else {
-    $size = 32
-  }
-
-  if ($service_state == 'no_op') {
-  } elsif ($service_state == 'uninstalled') {
-    hdp::package { 'hcat' :
-      ensure => 'uninstalled', 
-      size   => $size
-    }
-
-    hdp::directory { $hcat_config_dir:
-      service_state => $service_state,
-      force => true
-    }
-
-    hdp::directory { $hcat_pid_dir:
-      service_state => $service_state,
-      force => true
-    }
-
-    Hdp::Package['hcat'] -> Hdp::Directory[$hcat_config_dir] -> Hdp::Directory[$hcat_pid_dir]
-
-  } elsif ($service_state == 'installed_and_configured') {
-    hdp::package { 'hcat' : 
-      size => $size
-    }
-
-    hdp::directory { $hcat_config_dir:
-      service_state => $service_state,
-      force => true,
-      owner => $hcat_user,
-      group => $hdp::params::user_group,
-      override_owner => true
-    }
-
-    hdp::directory_recursive_create { $hcat_pid_dir:
-      owner => $webhcat_user,
-      service_state => $service_state,
-      force => true
-    }
-
-    hdp-hcat::configfile { 'hcat-env.sh':}
-  
-    Hdp::Package['hcat'] -> Hdp::Directory[$hcat_config_dir] -> Hdp::Directory_recursive_create[$hcat_pid_dir] -> Hdp-hcat::Configfile<||> 
-
- } else {
-    hdp_fail("TODO not implemented yet: service_state = ${service_state}")
-  }
-}
-
-### config files
-define hdp-hcat::configfile()
-{
-  hdp::configfile { "${hdp::params::hcat_conf_dir}/${name}":
-    component => 'hcat',
-    owner => $hdp::params::hcat_user
-  }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/params.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/params.pp b/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/params.pp
deleted file mode 100644
index b9c2f5e..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/params.pp
+++ /dev/null
@@ -1,36 +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.
-#
-#
-class hdp-hcat::params() inherits hdp::params
-{
-  $hcat_conf_dir = $hdp::params::hcat_conf_dir
-
-  $hcat_metastore_port = hdp_default("hcat_metastore_port",9933)
-  $hcat_lib = hdp_default("hcat_lib","/usr/lib/hcatalog/share/hcatalog") #TODO: should I remove and just use hcat_dbroot
-
-  ### hcat-env
-  $hcat_dbroot = hdp_default("hcat_dbroot",$hcat_lib)
-
-  $hcat_log_dir = hdp_default("hcat_log_dir","/var/log/hcatalog")
-
-  $hcat_pid_dir = hdp_default("hcat_pid_dir","/var/run/hcatalog")
-
-  $keytab_path = hdp_default("keytab_path","/etc/security/keytabs")
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hcat/templates/hcat-env.sh.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hcat/templates/hcat-env.sh.erb b/ambari-agent/src/main/puppet/modules/hdp-hcat/templates/hcat-env.sh.erb
deleted file mode 100644
index cf46b5c..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hcat/templates/hcat-env.sh.erb
+++ /dev/null
@@ -1,25 +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.
-
-JAVA_HOME=<%=scope.function_hdp_template_var("::hdp::params::java64_home")%>
-HCAT_PID_DIR=<%=scope.function_hdp_template_var("::hcat_pid_dir")%>/
-HCAT_LOG_DIR=<%=scope.function_hdp_template_var("::hcat_log_dir")%>/
-HCAT_CONF_DIR=<%=scope.function_hdp_template_var("hcat_conf_dir")%>
-HADOOP_HOME=${HADOOP_HOME:-<%=scope.function_hdp_template_var("::hdp::params::hadoop_home")%>}
-#DBROOT is the path where the connector jars are downloaded
-DBROOT=<%=scope.function_hdp_template_var("hcat_dbroot")%>
-USER=<%=scope.function_hdp_user("hcat_user")%>
-METASTORE_PORT=<%=scope.function_hdp_template_var("hcat_metastore_port")%>

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveSmoke.sh
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveSmoke.sh b/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveSmoke.sh
deleted file mode 100644
index 7e03524..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveSmoke.sh
+++ /dev/null
@@ -1,23 +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.
-#
-#
-export tablename=$1
-echo "CREATE EXTERNAL TABLE IF NOT EXISTS ${tablename} ( foo INT, bar STRING );" | hive
-echo "DESCRIBE ${tablename};" | hive

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveserver2.sql
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveserver2.sql b/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveserver2.sql
deleted file mode 100644
index 99a3865..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveserver2.sql
+++ /dev/null
@@ -1,23 +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.
-#
-#
-
-CREATE EXTERNAL TABLE IF NOT EXISTS hiveserver2smoke20408 ( foo INT, bar STRING );
-DESCRIBE hiveserver2smoke20408;

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveserver2Smoke.sh
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveserver2Smoke.sh b/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveserver2Smoke.sh
deleted file mode 100644
index 051a21e..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/files/hiveserver2Smoke.sh
+++ /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.
-#
-#
-
-smokeout=`/usr/lib/hive/bin/beeline -u $1 -n fakeuser -p fakepwd -d org.apache.hive.jdbc.HiveDriver -e '!run $2' 2>&1| awk '{print}'|grep Error`
-
-if [ "x$smokeout" == "x" ]; then
-  echo "Smoke test of hiveserver2 passed"
-  exit 0
-else
-  echo "Smoke test of hiveserver2 wasnt passed"
-  echo $smokeout
-  exit 1
-fi

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/files/startHiveserver2.sh
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/files/startHiveserver2.sh b/ambari-agent/src/main/puppet/modules/hdp-hive/files/startHiveserver2.sh
deleted file mode 100644
index fa90c2f..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/files/startHiveserver2.sh
+++ /dev/null
@@ -1,22 +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.
-#
-#
-HIVE_CONF_DIR=$4 /usr/lib/hive/bin/hiveserver2 -hiveconf hive.metastore.uris=' ' > $1 2> $2 &
-echo $!|cat>$3

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/files/startMetastore.sh
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/files/startMetastore.sh b/ambari-agent/src/main/puppet/modules/hdp-hive/files/startMetastore.sh
deleted file mode 100644
index 9350776..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/files/startMetastore.sh
+++ /dev/null
@@ -1,22 +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.
-#
-#
-HIVE_CONF_DIR=$4 hive --service metastore > $1 2> $2 &
-echo $!|cat>$3

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/client.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/client.pp b/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/client.pp
deleted file mode 100644
index 9e95e25..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/client.pp
+++ /dev/null
@@ -1,40 +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.
-#
-#
-class hdp-hive::client(
-  $service_state = $hdp::params::cluster_client_state,
-  $hive_server_host = undef
-) inherits hdp::params
-{ 
-  if ($service_state == 'no_op') {
-   } elsif ($service_state in ['installed_and_configured','uninstalled']) {
-    if ($hdp::params::service_exists['hdp-hive::server'] != true) {
-      #installs package, creates user, sets configuration
-      class { 'hdp-hive':
-        service_state => $service_state
-      } 
-      if ($hive_server_host != undef) {
-        Hdp-Hive::Configfile<||>{hive_server_host => $hive_server_host}
-      }
-    }
-  } else {
-    hdp_fail("TODO not implemented yet: service_state = ${service_state}")
-  }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/hive/service_check.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/hive/service_check.pp b/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/hive/service_check.pp
deleted file mode 100644
index cf47381..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/hive/service_check.pp
+++ /dev/null
@@ -1,88 +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.
-#
-#
-class hdp-hive::hive::service_check() inherits hdp-hive::params
-{
-  $smoke_test_user = $hdp::params::smokeuser
-  $smoke_test_sql = "/tmp/$smoke_test_sql_file"
-  $smoke_test_path = "/tmp/$smoke_test_script"
-  $security_enabled = $hdp::params::security_enabled
-  $smoke_user_keytab = $hdp::params::smokeuser_keytab
-
-  if ($security_enabled == true) {
-    $kinit_cmd = "${hdp::params::kinit_path_local} -kt ${smoke_user_keytab} ${smoke_test_user};"
-    $hive_principal_ext = "principal=${hdp-hive::params::hive_metatore_keytab_path}"
-    $hive_url_ext = "${hive_url}/\\;${hive_principal_ext}"
-    $smoke_cmd = "${kinit_cmd} env JAVA_HOME=${hdp::params::java64_home} ${smoke_test_path} ${hive_url_ext} ${smoke_test_sql}"
-  } else {
-    $smoke_cmd = "env JAVA_HOME=$hdp::params::java64_home $smoke_test_path $hive_url $smoke_test_sql"
-  }
-
-
-  file { $smoke_test_path:
-    ensure => present,
-    source => "puppet:///modules/hdp-hive/$smoke_test_script",
-    mode => '0755',
-  }
-
-  file { $smoke_test_sql:
-    ensure => present,
-    source => "puppet:///modules/hdp-hive/$smoke_test_sql_file"
-  }
-
-  exec { $smoke_test_path:
-    command   => $smoke_cmd,
-    tries     => 3,
-    try_sleep => 5,
-    path      => '/usr/sbin:/sbin:/usr/local/bin:/bin:/usr/bin',
-    logoutput => "true",
-    user => $smoke_test_user
-  }
-
-#  $unique = hdp_unique_id_and_date()
-#  $output_file = "/apps/hive/warehouse/hivesmoke${unique}"
-#  $test_cmd = "fs -test -e ${output_file}"
-
-#  file { '/tmp/hiveSmoke.sh':
-#    ensure => present,
-#    source => "puppet:///modules/hdp-hive/hiveSmoke.sh",
-#    mode => '0755',
-#  }
-#
-#  exec { '/tmp/hiveSmoke.sh':
-#    command => "su - ${smoke_test_user} -c 'env JAVA_HOME=$hdp::params::java64_home sh /tmp/hiveSmoke.sh hivesmoke${unique}'",
-#    tries => 3,
-#    try_sleep => 5,
-#    path => '/usr/sbin:/sbin:/usr/local/bin:/bin:/usr/bin',
-#    notify => Hdp-hadoop::Exec-hadoop['hive::service_check::test'],
-#    logoutput => "true"
-#  }
-
-#  hdp-hadoop::exec-hadoop { 'hive::service_check::test':
-#    command => $test_cmd,
-#    refreshonly => true
-#  }
-
-#  File[$smoke_test_path] -> File[$smoke_test_sql] -> Exec[$smoke_test_path] -> File['/tmp/hiveSmoke.sh'] -> Exec['/tmp/hiveSmoke.sh'] -> Hdp-Hadoop::Exec-Hadoop['hive::service_check::test']
-
-  include hdp-hcat::hcat::service_check  
-
-  File[$smoke_test_path] -> File[$smoke_test_sql] -> Exec[$smoke_test_path]
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/init.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/init.pp b/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/init.pp
deleted file mode 100644
index d7a58c1..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/init.pp
+++ /dev/null
@@ -1,145 +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.
-#
-#
-class hdp-hive(
-  $service_state,
-  $server = false
-) 
-{
-  include hdp-hive::params
-  
-  $hive_user = $hdp-hive::params::hive_user
-  if ($server == true) {
-    $hive_config_dir = $hdp-hive::params::hive_server_conf_dir
-    $config_file_mode = '0600'
-  } else {
-    $hive_config_dir = $hdp-hive::params::hive_conf_dir
-    $config_file_mode = '0644'
-  }
-
-  # Configs generation
-  if has_key($configuration, 'hive-site') {
-    configgenerator::configfile{'hive-site':
-      modulespath => $hive_config_dir, 
-      filename => 'hive-site.xml',
-      module => 'hdp-hive',
-      configuration => $configuration['hive-site'],
-      owner => $hive_user,
-      group => $hdp::params::user_group,
-      mode => $config_file_mode
-    }
-  } else {
-    file { "${hive_config_dir}/hive-site.xml":
-      owner => $hive_user,
-      group => $hdp::params::user_group,
-      mode => $config_file_mode
-    }
-  }
-
-  anchor { 'hdp-hive::begin': }
-  anchor { 'hdp-hive::end': }
-
-  if ($service_state == 'installed_and_configured' and ($hive_jdbc_driver == "com.mysql.jdbc.Driver" or $hive_jdbc_driver == "oracle.jdbc.driver.OracleDriver")) {
-    hdp::exec { "download DBConnectorVerification.jar" :
-      command => "/bin/sh -c 'cd /usr/lib/ambari-agent/ && curl -kf --retry 5 ${hdp::params::jdk_location}${hdp::params::check_db_connection_jar_name} -o ${hdp::params::check_db_connection_jar_name}'",
-      unless  => "[ -f ${check_db_connection_jar} ]"
-    }
-  }
-
-  if ($service_state == 'uninstalled') {
-    hdp::package { 'hive' : 
-      ensure => 'uninstalled'
-    }
-
-    hdp::directory_recursive_create { $hive_config_dir:
-      service_state => $service_state,
-      ensure => "directory",
-      force => true
-    }
-
-    Anchor['hdp-hive::begin'] -> Hdp::Package['hive'] -> Hdp::Directory_recursive_create[$hive_config_dir] ->  Anchor['hdp-hive::end']
-
-  } else {
-    hdp::package { 'hive' : }
-    if ($server == true ) {
-      class { 'hdp-hive::jdbc-connector': }
-    }
-
-    hdp::directory_recursive_create { $hive_config_dir:
-      service_state => $service_state,
-      force => true,
-      owner => $hive_user,
-      group => $hdp::params::user_group,
-      ensure => "directory",
-      override_owner => true
-    }
-
-    hdp-hive::configfile { 'hive-env.sh': config_dir => $hive_config_dir }
-
-    hdp-hive::ownership { 'ownership': config_dir => $hive_config_dir }
-  
-    Anchor['hdp-hive::begin'] -> Hdp::Package['hive'] -> 
-     Hdp::Directory_recursive_create[$hive_config_dir] -> Hdp-hive::Configfile<||> -> Hdp-hive::Ownership['ownership'] -> Anchor['hdp-hive::end']
-
-     if ($server == true ) {
-       Hdp::Package['hive'] -> Class['hdp-hive::jdbc-connector'] -> Anchor['hdp-hive::end']
-    }
-  }
-}
-
-### config files
-define hdp-hive::configfile(
-  $mode = undef,
-  $hive_server_host = undef,
-  $config_dir = $hdp-hive::params::hive_conf_dir
-) 
-{
-  hdp::configfile { "${config_dir}/${name}":
-    component        => 'hive',
-    owner            => $hdp-hive::params::hive_user,
-    mode             => $mode,
-    hive_server_host => $hive_server_host 
-  }
-}
-
-define hdp-hive::ownership(
-  $config_dir = $hdp-hive::params::hive_conf_dir
-)
-{
-  file { "${config_dir}/hive-default.xml.template":
-    owner => $hdp-hive::params::hive_user,
-    group => $hdp::params::user_group
-  }
-
-  file { "${config_dir}/hive-env.sh.template":
-    owner => $hdp-hive::params::hive_user,
-    group => $hdp::params::user_group
-  }
-
-  file { "${config_dir}/hive-exec-log4j.properties.template":
-    owner => $hdp-hive::params::hive_user,
-    group => $hdp::params::user_group
-  }
-
-  file { "${config_dir}/hive-log4j.properties.template":
-    owner => $hdp-hive::params::hive_user,
-    group => $hdp::params::user_group
-  }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/jdbc-connector.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/jdbc-connector.pp b/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/jdbc-connector.pp
deleted file mode 100644
index 8bd9302..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/jdbc-connector.pp
+++ /dev/null
@@ -1,63 +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.
-#
-#
-class hdp-hive::jdbc-connector()
-{
-  include hdp-hive::params
-
-  $jdbc_jar_name = $hdp-hive::params::jdbc_jar_name
-  
-  $java_share_dir = "/usr/share/java"
-  $driver_curl_target = "${java_share_dir}/${jdbc_jar_name}"
-
-  $hive_lib = $hdp-hive::params::hive_lib
-  $target = "${hive_lib}/${jdbc_jar_name}"
-  
-  $jdk_location = $hdp::params::jdk_location
-  $driver_curl_source = "${jdk_location}${jdbc_jar_name}"
-
-  anchor { 'hdp-hive::jdbc-connector::begin':}
-
-   hdp::package { 'mysql-connector-java' :
-     require   => Anchor['hdp-hive::jdbc-connector::begin']
-   }
-
-  if ($hive_jdbc_driver == "com.mysql.jdbc.Driver"){
-   hdp::exec { 'hive mkdir -p ${artifact_dir} ;  cp /usr/share/java/${jdbc_jar_name}  ${target}':
-       command => "mkdir -p ${::artifact_dir} ;  cp /usr/share/java/${jdbc_jar_name}  ${target}",
-       unless  => "test -f ${target}",
-       creates => $target,
-       path    => ["/bin","/usr/bin/"],
-       require => Hdp::Package['mysql-connector-java'],
-       notify  =>  Anchor['hdp-hive::jdbc-connector::end'],
-   }
-  } elsif ($hive_jdbc_driver == "oracle.jdbc.driver.OracleDriver") {
-   hdp::exec { 'hive mkdir -p ${artifact_dir} ; curl -kf --retry 10 ${driver_curl_source} -o ${driver_curl_target} &&  cp ${driver_curl_target} ${target}':
-       command => "mkdir -p ${::artifact_dir} ; curl -kf --retry 10 ${driver_curl_source} -o ${driver_curl_target} &&  cp ${driver_curl_target} ${target}",
-       unless  => "test -f ${target}",
-       path    => ["/bin","/usr/bin/"],
-       notify  =>  Anchor['hdp-hive::jdbc-connector::end'],
-     }  
-  }
-
-
-   anchor { 'hdp-hive::jdbc-connector::end':}
-
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/metastore.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/metastore.pp b/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/metastore.pp
deleted file mode 100644
index 29bfd97..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/metastore.pp
+++ /dev/null
@@ -1,61 +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.
-#
-#
-class hdp-hive::metastore(
-  $service_state = $hdp::params::cluster_service_state,
-  $opts = {}
-) inherits  hdp-hive::params
-{ 
-
-  if ($service_state == 'no_op') {
-  } elsif ($service_state in ['running','stopped','installed_and_configured','uninstalled']) { 
-
-    $hdp::params::service_exists['hdp-hive::server'] = true
-
-    if ( ($service_state == 'installed_and_configured') and
-         ($security_enabled == true) and ($kerberos_install_type == "AMBARI_SET_KERBEROS") ) {
-      $masterHost = $kerberos_adminclient_host[0]
-      hdp::download_keytab { 'hive_server_service_keytab' :
-        masterhost => $masterHost,
-        keytabdst => "${$keytab_path}/hive.service.keytab",
-        keytabfile => 'hive.service.keytab',
-        owner => $hdp-hive::params::hive_user
-      }
-    }
-
-    #installs package, creates user, sets configuration
-    class{ 'hdp-hive' : 
-      service_state => $service_state,
-      server        => true
-    } 
-  
-    Hdp-Hive::Configfile<||>{hive_server_host => $hdp::params::host_address}
-
-    class { 'hdp-hive::service' :
-      ensure => $service_state,
-      service_type => "metastore"
-    }
-  
-    #top level does not need anchors
-    Class['hdp-hive'] -> Class['hdp-hive::service']
-  } else {
-    hdp_fail("TODO not implemented yet: service_state = ${service_state}")
-  }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/params.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/params.pp b/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/params.pp
deleted file mode 100644
index 65f321e..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/params.pp
+++ /dev/null
@@ -1,86 +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.
-#
-#
-class hdp-hive::params() inherits hdp::params
-{
-
-  #TODO: will move to globals
-  $hive_metastore_user_name = hdp_default("hive-site/javax.jdo.option.ConnectionUserName","dbusername")
-  $hive_metastore_user_passwd = hdp_default("hive-site/javax.jdo.option.ConnectionPassword","dbpassword")
-  $hive_server_conf_dir = hdp_default("hive_server_conf_dir", "/etc/hive/conf.server")
-  $hive_jdbc_connection_url = hdp_default("hive-site/javax.jdo.option.ConnectionURL", "")
-
-  ### users
-  $hive_user = $hdp::params::hive_user
-  
-  ### JDBC driver jar name
-  if ($hive_jdbc_driver == "com.mysql.jdbc.Driver"){
-    $jdbc_jar_name = "mysql-connector-java.jar"
-  } elsif ($hive_jdbc_driver == "oracle.jdbc.driver.OracleDriver") {
-    $jdbc_jar_name = "ojdbc6.jar"  
-  }
-  
-  ### common
-  $hive_metastore_port = hdp_default("hive_metastore_port",9083)
-  $hive_lib = hdp_default("hive_lib","/usr/lib/hive/lib/") #TODO: should I remove and just use hive_dbroot
-  $hive_var_lib = hdp_default("hive_var_lib","/var/lib/hive")  
-  $hive_url = "jdbc:hive2://${hive_server_host}:10000"
-
-  ### hive-env
-  $hive_conf_dir = $hdp::params::hive_conf_dir
-
-  $hive_dbroot = hdp_default("hive_dbroot",$hive_lib)
-
-  $hive_log_dir = hdp_default("hive_log_dir","/var/log/hive")
-
-  $hive_pid_dir = hdp_default("hive_pid_dir","/var/run/hive")
-  $hive_pid = hdp_default("hive_pid","hive-server.pid")
-
-  
-  ### hive-site
-  $hive_database_name = hdp_default("hive-site/hive.database.name","hive")
-
-  if ($hdp::params::security_enabled == true) {
-    $hive_metastore_sasl_enabled = true
-  } else {
-    $hive_metastore_sasl_enabled = false
-  }
-
-  $keytab_path = hdp_default("keytab_path","/etc/security/keytabs")
-  $hive_metatore_keytab_path = hdp_default("hive-site/hive.metastore.kerberos.keytab.file","/etc/security/keytabs/hive.service.keytab")
-
-  #TODO: using instead hive_server_host in hdp::params 
-  #$hive_metastore_server_host = hdp_default("hive-site/hive.metastore.server.host")
-  
-  ###mysql connector
-  $download_url = $hdp::params::gpl_artifacts_download_url
-  $mysql_connector_url = "${download_url}/mysql-connector-java-5.1.18.zip"
-  $hive_aux_jars_path =  hdp_default("hive_aux_jars_path","/usr/lib/hcatalog/share/hcatalog/hcatalog-core.jar")
-
-  ##smoke test
-  $smoke_test_sql_file = 'hiveserver2.sql'
-  $smoke_test_script = 'hiveserver2Smoke.sh'
-
-  ##Starting hiveserver2
-  $start_hiveserver2_script = 'startHiveserver2.sh'
-
-  ##Starting metastore
-  $start_metastore_script = 'startMetastore.sh'
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/server.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/server.pp b/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/server.pp
deleted file mode 100644
index 7f4db1f..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/server.pp
+++ /dev/null
@@ -1,61 +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.
-#
-#
-class hdp-hive::server(
-  $service_state = $hdp::params::cluster_service_state,
-  $opts = {}
-) inherits  hdp-hive::params
-{ 
-
-  if ($service_state == 'no_op') {
-  } elsif ($service_state in ['running','stopped','installed_and_configured','uninstalled']) { 
-
-    $hdp::params::service_exists['hdp-hive::server'] = true
-
-    if ( ($service_state == 'installed_and_configured') and
-         ($security_enabled == true) and ($kerberos_install_type == "AMBARI_SET_KERBEROS") ) {
-      $masterHost = $kerberos_adminclient_host[0]
-      hdp::download_keytab { 'hive_server_service_keytab' :
-        masterhost => $masterHost,
-        keytabdst => "${$keytab_path}/hive.service.keytab",
-        keytabfile => 'hive.service.keytab',
-        owner => $hdp-hive::params::hive_user
-      }
-    }
-
-    #installs package, creates user, sets configuration
-    class{ 'hdp-hive' : 
-      service_state => $service_state,
-      server        => true
-    } 
-  
-    Hdp-Hive::Configfile<||>{hive_server_host => $hdp::params::host_address}
-
-    class { 'hdp-hive::service' :
-      ensure => $service_state,
-      service_type => "hiveserver2"
-    }
-  
-    #top level does not need anchors
-    Class['hdp-hive'] -> Class['hdp-hive::service']
-  } else {
-    hdp_fail("TODO not implemented yet: service_state = ${service_state}")
-  }
-}