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:13 UTC

[05/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-yarn/manifests/historyserver.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/historyserver.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/historyserver.pp
deleted file mode 100644
index 07a9376..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/historyserver.pp
+++ /dev/null
@@ -1,48 +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-yarn::historyserver(
-  $service_state = $hdp::params::cluster_service_state,
-  $opts = {}
-) inherits hdp-yarn::params
-{
-  $mapred_user = $hdp-yarn::params::mapred_user
-  
-  if ($service_state == 'no_op') {
-  } elsif ($service_state in 'installed_and_configured') {
-  
-    include hdp-yarn::initialize
-
-    ##Process package
-    hdp-yarn::package{'mapreduce-historyserver':}
-
-  } elsif ($service_state in ['running','stopped']) {
-
-    include hdp-yarn::initialize
- 
-    hdp-yarn::service{ 'historyserver':
-      ensure       => $service_state,
-      user         => $mapred_user
-    }
-
-  } else {
-    hdp_fail("TODO not implemented yet: service_state = ${service_state}")
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/historyserver/service_check.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/historyserver/service_check.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/historyserver/service_check.pp
deleted file mode 100644
index 885e24b..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/historyserver/service_check.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-yarn::historyserver::service_check() inherits hdp-yarn::params
-{
-  hdp-yarn::smoketest{'hdp-yarn::smoketest:rm': component_name => 'historyserver'}
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/init.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/init.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/init.pp
deleted file mode 100644
index 5d74f86..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/init.pp
+++ /dev/null
@@ -1,166 +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-yarn::initialize()
-{
-  $mapred_user = $hdp-yarn::params::mapred_user
-  $hdfs_user = $hdp::params::hdfs_user
-  $yarn_user = $hdp-yarn::params::yarn_user
-
-  ##Process package
-  hdp-yarn::package{'yarn-common':}
-
-  #Replace limits config file
-  hdp::configfile {"${hdp::params::limits_conf_dir}/yarn.conf":
-    component => 'yarn',
-    owner => 'root',
-    group => 'root',
-    mode => 644    
-  }
-
-  # Create users
-  hdp::user { 'yarn_mapred_user':
-     user_name => $mapred_user
-  }
-
-  hdp::user { 'yarn_hdfs_user':
-     user_name => $hdfs_user
-  }
-
-  hdp::user { 'yarn_yarn_user':
-     user_name => $yarn_user
-  }
-
-  #Generate common configs
-  hdp-yarn::generate_common_configs{'yarn-common-configs':}
-
-  anchor{ 'hdp-yarn::initialize::begin': } Hdp::Package['yarn-common'] -> Hdp::Configfile ["${hdp::params::limits_conf_dir}/yarn.conf"] ->
-    Hdp::User<|title == 'yarn_hdfs_user' or title == 'yarn_mapred_user' or title == 'yarn_yarn_user'|> ->
-      Hdp-yarn::Generate_common_configs['yarn-common-configs'] -> anchor{ 'hdp-yarn::initialize::end': }
-}
-
-define hdp-yarn::generate_common_configs() {
-
-  $yarn_config_dir = $hdp-yarn::params::conf_dir
-
-  # Generate configs
-  if has_key($::configuration, 'core-site') {
-      configgenerator::configfile{'core-site':
-        modulespath => $yarn_config_dir,
-        filename => 'core-site.xml',
-        module => 'hdp-hadoop',
-        configuration => $::configuration['core-site'],
-        owner => $hdp::params::hdfs_user,
-        group => $hdp::params::user_group,
-        mode => 644
-      }
-  } else { # Manually overriding ownership of file installed by hadoop package
-    file { "${yarn_config_dir}/core-site.xml":
-      owner => $hdp::params::hdfs_user,
-      group => $hdp::params::user_group,
-      mode => 644
-    }
-  }
-
-  if has_key($::configuration, 'mapred-site') {
-    configgenerator::configfile{'mapred-site': 
-      modulespath => $yarn_config_dir,
-      filename => 'mapred-site.xml',
-      module => 'hdp-yarn',
-      configuration => $::configuration['mapred-site'],
-      owner => $hdp-yarn::params::yarn_user,
-      group => $hdp::params::user_group,
-      mode => 644
-    }
-  } else { # Manually overriding ownership of file installed by hadoop package
-    file { "${yarn_config_dir}/mapred-site.xml":
-      owner => $hdp-yarn::params::yarn_user,
-      group => $hdp::params::user_group,
-      mode => 644
-    }
-  }
-  
-  if has_key($::configuration, 'yarn-site') {
-    configgenerator::configfile{'yarn-site': 
-      modulespath => $yarn_config_dir,
-      filename => 'yarn-site.xml',
-      module => 'hdp-yarn',
-      configuration => $::configuration['yarn-site'],
-      owner => $hdp-yarn::params::yarn_user,
-      group => $hdp::params::user_group,
-      mode => 644
-    }
-  } else { # Manually overriding ownership of file installed by hadoop package
-    file { "${yarn_config_dir}/yarn-site.xml":
-      owner => $hdp-yarn::params::yarn_user,
-      group => $hdp::params::user_group,
-      mode => 644
-    }
-  }
-
-  if has_key($::configuration, 'capacity-scheduler') {
-    configgenerator::configfile{'capacity-scheduler': 
-      modulespath => $yarn_config_dir,
-      filename => 'capacity-scheduler.xml',
-      module => 'hdp-yarn',
-      configuration => $::configuration['capacity-scheduler'],
-      owner => $hdp-yarn::params::yarn_user,
-      group => $hdp::params::user_group,
-      mode => 644
-    }
-  } else { # Manually overriding ownership of file installed by hadoop package
-    file { "${yarn_config_dir}/capacity-scheduler.xml":
-      owner => $hdp-yarn::params::yarn_user,
-      group => $hdp::params::user_group,
-      mode => 644
-    }
-  }
-
-  hdp::configfile {"${yarn_config_dir}/yarn-env.sh":
-    component => 'yarn',
-    owner => $hdp-yarn::params::yarn_user,
-    group => $hdp::params::user_group,
-    mode => 755
-  }
-
-  hdp::configfile { "${yarn_config_dir}/hadoop-env.sh":
-    mode => 755,
-    owner => $hdp::params::hdfs_user,
-    group => $hdp::params::user_group,
-    component => 'hadoop'
-  }
-
-  if ($hdp::params::security_enabled == true) {
-    $container_executor = "${hdp::params::yarn_container_bin}/container-executor"
-    file { $container_executor:
-      ensure => present,
-      group => $hdp-yarn::params::yarn_executor_container_group,
-      mode => 6050
-    }
-
-    hdp::configfile { "${yarn_config_dir}/container-executor.cfg" :
-      component => 'yarn',
-      owner => 'root',
-      group   => $hdp::params::user_group,
-      mode  => '0644'
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/mapred2/service_check.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/mapred2/service_check.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/mapred2/service_check.pp
deleted file mode 100644
index 3ada16e..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/mapred2/service_check.pp
+++ /dev/null
@@ -1,69 +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-yarn::mapred2::service_check() inherits hdp-yarn::params
-{
-  $smoke_test_user = $hdp::params::smokeuser
-  $hadoopMapredExamplesJarName = $hdp-yarn::params::hadoopMapredExamplesJarName
-  $jar_path = "$hdp::params::hadoop_mapred2_jar_location/$hadoopMapredExamplesJarName"
-  $input_file = "/user/${smoke_test_user}/mapredsmokeinput"
-  $output_file = "/user/${smoke_test_user}/mapredsmokeoutput"
-  $hadoop_conf_dir = $hdp::params::hadoop_conf_dir
-
-  $cleanup_cmd = "fs -rm -r -f ${output_file} ${input_file}"
-  $create_file_cmd = "fs -put /etc/passwd ${input_file}"
-  $test_cmd = "fs -test -e ${output_file}"
-  $run_wordcount_job = "jar $jar_path wordcount ${input_file} ${output_file}"
-
-  anchor { 'hdp-yarn::mapred2::service_check::begin':}
-
-  hdp-hadoop::exec-hadoop { 'mapred::service_check::cleanup_before':
-    command   => $cleanup_cmd,
-    tries     => 1,
-    try_sleep => 5,
-    user      => $smoke_test_user
-  }
-
-  hdp-hadoop::exec-hadoop { 'mapred::service_check::create_file':
-    command   => $create_file_cmd,
-    tries     => 1,
-    try_sleep => 5,
-    user      => $smoke_test_user
-  }
-
-  hdp-hadoop::exec-hadoop { 'mapred::service_check::run_wordcount':
-    command   => $run_wordcount_job,
-    tries     => 1,
-    try_sleep => 5,
-    user      => $smoke_test_user,
-    logoutput => "true"
-  }
-
-  hdp-hadoop::exec-hadoop { 'mapred::service_check::test':
-    command     => $test_cmd,
-    refreshonly => true,
-    user        => $smoke_test_user
-  }
-
-  anchor { 'hdp-yarn::mapred2::service_check::end':}
-
-  Anchor['hdp-yarn::mapred2::service_check::begin'] -> Hdp-hadoop::Exec-hadoop['mapred::service_check::cleanup_before'] -> Hdp-hadoop::Exec-hadoop['mapred::service_check::create_file'] -> Hdp-hadoop::Exec-hadoop['mapred::service_check::run_wordcount'] -> Hdp-hadoop::Exec-hadoop['mapred::service_check::test'] -> Anchor['hdp-yarn::mapred2::service_check::end']
-
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/mapreducev2_client.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/mapreducev2_client.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/mapreducev2_client.pp
deleted file mode 100644
index 2cf607d..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/mapreducev2_client.pp
+++ /dev/null
@@ -1,43 +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-yarn::mapreducev2_client(
-  $service_state = $hdp::params::cluster_service_state,
-  $opts = {}
-) inherits hdp-yarn::params
-{
-  if ($service_state == 'no_op') {
-  } elsif ($service_state in 'installed_and_configured') {
-
-    include hdp-yarn::initialize
-
-    hdp-yarn::package{'hadoop-mapreduce-client':}
-
-    hdp::configfile {"${hdp::params::limits_conf_dir}/mapreduce.conf":
-      component => 'yarn',
-      owner => 'root',
-      group => 'root',
-      mode => 644,
-      require => Hdp-yarn::Package['hadoop-mapreduce-client']
-    }
-
-  }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/nodemanager.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/nodemanager.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/nodemanager.pp
deleted file mode 100644
index 67856bb..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/nodemanager.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.
-#
-#
-class hdp-yarn::nodemanager(
-  $service_state = $hdp::params::cluster_service_state,
-  $opts = {}
-) inherits hdp-yarn::params
-{
-  $yarn_user = $hdp-yarn::params::yarn_user
-  $nm_local_dirs = $hdp-yarn::params::nm_local_dirs
-  $nm_log_dirs = $hdp-yarn::params::nm_log_dirs
-  $yarn_log_dir_prefix = $hdp-yarn::params::yarn_log_dir_prefix
-
-  if ($service_state == 'no_op') {
-  } elsif ($service_state in 'installed_and_configured') {
-  
-    include hdp-yarn::initialize
-
-    ##Process package
-    hdp-yarn::package{'yarn-nodemanager':}
-
-    hdp::configfile {"${hdp::params::limits_conf_dir}/mapreduce.conf":
-      component => 'yarn',
-      owner => 'root',
-      group => 'root',
-      mode => 644,
-      require => Hdp-yarn::Package['yarn-nodemanager']
-    }
-
-  } elsif ($service_state in ['running','stopped']) {
-
-    include hdp-yarn::initialize
-
-    # To avoid duplicate resource definitions
-    $nm_dirs = hdp_set_from_comma_list("${nm_local_dirs},${nm_log_dirs}", "$yarn_log_dir_prefix")
-
-    hdp-yarn::nodemanager::create_nm_dirs { $nm_dirs:
-      service_state => $service_state
-    }
-
-    hdp-yarn::service{ 'nodemanager':
-      ensure       => $service_state,
-      user         => $yarn_user
-    }
-
-    anchor{"hdp-yarn::nodemanager::begin" : } ->
-    Hdp-yarn::Nodemanager::Create_nm_dirs<||> ->
-    Hdp-yarn::Service['nodemanager'] ->
-    anchor{"hdp-yarn::nodemanager::end": }
-
-  } else {
-    hdp_fail("TODO not implemented yet: service_state = ${service_state}")
-  }
-}
-
-
-define hdp-yarn::nodemanager::create_nm_dirs($service_state) {
-  $dirs = hdp_array_from_comma_list($name)
-  hdp::directory_recursive_create_ignore_failure { $dirs :
-    owner => $hdp-yarn::params::yarn_user,
-    context_tag => 'yarn_service',
-    service_state => $service_state,
-    force => true
-  }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/package.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/package.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/package.pp
deleted file mode 100644
index 154959d..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/package.pp
+++ /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.
-#
-#
-define hdp-yarn::package()
-{
-  hdp::package{ $name:
-    ensure       => present,
-    package_type => $package
-  }
-  anchor{ "hdp-yarn::package::${name}::begin": } -> Hdp::Package[$name] -> anchor{ "hdp-yarn::package::${name}::end": }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/params.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/params.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/params.pp
deleted file mode 100644
index 9fa897a..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/params.pp
+++ /dev/null
@@ -1,59 +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-yarn::params(
-) inherits hdp-hadoop::params 
-{
-
-  $conf_dir = $hdp::params::yarn_conf_dir
-  $stack_version = $hdp::params::stack_version
-  $smoke_test_user = $hdp::params::smokeuser
-  ## security params
-  $security_enabled = $hdp::params::security_enabled
-  $smoke_user_keytab = $hdp::params::smokeuser_keytab
-  $yarn_executor_container_group = hdp_default("yarn-site/yarn.nodemanager.linux-container-executor.group","hadoop")
-  $kinit_cmd = "${hdp::params::kinit_path_local} -kt ${smoke_user_keytab} ${smoke_test_user};"
-  $rm_host = $hdp::params::rm_host
-  $rm_port = $hdp::rm_port
-  $rm_https_port = $hdp::rm_https_port
-
-  ## yarn-env 
-  $hadoop_libexec_dir = $hdp-hadoop::params::hadoop_libexec_dir
-  $hadoop_yarn_home = hdp_default("hadoop_yarn_home","/usr/lib/hadoop-yarn")
-  $yarn_heapsize = hdp_default("yarn_heapsize","1024")
-  $resourcemanager_heapsize = hdp_default("resourcemanager_heapsize","1024")
-  $nodemanager_heapsize = hdp_default("nodemanager_heapsize","1024")
-
-  $yarn_log_dir_prefix = hdp_default("yarn_log_dir_prefix","/var/log/hadoop-yarn")
-  $yarn_pid_dir_prefix = hdp_default("yarn_pid_dir_prefix","/var/run/hadoop-yarn")
-  
-  ## yarn-site
-  $rm_webui_address = "${rm_host}:${rm_port}"
-  $rm_webui_https_address = "${rm_host}:${rm_https_port}"
-  $nm_webui_address = hdp_default("yarn-site/yarn.nodemanager.webapp.address", "0.0.0.0:8042")
-  $hs_webui_address = hdp_default("mapred-site/mapreduce.jobhistory.webapp.address", "0.0.0.0:19888")
-  
-  $nm_local_dirs = hdp_default("yarn-site/yarn.nodemanager.local-dirs", "${hadoop_tmp_dir}/nm-local-dir")
-  $nm_log_dirs = hdp_default("yarn-site/yarn.nodemanager.log-dirs", "/var/log/hadoop-yarn/yarn")
-
-  ##smoke test configs
-  $distrAppJarName = "hadoop-yarn-applications-distributedshell-2.*.jar"
-  $hadoopMapredExamplesJarName = "hadoop-mapreduce-examples-2.*.jar"
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/resourcemanager.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/resourcemanager.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/resourcemanager.pp
deleted file mode 100644
index 2ecf442..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/resourcemanager.pp
+++ /dev/null
@@ -1,56 +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-yarn::resourcemanager(
-  $service_state = $hdp::params::cluster_service_state,
-  $opts = {}
-) inherits hdp-yarn::params
-{
-  $yarn_user = $hdp-yarn::params::yarn_user
-  
-  if ($service_state == 'no_op') {
-  } elsif ($service_state in 'installed_and_configured') {
-  
-    include hdp-yarn::initialize
-
-    ##Process package
-    hdp-yarn::package{'yarn-resourcemanager':}
-
-    hdp::configfile {"${hdp::params::limits_conf_dir}/mapreduce.conf":
-      component => 'yarn',
-      owner => 'root',
-      group => 'root',
-      mode => 644,
-      require => Hdp-yarn::Package['yarn-resourcemanager']
-    }
-
-  } elsif ($service_state in ['running','stopped']) {
-  
-    include hdp-yarn::initialize
- 
-    hdp-yarn::service{ 'resourcemanager':
-      ensure       => $service_state,
-      user         => $yarn_user
-    }
-
-  } 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-yarn/manifests/resourcemanager/service_check.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/resourcemanager/service_check.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/resourcemanager/service_check.pp
deleted file mode 100644
index c5386c3..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/resourcemanager/service_check.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-yarn::resourcemanager::service_check() inherits hdp-yarn::params
-{
-  hdp-yarn::smoketest{'hdp-yarn::smoketest:rm': component_name => 'resourcemanager'}
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/service.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/service.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/service.pp
deleted file mode 100644
index 3589829..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/service.pp
+++ /dev/null
@@ -1,116 +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-yarn::service(
-  $ensure = 'running',
-  $user,
-  $initial_wait = undef,
-  $create_pid_dir = true,
-  $create_log_dir = true
-)
-{
-
-  $security_enabled = $hdp::params::security_enabled
-  
-  if ($name == 'historyserver') {
-    $log_dir = "${hdp-yarn::params::mapred_log_dir_prefix}/${user}"
-    $pid_dir = "${hdp-yarn::params::mapred_pid_dir_prefix}/${user}"
-    $daemon = "${hdp::params::mapred_bin}/mr-jobhistory-daemon.sh"
-    $pid_file = "${pid_dir}/mapred-${user}-${name}.pid"
-    $job_summary_log = "${hdp-yarn::params::mapred_log_dir_prefix}/${user}/hadoop-mapreduce.jobsummary.log"
-  } else {
-    $log_dir = "${hdp-yarn::params::yarn_log_dir_prefix}/${user}"
-    $pid_dir = "${hdp-yarn::params::yarn_pid_dir_prefix}/${user}"
-    $daemon = "${hdp::params::yarn_bin}/yarn-daemon.sh"
-    $pid_file = "${pid_dir}/yarn-${user}-${name}.pid"
-    $job_summary_log = "${hdp-yarn::params::yarn_log_dir_prefix}/${user}/hadoop-mapreduce.jobsummary.log"
-  }
-  
-  $hadoop_libexec_dir = $hdp-yarn::params::hadoop_libexec_dir
-   
-  $cmd = "export HADOOP_LIBEXEC_DIR=${hadoop_libexec_dir} && ${daemon} --config ${hdp-yarn::params::conf_dir}"
-  
-  if ($ensure == 'running') {
-    if ($run_as_root == true) {
-      $daemon_cmd = "${cmd} start ${name}"
-    } else {
-      $daemon_cmd = "su - ${user} -c  '${cmd} start ${name}'"
-    }
-    $service_is_up = "ls ${pid_file} >/dev/null 2>&1 && ps `cat ${pid_file}` >/dev/null 2>&1"
-  } elsif ($ensure == 'stopped') {
-    if ($run_as_root == true) {
-      $daemon_cmd = "${cmd} stop ${name} && rm -f ${pid_file}"
-    } else {
-      $daemon_cmd = "su - ${user} -c  '${cmd} stop ${name}' && rm -f ${pid_file}"
-    }
-    $service_is_up = undef
-  } else {
-    $daemon_cmd = undef
-  }
- 
-   if ($create_pid_dir == true) {
-    hdp::directory_recursive_create { $pid_dir: 
-      owner       => $user,
-      context_tag => 'yarn_service',
-      service_state => $ensure,
-      force => true
-    }
-  }
- 
-  if ($create_log_dir == true) {
-    hdp::directory_recursive_create { $log_dir: 
-      owner       => $user,
-      context_tag => 'yarn_service',
-      service_state => $ensure,
-      force => true
-    }
-
-    file {$job_summary_log:
-      path => $job_summary_log,
-      owner => $user,
-    }
-  }
- 
-  if ($daemon_cmd != undef) {  
-    hdp::exec { $daemon_cmd:
-      command      => $daemon_cmd,
-      unless       => $service_is_up,
-      initial_wait => $initial_wait
-    }
-  }
-
-  anchor{"hdp-yarn::service::${name}::begin":}
-  anchor{"hdp-yarn::service::${name}::end":}
-  if ($daemon_cmd != undef) {
-    Anchor["hdp-yarn::service::${name}::begin"] -> Hdp::Directory_recursive_create<|title == $pid_dir or title == $log_dir|> -> File[$job_summary_log] -> Hdp::Exec[$daemon_cmd] -> Anchor["hdp-yarn::service::${name}::end"]
-
-  }
-  if ($ensure == 'running') {
-    #TODO: look at Puppet resource retry and retry_sleep
-    #TODO: can make sleep contingent on $name
-    $sleep = 5
-    $post_check = "sleep ${sleep}; ${service_is_up}"
-    hdp::exec { $post_check:
-      command => $post_check,
-      unless  => $service_is_up
-    }
-    Hdp::Exec[$daemon_cmd] -> Hdp::Exec[$post_check] -> Anchor["hdp-yarn::service::${name}::end"]
-  }  
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/smoketest.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/smoketest.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/smoketest.pp
deleted file mode 100644
index e2faef4..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/smoketest.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-yarn::smoketest(
-  $component_name = undef
-)
-{
-  $rm_webui_address = $hdp-yarn::params::rm_webui_address
-  $rm_webui_https_address = $hdp-yarn::params::rm_webui_https_address
-  $nm_webui_address = $hdp-yarn::params::nm_webui_address
-  $hs_webui_address = $hdp-yarn::params::hs_webui_address
-  
-  $hadoop_ssl_enabled = $hdp-hadoop::params::hadoop_ssl_enabled
-
-  if ($component_name == 'resourcemanager') {
-    $component_type = 'rm'
-    if ($hadoop_ssl_enabled == "true") {
-      $component_address = $rm_webui_https_address
-    } else {
-      $component_address = $rm_webui_address
-    }
-  } elsif ($component_name == 'nodemanager') {
-    $component_type = 'nm'
-    $component_address = $nm_webui_address
-  } elsif ($component_name == 'historyserver') {
-    $component_type = 'hs'
-    $component_address = $hs_webui_address
-  } else {
-    hdp_fail("Unsupported component name: $component_name")
-  }
-
-  $security_enabled = $hdp::params::security_enabled
-  $smoke_user_keytab = $hdp::params::smokeuser_keytab
-  $smoke_test_user = $hdp::params::smokeuser
-  $kinit_cmd = "${hdp::params::kinit_path_local} -kt ${smoke_user_keytab} ${smoke_test_user};"
-
-
-  $validateStatusFileName = "validateYarnComponentStatus.py"
-  $validateStatusFilePath = "/tmp/$validateStatusFileName"
-
-  $validateStatusCmd = "$validateStatusFilePath $component_type -p $component_address -s $hadoop_ssl_enabled"
-
-    if ($security_enabled == true) {
-         $smoke_cmd = "${kinit_cmd}  $validateStatusCmd"
-        } else {
-          $smoke_cmd = $validateStatusCmd
-        }
-
-
-  file { $validateStatusFilePath:
-    ensure => present,
-    source => "puppet:///modules/hdp-yarn/$validateStatusFileName",
-    mode => '0755'
-  }
-
-  exec { $validateStatusFilePath:
-    command   => $smoke_cmd,
-    tries     => 3,
-    try_sleep => 5,
-    path      => '/usr/sbin:/sbin:/usr/local/bin:/bin:/usr/bin',
-    logoutput => "true",
-    user     =>  $smoke_test_user
-}
-  anchor{"hdp-yarn::smoketest::begin":} -> File[$validateStatusFilePath] -> Exec[$validateStatusFilePath] -> anchor{"hdp-yarn::smoketest::end":}
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/yarn/service_check.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/yarn/service_check.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/yarn/service_check.pp
deleted file mode 100644
index 4f2fffe..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/yarn/service_check.pp
+++ /dev/null
@@ -1,38 +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-yarn::yarn::service_check() inherits hdp-yarn::params
-{
-
-  $jar_path = "$hadoop_yarn_home/$distrAppJarName"
-  $run_yarn_check_cmd = "node -list"
-  
-  ## Check availability of REST api
-  hdp-yarn::smoketest{'hdp-yarn::smoketest:rm': component_name => 'resourcemanager'}
-  
-  ## Run distributed shell application check
-  hdp-hadoop::exec-hadoop { 'hdp-yarn::yarn::service_check':
-    path        => '/usr/bin/yarn',
-    command     => $run_yarn_check_cmd,
-    user        => $smoke_test_user
-  }
-  
-  anchor{"hdp-yarn::yarn::service_check::begin":} -> Hdp-yarn::Smoketest['hdp-yarn::smoketest:rm'] ->  Hdp-hadoop::Exec-hadoop['hdp-yarn::yarn::service_check'] -> anchor{"hdp-yarn::yarn::service_check::end":}
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/yarn_client.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/yarn_client.pp b/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/yarn_client.pp
deleted file mode 100644
index 8914233..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/manifests/yarn_client.pp
+++ /dev/null
@@ -1,34 +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-yarn::yarn_client(
-  $service_state = $hdp::params::cluster_service_state,
-  $opts = {}
-) inherits hdp-yarn::params
-{  
-  if ($service_state == 'no_op') {
-  } elsif ($service_state in 'installed_and_configured') {
-  
-    include hdp-yarn::initialize
-
-  } else {
-    hdp_fail("TODO not implemented yet: service_state = ${service_state}")
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/container-executor.cfg.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/container-executor.cfg.erb b/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/container-executor.cfg.erb
deleted file mode 100644
index c6a2479..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/container-executor.cfg.erb
+++ /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.
-# */
-yarn.nodemanager.local-dirs=<%=scope.function_hdp_default(["yarn-site/yarn.nodemanager.local-dirs","/hadoop/yarn"])%>
-yarn.nodemanager.log-dirs=<%=scope.function_hdp_default(["yarn-site/yarn.nodemanager.log-dirs","/var/log/hadoop/yarn"])%>
-yarn.nodemanager.linux-container-executor.group=<%=scope.function_hdp_default(["yarn-site/yarn.nodemanager.linux-container-executor.group","hadoop"])%>
-banned.users = hdfs,yarn,mapred,bin
-min.user.id=1000

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/mapreduce.conf.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/mapreduce.conf.erb b/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/mapreduce.conf.erb
deleted file mode 100644
index 222938e..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/mapreduce.conf.erb
+++ /dev/null
@@ -1,17 +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.
-
-<%=scope.function_hdp_template_var("mapred_user")%>   - nofile 32768
-<%=scope.function_hdp_template_var("mapred_user")%>   - nproc  65536

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/yarn-env.sh.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/yarn-env.sh.erb b/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/yarn-env.sh.erb
deleted file mode 100644
index b9e9398..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/yarn-env.sh.erb
+++ /dev/null
@@ -1,119 +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 HADOOP_YARN_HOME=<%=scope.function_hdp_template_var("hadoop_yarn_home")%>
-export YARN_LOG_DIR=<%=scope.function_hdp_template_var("yarn_log_dir_prefix")%>/$USER
-export YARN_PID_DIR=<%=scope.function_hdp_template_var("yarn_pid_dir_prefix")%>/$USER
-export HADOOP_LIBEXEC_DIR=<%=scope.function_hdp_template_var("hadoop_libexec_dir")%>
-export JAVA_HOME=<%=scope.function_hdp_template_var("::hdp::params::java64_home")%>
-
-# User for YARN daemons
-export HADOOP_YARN_USER=${HADOOP_YARN_USER:-yarn}
-
-# resolve links - $0 may be a softlink
-export YARN_CONF_DIR="${YARN_CONF_DIR:-$HADOOP_YARN_HOME/conf}"
-
-# some Java parameters
-# export JAVA_HOME=/home/y/libexec/jdk1.6.0/
-if [ "$JAVA_HOME" != "" ]; then
-  #echo "run java in $JAVA_HOME"
-  JAVA_HOME=$JAVA_HOME
-fi
-
-if [ "$JAVA_HOME" = "" ]; then
-  echo "Error: JAVA_HOME is not set."
-  exit 1
-fi
-
-JAVA=$JAVA_HOME/bin/java
-JAVA_HEAP_MAX=-Xmx1000m
-
-# For setting YARN specific HEAP sizes please use this
-# Parameter and set appropriately
-YARN_HEAPSIZE=<%=scope.function_hdp_template_var("yarn_heapsize")%>
-
-# check envvars which might override default args
-if [ "$YARN_HEAPSIZE" != "" ]; then
-  JAVA_HEAP_MAX="-Xmx""$YARN_HEAPSIZE""m"
-fi
-
-# Resource Manager specific parameters
-
-# Specify the max Heapsize for the ResourceManager using a numerical value
-# in the scale of MB. For example, to specify an jvm option of -Xmx1000m, set
-# the value to 1000.
-# This value will be overridden by an Xmx setting specified in either YARN_OPTS
-# and/or YARN_RESOURCEMANAGER_OPTS.
-# If not specified, the default value will be picked from either YARN_HEAPMAX
-# or JAVA_HEAP_MAX with YARN_HEAPMAX as the preferred option of the two.
-export YARN_RESOURCEMANAGER_HEAPSIZE=<%=scope.function_hdp_template_var("resourcemanager_heapsize")%>
-
-# Specify the JVM options to be used when starting the ResourceManager.
-# These options will be appended to the options specified as YARN_OPTS
-# and therefore may override any similar flags set in YARN_OPTS
-#export YARN_RESOURCEMANAGER_OPTS=
-
-# Node Manager specific parameters
-
-# Specify the max Heapsize for the NodeManager using a numerical value
-# in the scale of MB. For example, to specify an jvm option of -Xmx1000m, set
-# the value to 1000.
-# This value will be overridden by an Xmx setting specified in either YARN_OPTS
-# and/or YARN_NODEMANAGER_OPTS.
-# If not specified, the default value will be picked from either YARN_HEAPMAX
-# or JAVA_HEAP_MAX with YARN_HEAPMAX as the preferred option of the two.
-export YARN_NODEMANAGER_HEAPSIZE=<%=scope.function_hdp_template_var("nodemanager_heapsize")%>
-
-# Specify the JVM options to be used when starting the NodeManager.
-# These options will be appended to the options specified as YARN_OPTS
-# and therefore may override any similar flags set in YARN_OPTS
-#export YARN_NODEMANAGER_OPTS=
-
-# so that filenames w/ spaces are handled correctly in loops below
-IFS=
-
-
-# default log directory & file
-if [ "$YARN_LOG_DIR" = "" ]; then
-  YARN_LOG_DIR="$HADOOP_YARN_HOME/logs"
-fi
-if [ "$YARN_LOGFILE" = "" ]; then
-  YARN_LOGFILE='yarn.log'
-fi
-
-# default policy file for service-level authorization
-if [ "$YARN_POLICYFILE" = "" ]; then
-  YARN_POLICYFILE="hadoop-policy.xml"
-fi
-
-# restore ordinary behaviour
-unset IFS
-
-
-YARN_OPTS="$YARN_OPTS -Dhadoop.log.dir=$YARN_LOG_DIR"
-YARN_OPTS="$YARN_OPTS -Dyarn.log.dir=$YARN_LOG_DIR"
-YARN_OPTS="$YARN_OPTS -Dhadoop.log.file=$YARN_LOGFILE"
-YARN_OPTS="$YARN_OPTS -Dyarn.log.file=$YARN_LOGFILE"
-YARN_OPTS="$YARN_OPTS -Dyarn.home.dir=$YARN_COMMON_HOME"
-YARN_OPTS="$YARN_OPTS -Dyarn.id.str=$YARN_IDENT_STRING"
-YARN_OPTS="$YARN_OPTS -Dhadoop.root.logger=${YARN_ROOT_LOGGER:-INFO,console}"
-YARN_OPTS="$YARN_OPTS -Dyarn.root.logger=${YARN_ROOT_LOGGER:-INFO,console}"
-if [ "x$JAVA_LIBRARY_PATH" != "x" ]; then
-  YARN_OPTS="$YARN_OPTS -Djava.library.path=$JAVA_LIBRARY_PATH"
-fi
-YARN_OPTS="$YARN_OPTS -Dyarn.policy.file=$YARN_POLICYFILE"

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/yarn.conf.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/yarn.conf.erb b/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/yarn.conf.erb
deleted file mode 100644
index bb0c951..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-yarn/templates/yarn.conf.erb
+++ /dev/null
@@ -1,17 +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.
-
-<%=scope.function_hdp_template_var("yarn_user")%>   - nofile 32768
-<%=scope.function_hdp_template_var("yarn_user")%>   - nproc  65536

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkEnv.sh
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkEnv.sh b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkEnv.sh
deleted file mode 100644
index 07017e1..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkEnv.sh
+++ /dev/null
@@ -1,96 +0,0 @@
-#!/bin/sh
-
-# 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.
-
-# This script should be sourced into other zookeeper
-# scripts to setup the env variables
-
-# We use ZOOCFGDIR if defined,
-# otherwise we use /etc/zookeeper
-# or the conf directory that is
-# a sibling of this script's directory
-if [ "x$ZOOCFGDIR" = "x" ]
-then
-    if [ -d "/etc/zookeeper" ]
-    then
-        ZOOCFGDIR="/etc/zookeeper"
-    else
-        ZOOCFGDIR="$ZOOBINDIR/../conf"
-    fi
-fi
-
-if [ "x$ZOOCFG" = "x" ]
-then
-    ZOOCFG="zoo.cfg"
-fi
-
-ZOOCFG="$ZOOCFGDIR/$ZOOCFG"
-
-if [ -e "$ZOOCFGDIR/zookeeper-env.sh" ]
-then
-    . "$ZOOCFGDIR/zookeeper-env.sh"
-fi
-
-if [ "x${ZOO_LOG_DIR}" = "x" ]
-then
-    ZOO_LOG_DIR="."
-fi
-
-if [ "x${ZOO_LOG4J_PROP}" = "x" ]
-then
-    ZOO_LOG4J_PROP="INFO,CONSOLE"
-fi
-
-#add the zoocfg dir to classpath
-CLASSPATH="$ZOOCFGDIR:$CLASSPATH"
-
-for i in "$ZOOBINDIR"/../src/java/lib/*.jar
-do
-    CLASSPATH="$i:$CLASSPATH"
-done
-
-#make it work in the release
-for i in "$ZOOBINDIR"/../lib/*.jar
-do
-    CLASSPATH="$i:$CLASSPATH"
-done
-
-#make it work in the release
-for i in "$ZOOBINDIR"/../zookeeper-*.jar
-do
-    CLASSPATH="$i:$CLASSPATH"
-done
-
-#make it work for developers
-for d in "$ZOOBINDIR"/../build/lib/*.jar
-do
-   CLASSPATH="$d:$CLASSPATH"
-done
-
-#make it work for developers
-CLASSPATH="$ZOOBINDIR/../build/classes:$CLASSPATH"
-
-case "`uname`" in
-    CYGWIN*) cygwin=true ;;
-    *) cygwin=false ;;
-esac
-
-if $cygwin
-then
-    CLASSPATH=`cygpath -wp "$CLASSPATH"`
-fi
-
-#echo "CLASSPATH=$CLASSPATH"

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkServer.sh
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkServer.sh b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkServer.sh
deleted file mode 100644
index 49ceb4d..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkServer.sh
+++ /dev/null
@@ -1,120 +0,0 @@
-#!/bin/sh
-
-# 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.
-
-#
-# If this scripted is run out of /usr/bin or some other system bin directory
-# it should be linked to and not copied. Things like java jar files are found
-# relative to the canonical path of this script.
-#
-
-# See the following page for extensive details on setting
-# up the JVM to accept JMX remote management:
-# http://java.sun.com/javase/6/docs/technotes/guides/management/agent.html
-# by default we allow local JMX connections
-if [ "x$JMXLOCALONLY" = "x" ]
-then
-    JMXLOCALONLY=false
-fi
-
-if [ "x$JMXDISABLE" = "x" ]
-then
-    echo "JMX enabled by default"
-    # for some reason these two options are necessary on jdk6 on Ubuntu
-    #   accord to the docs they are not necessary, but otw jconsole cannot
-    #   do a local attach
-    ZOOMAIN="-Dcom.sun.management.jmxremote -Dcom.sun.management.jmxremote.local.only=$JMXLOCALONLY org.apache.zookeeper.server.quorum.QuorumPeerMain"
-else
-    echo "JMX disabled by user request"
-    ZOOMAIN="org.apache.zookeeper.server.quorum.QuorumPeerMain"
-fi
-
-# Only follow symlinks if readlink supports it
-if readlink -f "$0" > /dev/null 2>&1
-then
-  ZOOBIN=`readlink -f "$0"`
-else
-  ZOOBIN="$0"
-fi
-ZOOBINDIR=`dirname "$ZOOBIN"`
-
-. "$ZOOBINDIR"/zkEnv.sh
-
-if [ "x$2" != "x" ]
-then
-    ZOOCFG="$ZOOCFGDIR/$2"
-fi
-
-if $cygwin
-then
-    ZOOCFG=`cygpath -wp "$ZOOCFG"`
-    # cygwin has a "kill" in the shell itself, gets confused
-    KILL=/bin/kill
-else
-    KILL=kill
-fi
-
-echo "Using config: $ZOOCFG"
-
-ZOOPIDFILE=$(grep dataDir "$ZOOCFG" | sed -e 's/.*=//')/zookeeper_server.pid
-
-
-case $1 in
-start)
-    echo  "Starting zookeeper ... "
-    $JAVA  "-Dzookeeper.log.dir=${ZOO_LOG_DIR}" "-Dzookeeper.root.logger=${ZOO_LOG4J_PROP}" \
-    -cp "$CLASSPATH" $JVMFLAGS $ZOOMAIN "$ZOOCFG" &
-    /bin/echo -n $! > "$ZOOPIDFILE"
-    echo STARTED
-    ;;
-stop)
-    echo "Stopping zookeeper ... "
-    if [ ! -f "$ZOOPIDFILE" ]
-    then
-    echo "error: could not find file $ZOOPIDFILE"
-    exit 1
-    else
-    $KILL -9 $(cat "$ZOOPIDFILE")
-    rm "$ZOOPIDFILE"
-    echo STOPPED
-    fi
-    ;;
-upgrade)
-    shift
-    echo "upgrading the servers to 3.*"
-    java "-Dzookeeper.log.dir=${ZOO_LOG_DIR}" "-Dzookeeper.root.logger=${ZOO_LOG4J_PROP}" \
-    -cp "$CLASSPATH" $JVMFLAGS org.apache.zookeeper.server.upgrade.UpgradeMain ${@}
-    echo "Upgrading ... "
-    ;;
-restart)
-    shift
-    "$0" stop ${@}
-    sleep 3
-    "$0" start ${@}
-    ;;
-status)
-    STAT=`echo stat | nc localhost $(grep clientPort "$ZOOCFG" | sed -e 's/.*=//') 2> /dev/null| grep Mode`
-    if [ "x$STAT" = "x" ]
-    then
-        echo "Error contacting service. It is probably not running."
-    else
-        echo $STAT
-    fi
-    ;;
-*)
-    echo "Usage: $0 {start|stop|restart|status}" >&2
-
-esac

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkService.sh
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkService.sh b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkService.sh
deleted file mode 100644
index 32dfce4..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkService.sh
+++ /dev/null
@@ -1,26 +0,0 @@
-#!/bin/sh
-#
-#
-# 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.
-#
-#
-
-zkcli_script=$1
-user=$2
-conf_dir=$3
-su - $user -c "source $conf_dir/zookeeper-env.sh ; echo 'ls /' | $zkcli_script"

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkSmoke.sh
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkSmoke.sh b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkSmoke.sh
deleted file mode 100755
index 00350ff..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/files/zkSmoke.sh
+++ /dev/null
@@ -1,78 +0,0 @@
-#!/bin/sh
-#
-#
-# 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.
-#
-#
-
-smoke_script=$1
-smoke_user=$2
-conf_dir=$3
-client_port=$4
-security_enabled=$5
-kinit_path_local=$6
-smoke_user_keytab=$7
-export ZOOKEEPER_EXIT_CODE=0
-test_output_file=/tmp/zkSmoke.out
-errors_expr="ERROR|Exception"
-acceptable_expr="SecurityException"
-zkhosts=` grep "^server\.[[:digit:]]"  $conf_dir/zoo.cfg  | cut -f 2 -d '=' | cut -f 1 -d ':' | tr '\n' ' ' `
-zk_node1=`echo $zkhosts | tr ' ' '\n' | head -n 1`  
-echo "zk_node1=$zk_node1"
-if [[ $security_enabled == "true" ]]; then
-  kinitcmd="$kinit_path_local -kt $smoke_user_keytab $smoke_user"
-  su - $smoke_user -c "$kinitcmd"
-fi
-
-function verify_output() {
-  if [ -f $test_output_file ]; then
-    errors=`grep -E $errors_expr $test_output_file | grep -v $acceptable_expr`
-    if [ "$?" -eq 0 ]; then
-      echo "Error found in the zookeeper smoke test. Exiting."
-      echo $errors
-      exit 1
-    fi
-  fi
-}
-
-# Delete /zk_smoketest znode if exists
-su - $smoke_user -c "source $conf_dir/zookeeper-env.sh ;  echo delete /zk_smoketest | ${smoke_script} -server $zk_node1:$client_port" 2>&1>$test_output_file
-# Create /zk_smoketest znode on one zookeeper server
-su - $smoke_user -c "source $conf_dir/zookeeper-env.sh ; echo create /zk_smoketest smoke_data | ${smoke_script} -server $zk_node1:$client_port" 2>&1>>$test_output_file
-verify_output
-
-for i in $zkhosts ; do
-  echo "Running test on host $i"
-  # Verify the data associated with znode across all the nodes in the zookeeper quorum
-  su - $smoke_user -c "source $conf_dir/zookeeper-env.sh ; echo 'get /zk_smoketest' | ${smoke_script} -server $i:$client_port"
-  su - $smoke_user -c "source $conf_dir/zookeeper-env.sh ; echo 'ls /' | ${smoke_script} -server $i:$client_port"
-  output=$(su - $smoke_user -c "source $conf_dir/zookeeper-env.sh ; echo 'get /zk_smoketest' | ${smoke_script} -server $i:$client_port")
-  echo $output | grep smoke_data
-  if [[ $? -ne 0 ]] ; then
-    echo "Data associated with znode /zk_smoketests is not consistent on host $i"
-    ((ZOOKEEPER_EXIT_CODE=$ZOOKEEPER_EXIT_CODE+1))
-  fi
-done
-
-su - $smoke_user -c "source $conf_dir/zookeeper-env.sh ; echo 'delete /zk_smoketest' | ${smoke_script} -server $zk_node1:$client_port"
-if [[ "$ZOOKEEPER_EXIT_CODE" -ne "0" ]] ; then
-  echo "Zookeeper Smoke Test: Failed" 
-else
-   echo "Zookeeper Smoke Test: Passed" 
-fi
-exit $ZOOKEEPER_EXIT_CODE

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/client.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/client.pp b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/client.pp
deleted file mode 100644
index 23eb15b..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/client.pp
+++ /dev/null
@@ -1,47 +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-zookeeper::client(
-  $service_state = $hdp::params::cluster_client_state
-) inherits hdp::params
-{
-  $package_type = $hdp::params::packages
-
-  if ($service_state == 'no_op') {
-  } elsif  ($service_state in ['installed_and_configured','uninstalled']) {
-      if ($package_type == 'hdp') {
-        $cmd = "ln -s /usr/libexec/zkEnv.sh /usr/bin/zkEnv.sh"
-        $test = "test -e /usr/bin/zkEnv.sh"
-        hdp::exec { $cmd :
-           command => $cmd,
-           unless  => $test,
-           require => Class['hdp-zookeeper']
-        }
-      } 
-      if ($hdp::params::service_exists['hdp-zookeeper'] != true) {
-        class { 'hdp-zookeeper' : 
-         type => 'client',
-         service_state => $service_state
-        } 
-      }
-    } 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-zookeeper/manifests/init.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/init.pp b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/init.pp
deleted file mode 100644
index 6540f96..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/init.pp
+++ /dev/null
@@ -1,142 +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-zookeeper(
-  $type = server,
-  $service_state = $hdp::params::cluster_service_state,
-  $myid = 1,
-  $opts = {}
-) inherits hdp-zookeeper::params 
-{
-
- if ($service_state == 'no_op') {
-   if ($type == 'server') {
-     $hdp::params::service_exists['hdp-zookeeper'] = true
-  }
- } elsif ($service_state in ['running','stopped','installed_and_configured','uninstalled']) { 
-   $zk_user = $hdp-zookeeper::params::zk_user
-   $zk_config_dir = $hdp-zookeeper::params::conf_dir
- 
-   anchor{'hdp-zookeeper::begin':}
-   anchor{'hdp-zookeeper::end':}
-
-   if ($service_state == 'uninstalled') {
-     if ($type == 'server') {
-       $hdp::params::service_exists['hdp-zookeeper'] = true
-    }
-     hdp::package { 'zookeeper':
-       ensure => 'uninstalled'
-     }
-     hdp::directory_recursive_create { $zk_config_dir:
-       service_state => $service_state,
-       force => true
-     }
-
-     if ($type == 'server') {
-        class { 'hdp-zookeeper::service':
-          ensure => $service_state,
-          myid   => $myid
-        }
-       }
-
-     if ($type == 'server') {
-       Anchor['hdp-zookeeper::begin'] -> Hdp::Package['zookeeper'] -> Hdp::Directory_recursive_create[$zk_config_dir] -> Class['hdp-zookeeper::service']  -> Anchor['hdp-zookeeper::end']
-     } else {
-       Anchor['hdp-zookeeper::begin'] -> Hdp::Package['zookeeper'] -> Hdp::Directory_recursive_create[$zk_config_dir] -> Anchor['hdp-zookeeper::end']
-     }
-   } else {
-     hdp::package { 'zookeeper':}
-
-     hdp::user{ 'zk_user':
-       user_name => $zk_user
-     }
-
-     hdp::directory_recursive_create { $zk_config_dir: 
-      service_state => $service_state,
-      force => true,
-      owner => $zk_user
-     }
-
-     hdp-zookeeper::configfile { ['zoo.cfg','zookeeper-env.sh','configuration.xsl']: }
-
-     if ($service_state == 'installed_and_configured') {
-       hdp-zookeeper::configfile { 'log4j.properties': }
-     }
- 
-     if ($hdp::params::update_zk_shell_files == true) {
-       hdp-zookeeper::shell_file{ ['zkServer.sh','zkEnv.sh']: }
-     }
-
-     if ($type == 'server') {
-       $hdp::params::service_exists['hdp-zookeeper'] = true
-       class { 'hdp-zookeeper::service': 
-         ensure => $service_state,
-         myid   => $myid
-       }
-      }
-
-      if ($security_enabled == true) {
-        if ($type == 'server') {
-          hdp-zookeeper::configfile { 'zookeeper_jaas.conf' : }
-          hdp-zookeeper::configfile { 'zookeeper_client_jaas.conf' : }
-        } else {
-          hdp-zookeeper::configfile { 'zookeeper_client_jaas.conf' : }
-        }
-      }
-
-     file { "${zk_config_dir}/zoo_sample.cfg":
-       owner => $zk_user,
-       group => $hdp::params::user_group
-     }
-
-      Anchor['hdp-zookeeper::begin'] -> Hdp::Package['zookeeper'] -> Hdp::User['zk_user'] -> 
-        Hdp::Directory_recursive_create[$zk_config_dir] -> Hdp-zookeeper::Configfile<||> -> File["${zk_config_dir}/zoo_sample.cfg"] -> Anchor['hdp-zookeeper::end']
-      if ($type == 'server') {
-        Hdp::Directory_recursive_create[$zk_config_dir] -> Hdp-zookeeper::Configfile<||> -> Class['hdp-zookeeper::service'] -> Anchor['hdp-zookeeper::end']
-      }
-      if ($hdp::params::update_zk_shell_files == true) {
-        Hdp::Package['zookeeper'] -> Hdp-zookeeper::Shell_file<||> -> Anchor['hdp-zookeeper::end']
-      }
-    }
-  } else {
-    hdp_fail("TODO not implemented yet: service_state = ${service_state}")
-  }
-}
-
-### config files
-define hdp-zookeeper::configfile(
-  $mode = undef
-) 
-{
-  hdp::configfile { "${hdp-zookeeper::params::conf_dir}/${name}":
-    component       => 'zookeeper',
-    owner           => $hdp-zookeeper::params::zk_user,
-    mode            => $mode
-  }
-}
-
-### 
-define hdp-zookeeper::shell_file()
-{
-  file { "${hdp::params::zk_bin}/${name}":
-    source => "puppet:///modules/hdp-zookeeper/${name}", 
-    mode => '0755'
-  }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/params.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/params.pp b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/params.pp
deleted file mode 100644
index 1102bf6..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/params.pp
+++ /dev/null
@@ -1,45 +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-zookeeper::params() inherits hdp::params 
-{
-  $conf_dir = $hdp::params::zk_conf_dir
-  $zk_user = $hdp::params::zk_user
-  $hostname = $hdp::params::hostname
-  
-  $zk_log_dir = hdp_default("zk_log_dir","/var/log/zookeeper")
-  $zk_data_dir = hdp_default("zk_data_dir","/var/lib/zookeeper/data")
-  $zk_pid_dir = hdp_default("zk_pid_dir","/var/run/zookeeper")
-  $zk_pid_file = "${zk_pid_dir}/zookeeper_server.pid"
-  $zk_server_heapsize = hdp_default("zk_server_heapsize","-Xmx1024m")
-
-  $tickTime = hdp_default("tickTime","2000")
-  $initLimit = hdp_default("initLimit","10")
-  $syncLimit = hdp_default("syncLimit","5")
-  $clientPort = hdp_default("clientPort","2181")
-
-  $zk_primary_name = hdp_default("zookeeper_primary_name", "zookeeper")
-  $zk_principal_name = hdp_default("zookeeper_principal_name", "zookeeper/_HOST@EXAMPLE.COM")
-  $zk_principal = regsubst($zk_principal_name, '_HOST', $hostname)
-
-  $zk_keytab_path = hdp_default("zookeeper_keytab_path", "${keytab_path}/zk.service.keytab")
-  $zk_server_jaas_file = hdp_default("zk_server_jaas_conf_file", "${conf_dir}/zookeeper_jaas.conf")
-  $zk_client_jaas_file = hdp_default("zk_client_jaas_conf_file", "${conf_dir}/zookeeper_client_jaas.conf")
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/quorum/service_check.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/quorum/service_check.pp b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/quorum/service_check.pp
deleted file mode 100644
index 159f225..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/quorum/service_check.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-zookeeper::quorum::service_check()
-{
-  include hdp-zookeeper::params
-  $conf_dir = $hdp-zookeeper::params::conf_dir
-  $security_enabled = $hdp::params::security_enabled
-  $smoke_test_user = $hdp::params::smokeuser
-  $kinit_path = $hdp::params::kinit_path_local
-  $smoke_user_keytab = $hdp::params::smokeuser_keytab
-  $smoke_script = $hdp::params::zk_smoke_test_script
-  $quorum_smoke_shell_files = ['zkSmoke.sh']
-
-  anchor { 'hdp-zookeeper::quorum::service_check::begin':}
-
-  hdp-zookeeper::quorum_smoke_shell_file { $quorum_smoke_shell_files: }
-
-  anchor{ 'hdp-zookeeper::quorum::service_check::end':}
-}
-
-define hdp-zookeeper::quorum_smoke_shell_file()
-{
-  $conf_dir = $hdp-zookeeper::params::conf_dir
-  $smoke_test_user = $hdp::params::smokeuser
-  $smoke_script = $hdp::params::zk_smoke_test_script
-  $smoke_user_keytab = $hdp::params::smokeuser_keytab
-  $kinit_path = $hdp::params::kinit_path_local
-  $security_enabled =  $hdp::params::security_enabled
-  file { '/tmp/zkSmoke.sh':
-    ensure => present,
-    source => "puppet:///modules/hdp-zookeeper/zkSmoke.sh",
-    mode => '0755'
-  }
-
-  exec { '/tmp/zkSmoke.sh':
-   command   => "sh /tmp/zkSmoke.sh ${smoke_script} ${smoke_test_user} ${conf_dir} ${::clientPort} ${security_enabled} ${kinit_path} ${smoke_user_keytab}",
-    tries     => 3,
-    try_sleep => 5,
-    require   => File['/tmp/zkSmoke.sh'],
-    path      => '/usr/sbin:/sbin:/usr/local/bin:/bin:/usr/bin',
-    logoutput => "true"
-  }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/service.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/service.pp b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/service.pp
deleted file mode 100644
index 0456520..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/service.pp
+++ /dev/null
@@ -1,96 +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-zookeeper::service(
-  $ensure = $hdp::params::cluster_service_state,
-  $myid
-)
-{
-  include $hdp-zookeeper::params
-  $user = $hdp-zookeeper::params::zk_user
-  $conf_dir = $hdp-zookeeper::params::conf_dir
-  $zk_bin = $hdp::params::zk_bin
-  $cmd = "env ZOOCFGDIR=${conf_dir} ZOOCFG=zoo.cfg ${zk_bin}/zkServer.sh"
-
-  $pid_file = $hdp-zookeeper::params::zk_pid_file  
-
-  if ($ensure == 'running') {
-    $daemon_cmd = "su - ${user} -c  'source ${conf_dir}/zookeeper-env.sh ; ${cmd} start'"
-    $no_op_test = "ls ${pid_file} >/dev/null 2>&1 && ps `cat ${pid_file}` >/dev/null 2>&1"
-    #not using $no_op_test = "su - ${user} -c  '${cmd} status'" because checks more than whether there is a service started up
-  } elsif ($ensure == 'stopped') {
-    $daemon_cmd = "su - ${user} -c  'source ${conf_dir}/zookeeper-env.sh ; ${cmd} stop' && rm -f ${pid_file}"
-    #TODO: put in no_op_test for stopped
-    $no_op_test = undef
-  } else {
-    $daemon_cmd = undef
-  }
-  hdp::directory_recursive_create { $hdp-zookeeper::params::zk_pid_dir: 
-    owner        => $user,
-    context_tag => 'zk_service',
-    service_state => $ensure,
-    force => true
-  }
-  hdp::directory_recursive_create { $hdp-zookeeper::params::zk_log_dir: 
-    owner        => $user,
-    context_tag => 'zk_service',
-    service_state => $ensure,
-    force => true
-  }
-   hdp::directory_recursive_create { $hdp-zookeeper::params::zk_data_dir: 
-    owner        => $user,
-    context_tag => 'zk_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
-    }
-  }
-
-  if ($ensure == 'uninstalled') {
-    anchor{'hdp-zookeeper::service::begin':} -> Hdp::Directory_recursive_create<|context_tag == 'zk_service'|> ->  anchor{'hdp-zookeeper::service::end':}
-  } else {
-    class { 'hdp-zookeeper::set_myid': myid => $myid}
-
-    anchor{'hdp-zookeeper::service::begin':} -> Hdp::Directory_recursive_create<|context_tag == 'zk_service'|> -> 
-    Class['hdp-zookeeper::set_myid'] -> anchor{'hdp-zookeeper::service::end':}
-
-    if ($daemon_cmd != undef) {
-      Class['hdp-zookeeper::set_myid'] -> Hdp::Exec[$daemon_cmd] -> Anchor['hdp-zookeeper::service::end']
-    }
-  }
-}
-
-class hdp-zookeeper::set_myid($myid)
-{
-  file {"${hdp-zookeeper::params::zk_data_dir}/myid":
-    ensure  => file,
-    content => $myid,
-    mode    => 0644,
-  }
-}
-
-
-

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/zookeeper/service_check.pp
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/zookeeper/service_check.pp b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/zookeeper/service_check.pp
deleted file mode 100644
index 283c6ab..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/manifests/zookeeper/service_check.pp
+++ /dev/null
@@ -1,54 +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-zookeeper::zookeeper::service_check()
-{
-  include hdp-zookeeper::params
-  $conf_dir = $hdp-zookeeper::params::conf_dir
-  $smoke_script = $hdp::params::zk_smoke_test_script
-  $security_enabled = $hdp::params::security_enabled
-  $smoke_test_user = $hdp::params::smokeuser
-  $zookeeper_smoke_shell_files = ['zkService.sh']
-  $kinit_path = $hdp::params::kinit_path_local
-  $smoke_user_keytab = $hdp::params::smokeuser_keytab
-  anchor { 'hdp-zookeeper::zookeeper::service_check::begin':}
-
-  hdp-zookeeper::zookeeper_smoke_shell_file { $zookeeper_smoke_shell_files: }
-
-  anchor{ 'hdp-zookeeper::zookeeper::service_check::end':}
-}
-
-define hdp-zookeeper::zookeeper_smoke_shell_file()
-{
-  file { '/tmp/zkService.sh':
-    ensure => present,
-    source => "puppet:///modules/hdp-zookeeper/zkService.sh",
-    mode => '0755'
-  }
-
-  exec { '/tmp/zkService.sh':
-    command   => "sh /tmp/zkSmoke.sh ${smoke_script} ${smoke_test_user} ${conf_dir} ${clientPort} ${security_enabled} ${kinit_path} ${smoke_user_keytab}",
-    tries     => 3,
-    try_sleep => 5,
-    require   => File['/tmp/zkService.sh'],
-    path      => '/usr/sbin:/sbin:/usr/local/bin:/bin:/usr/bin',
-    logoutput => "true"
-  }
-}

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/configuration.xsl.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/configuration.xsl.erb b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/configuration.xsl.erb
deleted file mode 100644
index c003ba2..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/configuration.xsl.erb
+++ /dev/null
@@ -1,24 +0,0 @@
-<?xml version="1.0"?>
-<xsl:stylesheet xmlns:xsl="http://www.w3.org/1999/XSL/Transform" version="1.0">
-<xsl:output method="html"/>
-<xsl:template match="configuration">
-<html>
-<body>
-<table border="1">
-<tr>
- <td>name</td>
- <td>value</td>
- <td>description</td>
-</tr>
-<xsl:for-each select="property">
-  <tr>
-     <td><a name="{name}"><xsl:value-of select="name"/></a></td>
-     <td><xsl:value-of select="value"/></td>
-     <td><xsl:value-of select="description"/></td>
-  </tr>
-</xsl:for-each>
-</table>
-</body>
-</html>
-</xsl:template>
-</xsl:stylesheet>

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/log4j.properties.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/log4j.properties.erb b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/log4j.properties.erb
deleted file mode 100644
index db69564..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/log4j.properties.erb
+++ /dev/null
@@ -1,71 +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.
-#
-#
-#
-
-#
-# ZooKeeper Logging Configuration
-#
-
-# Format is "<default threshold> (, <appender>)+
-
-# DEFAULT: console appender only
-log4j.rootLogger=INFO, CONSOLE
-
-# Example with rolling log file
-#log4j.rootLogger=DEBUG, CONSOLE, ROLLINGFILE
-
-# Example with rolling log file and tracing
-#log4j.rootLogger=TRACE, CONSOLE, ROLLINGFILE, TRACEFILE
-
-#
-# Log INFO level and above messages to the console
-#
-log4j.appender.CONSOLE=org.apache.log4j.ConsoleAppender
-log4j.appender.CONSOLE.Threshold=INFO
-log4j.appender.CONSOLE.layout=org.apache.log4j.PatternLayout
-log4j.appender.CONSOLE.layout.ConversionPattern=%d{ISO8601} - %-5p [%t:%C{1}@%L] - %m%n
-
-#
-# Add ROLLINGFILE to rootLogger to get log file output
-#    Log DEBUG level and above messages to a log file
-log4j.appender.ROLLINGFILE=org.apache.log4j.RollingFileAppender
-log4j.appender.ROLLINGFILE.Threshold=DEBUG
-log4j.appender.ROLLINGFILE.File=zookeeper.log
-
-# Max log file size of 10MB
-log4j.appender.ROLLINGFILE.MaxFileSize=10MB
-# uncomment the next line to limit number of backup files
-#log4j.appender.ROLLINGFILE.MaxBackupIndex=10
-
-log4j.appender.ROLLINGFILE.layout=org.apache.log4j.PatternLayout
-log4j.appender.ROLLINGFILE.layout.ConversionPattern=%d{ISO8601} - %-5p [%t:%C{1}@%L] - %m%n
-
-
-#
-# Add TRACEFILE to rootLogger to get log file output
-#    Log DEBUG level and above messages to a log file
-log4j.appender.TRACEFILE=org.apache.log4j.FileAppender
-log4j.appender.TRACEFILE.Threshold=TRACE
-log4j.appender.TRACEFILE.File=zookeeper_trace.log
-
-log4j.appender.TRACEFILE.layout=org.apache.log4j.PatternLayout
-### Notice we are including log4j's NDC here (%x)
-log4j.appender.TRACEFILE.layout.ConversionPattern=%d{ISO8601} - %-5p [%t:%C{1}@%L][%x] - %m%n

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/zoo.cfg.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/zoo.cfg.erb b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/zoo.cfg.erb
deleted file mode 100644
index e3edc7c..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/zoo.cfg.erb
+++ /dev/null
@@ -1,44 +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.
-#
-#
-#
-
-# The number of milliseconds of each tick
-tickTime=<%=scope.function_hdp_template_var("tickTime")%>
-# The number of ticks that the initial
-# synchronization phase can take
-initLimit=<%=scope.function_hdp_template_var("initLimit")%>
-# The number of ticks that can pass between
-# sending a request and getting an acknowledgement
-syncLimit=<%=scope.function_hdp_template_var("syncLimit")%>
-# the directory where the snapshot is stored.
-dataDir=<%=scope.function_hdp_template_var("zk_data_dir")%>
-# the port at which the clients will connect
-clientPort=<%=scope.function_hdp_template_var("clientPort")%>
-<%(scope.function_hdp_host("zookeeper_hosts")||[]).each_with_index do |host,i|-%>
-server.<%=(i+1).to_s%>=<%=host%>:2888:3888
-<% end -%>
-
-<% if scope.function_hdp_template_var("::hdp::params::security_enabled") == true %>
-authProvider.1=org.apache.zookeeper.server.auth.SASLAuthenticationProvider
-jaasLoginRenew=3600000
-kerberos.removeHostFromPrincipal=true
-kerberos.removeRealmFromPrincipal=true
-<% end %>

http://git-wip-us.apache.org/repos/asf/ambari/blob/3d1171b0/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/zookeeper-env.sh.erb
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/zookeeper-env.sh.erb b/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/zookeeper-env.sh.erb
deleted file mode 100644
index f0c18f7..0000000
--- a/ambari-agent/src/main/puppet/modules/hdp-zookeeper/templates/zookeeper-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.
-export JAVA_HOME=<%=scope.function_hdp_template_var("::hdp::params::java64_home")%>
-export ZOO_LOG_DIR=<%=scope.function_hdp_template_var("zk_log_dir")%>
-export ZOOPIDFILE=<%=scope.function_hdp_template_var("zk_pid_file")%>
-export SERVER_JVMFLAGS=<%=scope.function_hdp_template_var("zk_server_heapsize")%>
-export JAVA=$JAVA_HOME/bin/java
-export CLASSPATH=$CLASSPATH:/usr/share/zookeeper/*
-
-<% if scope.function_hdp_template_var("::hdp::params::security_enabled") == true %>
-export SERVER_JVMFLAGS="$SERVER_JVMFLAGS -Djava.security.auth.login.config=<%=scope.function_hdp_template_var("::hdp-zookeeper::params::zk_server_jaas_file")%>"
-export CLIENT_JVMFLAGS="$CLIENT_JVMFLAGS -Djava.security.auth.login.config=<%=scope.function_hdp_template_var("::hdp-zookeeper::params::zk_client_jaas_file")%>"
-<% end %>

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