You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by sw...@apache.org on 2013/04/20 01:09:53 UTC

svn commit: r1470084 - in /incubator/ambari/trunk: ./ ambari-agent/src/main/puppet/modules/hdp-ganglia/manifests/ ambari-agent/src/main/puppet/modules/hdp-hadoop/manifests/ ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/ ambari-agent/src/main...

Author: swagle
Date: Fri Apr 19 23:09:52 2013
New Revision: 1470084

URL: http://svn.apache.org/r1470084
Log:
AMBARI-1753. Puppet paramter configuration not working as expected. (swagle)

Modified:
    incubator/ambari/trunk/CHANGES.txt
    incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-ganglia/manifests/params.pp
    incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hadoop/manifests/params.pp
    incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/params.pp
    incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/params.pp
    incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/params.pp
    incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-oozie/manifests/params.pp
    incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-templeton/manifests/params.pp
    incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/lib/puppet/parser/functions/hdp_default.rb
    incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/manifests/init.pp
    incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/manifests/params.pp

Modified: incubator/ambari/trunk/CHANGES.txt
URL: http://svn.apache.org/viewvc/incubator/ambari/trunk/CHANGES.txt?rev=1470084&r1=1470083&r2=1470084&view=diff
==============================================================================
--- incubator/ambari/trunk/CHANGES.txt (original)
+++ incubator/ambari/trunk/CHANGES.txt Fri Apr 19 23:09:52 2013
@@ -774,6 +774,8 @@ Trunk (unreleased changes):
 
  BUG FIXES
 
+ AMBARI-1753. Puppet paramter configuration not working as expected. (swagle)
+
  AMBARI-1978. Deploying HDP-1.3.0 results in several alerts - is it related to 
  hard-coded port. Incremental update. (swagle)
 

Modified: incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-ganglia/manifests/params.pp
URL: http://svn.apache.org/viewvc/incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-ganglia/manifests/params.pp?rev=1470084&r1=1470083&r2=1470084&view=diff
==============================================================================
--- incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-ganglia/manifests/params.pp (original)
+++ incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-ganglia/manifests/params.pp Fri Apr 19 23:09:52 2013
@@ -29,7 +29,7 @@ class hdp-ganglia::params() inherits hdp
   $gmetad_user = $hdp::params::gmetad_user
   $gmond_user = $hdp::params::gmond_user
 
-  $webserver_group = hdp_default("hadoop/gangliaEnv/webserver_group","apache")
+  $webserver_group = hdp_default("webserver_group","apache")
   $rrdcached_default_base_dir = "/var/lib/ganglia/rrds"
   $rrdcached_base_dir = hdp_default("rrdcached_base_dir", "/var/lib/ganglia/rrds")
 }

Modified: incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hadoop/manifests/params.pp
URL: http://svn.apache.org/viewvc/incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hadoop/manifests/params.pp?rev=1470084&r1=1470083&r2=1470084&view=diff
==============================================================================
--- incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hadoop/manifests/params.pp (original)
+++ incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hadoop/manifests/params.pp Fri Apr 19 23:09:52 2013
@@ -51,31 +51,31 @@ class hdp-hadoop::params(
 
   ### hadoop-env
   
-  $dtnode_heapsize = hdp_default("hadoop/hadoop-env/dtnode_heapsize","1024m")
-  $ttnode_heapsize = hdp_default("hadoop/hadoop-env/ttnode_heapsize","1024m")
+  $dtnode_heapsize = hdp_default("dtnode_heapsize","1024m")
+  $ttnode_heapsize = hdp_default("ttnode_heapsize","1024m")
 
-  $hadoop_heapsize = hdp_default("hadoop/hadoop-env/hadoop_heapsize","1024m")
+  $hadoop_heapsize = hdp_default("hadoop_heapsize","1024m")
 
-  $hdfs_log_dir_prefix = hdp_default("hadoop/hadoop-env/hdfs_log_dir_prefix","/var/log/hadoop")
+  $hdfs_log_dir_prefix = hdp_default("hdfs_log_dir_prefix","/var/log/hadoop")
 
-  $hadoop_pid_dir_prefix = hdp_default("hadoop/hadoop-env/hadoop_pid_dir_prefix","/var/run/hadoop")
+  $hadoop_pid_dir_prefix = hdp_default("hadoop_pid_dir_prefix","/var/run/hadoop")
   $run_dir = $hadoop_pid_dir_prefix
 
   $namenode_formatted_mark_dir = "${run_dir}/hdfs/namenode/formatted/"
 
-  $jtnode_heapsize = hdp_default("hadoop/hadoop-env/jtnode_heapsize","1024m")
+  $jtnode_heapsize = hdp_default("jtnode_heapsize","1024m")
 
-  $jtnode_opt_maxnewsize = hdp_default("hadoop/hadoop-env/jtnode_opt_maxnewsize","200m")
+  $jtnode_opt_maxnewsize = hdp_default("jtnode_opt_maxnewsize","200m")
 
-  $jtnode_opt_newsize = hdp_default("hadoop/hadoop-env/jtnode_opt_newsize","200m")
+  $jtnode_opt_newsize = hdp_default("jtnode_opt_newsize","200m")
 
-  $namenode_heapsize = hdp_default("hadoop/hadoop-env/namenode_heapsize","1024m")
+  $namenode_heapsize = hdp_default("namenode_heapsize","1024m")
 
-  $namenode_opt_maxnewsize = hdp_default("hadoop/hadoop-env/namenode_opt_maxnewsize","640m")
+  $namenode_opt_maxnewsize = hdp_default("namenode_opt_maxnewsize","640m")
 
-  $namenode_opt_newsize = hdp_default("hadoop/hadoop-env/namenode_opt_newsize","640m")
+  $namenode_opt_newsize = hdp_default("namenode_opt_newsize","640m")
   
-  $hadoop_libexec_dir = hdp_default("yarn/yarn-env/hadoop_libexec_dir","/usr/lib/hadoop/libexec")
+  $hadoop_libexec_dir = hdp_default("hadoop_libexec_dir","/usr/lib/hadoop/libexec")
   
   ### compression related
   if (($hdp::params::lzo_enabled == true) and ($hdp::params::snappy_enabled == true)) {
@@ -97,32 +97,32 @@ class hdp-hadoop::params(
   }
 
   ### core-site
-  $fs_checkpoint_dir = hdp_default("hadoop/core-site/fs_checkpoint_dir","/tmp/hadoop-hdfs/dfs/namesecondary")
+  $fs_checkpoint_dir = hdp_default("core-site/fs.checkpoint.dir","/tmp/hadoop-hdfs/dfs/namesecondary")
 
-  $proxyuser_group = hdp_default("hadoop/core-site/proxyuser_group","users")
+  $proxyuser_group = hdp_default("core-site/proxyuser.group","users")
 
   ### hdfs-site
-  $datanode_du_reserved = hdp_default("hadoop/hdfs-site/datanode_du_reserved",1073741824)
+  $datanode_du_reserved = hdp_default("hdfs-site/datanode.du.reserved",1073741824)
 
-  $dfs_block_local_path_access_user = hdp_default("hadoop/hdfs-site/dfs_block_local_path_access_user","hbase")
+  $dfs_block_local_path_access_user = hdp_default("hdfs-site/dfs.block.local.path.access.user","hbase")
 
   $dfs_data_dir = $hdp::params::dfs_data_dir
 
-  $dfs_datanode_data_dir_perm = hdp_default("hadoop/hdfs-site/dfs_datanode_data_dir_perm",750)
+  $dfs_datanode_data_dir_perm = hdp_default("hdfs-site/dfs.datanode.data.dir.perm",750)
 
-  $dfs_datanode_failed_volume_tolerated = hdp_default("hadoop/hdfs-site/dfs_datanode_failed_volume_tolerated",0)
+  $dfs_datanode_failed_volume_tolerated = hdp_default("hdfs-site/dfs.datanode.failed.volume.tolerated",0)
 
-  $dfs_exclude = hdp_default("hadoop/hdfs-site/dfs_exclude","dfs.exclude")
+  $dfs_exclude = hdp_default("hdfs-site/dfs.exclude","dfs.exclude")
 
-  $dfs_include = hdp_default("hadoop/hdfs-site/dfs_include","dfs.include")
+  $dfs_include = hdp_default("hdfs-site/dfs.include","dfs.include")
   
-  $dfs_name_dir = hdp_default("hadoop/hdfs-site/dfs_name_dir","/tmp/hadoop-hdfs/dfs/name")
+  $dfs_name_dir = hdp_default("hdfs-site/dfs.name.dir","/tmp/hadoop-hdfs/dfs/name")
   
-  $dfs_replication = hdp_default("hadoop/hdfs-site/dfs_replication",3)
+  $dfs_replication = hdp_default("hdfs-site/dfs.replication",3)
 
-  $dfs_support_append = hdp_default("hadoop/hdfs-site/dfs_support_append",true)
+  $dfs_support_append = hdp_default("hdfs-site/dfs.support.append",true)
 
-  $dfs_webhdfs_enabled = hdp_default("hadoop/hdfs-site/dfs_webhdfs_enabled",false)
+  $dfs_webhdfs_enabled = hdp_default("hdfs-site/dfs.webhdfs.enabled",false)
 
 
  ######### mapred #######
@@ -130,47 +130,47 @@ class hdp-hadoop::params(
 
   $mapred_system_dir = '/mapred/system'
 
-  $io_sort_mb = hdp_default("hadoop/mapred-site/io_sort_mb","200")
+  $io_sort_mb = hdp_default("mapred-site/io.sort.mb","200")
 
-  $io_sort_spill_percent = hdp_default("hadoop/mapred-site/io_sort_spill_percent","0.9")
+  $io_sort_spill_percent = hdp_default("mapred-site/io.sort.spill.percent","0.9")
 
-  $mapred_child_java_opts_sz = hdp_default("hadoop/mapred-site/mapred_child_java_opts_sz","-Xmx768m")
+  $mapred_child_java_opts_sz = hdp_default("mapred-site/mapred.child.java.opts.sz","-Xmx768m")
 
-  $mapred_cluster_map_mem_mb = hdp_default("hadoop/mapred-site/mapred_cluster_map_mem_mb","-1")
+  $mapred_cluster_map_mem_mb = hdp_default("mapred-site/mapred.cluster.map.mem.mb","-1")
 
-  $mapred_cluster_max_map_mem_mb = hdp_default("hadoop/mapred-site/mapred_cluster_max_map_mem_mb","-1")
+  $mapred_cluster_max_map_mem_mb = hdp_default("mapred-site/mapred.cluster.max.map.mem.mb","-1")
 
-  $mapred_cluster_max_red_mem_mb = hdp_default("hadoop/mapred-site/mapred_cluster_max_red_mem_mb","-1")
+  $mapred_cluster_max_red_mem_mb = hdp_default("mapred-site/mapred.cluster.max.red.mem.mb","-1")
 
-  $mapred_cluster_red_mem_mb = hdp_default("hadoop/mapred-site/mapred_cluster_red_mem_mb","-1")
+  $mapred_cluster_red_mem_mb = hdp_default("mapred-site/mapred.cluster.red.mem.mb","-1")
 
-  $mapred_hosts_exclude = hdp_default("hadoop/mapred-site/mapred_hosts_exclude","mapred.exclude")
+  $mapred_hosts_exclude = hdp_default("mapred-site/mapred.hosts.exclude","mapred.exclude")
 
-  $mapred_hosts_include = hdp_default("hadoop/mapred-site/mapred_hosts_include","mapred.include")
+  $mapred_hosts_include = hdp_default("mapred-site/mapred.hosts.include","mapred.include")
 
-  $mapred_job_map_mem_mb = hdp_default("hadoop/mapred-site/mapred_job_map_mem_mb","-1")
+  $mapred_job_map_mem_mb = hdp_default("mapred-site/mapred.job.map.mem.mb","-1")
 
-  $mapred_job_red_mem_mb = hdp_default("hadoop/mapred-site/mapred_job_red_mem_mb","-1")
+  $mapred_job_red_mem_mb = hdp_default("mapred-site/mapred.job.red.mem.mb","-1")
 
-  $mapred_jobstatus_dir = hdp_default("hadoop/mapred-site/mapred_jobstatus_dir","file:////mapred/jobstatus")
+  $mapred_jobstatus_dir = hdp_default("mapred-site/mapred.jobstatus.dir","file:////mapred/jobstatus")
 
-  $mapred_local_dir = hdp_default("hadoop/mapred-site/mapred_local_dir","/tmp/hadoop-mapred/mapred/local")
+  $mapred_local_dir = hdp_default("mapred-site/mapred.local.dir","/tmp/hadoop-mapred/mapred/local")
    
-  $mapred_map_tasks_max = hdp_default("hadoop/mapred-site/mapred_map_tasks_max",4)
+  $mapred_map_tasks_max = hdp_default("mapred-site/mapred.map.tasks.max",4)
 
-  $mapred_red_tasks_max = hdp_default("hadoop/mapred-site/mapred_red_tasks_max",4)
+  $mapred_red_tasks_max = hdp_default("mapred-site/mapred.red.tasks.max",4)
 
-  $mapreduce_userlog_retainhours = hdp_default("hadoop/mapred-site/mapreduce_userlog_retainhours",24)
+  $mapreduce_userlog_retainhours = hdp_default("mapred-site/mapreduce.userlog.retainhours",24)
 
-  $maxtasks_per_job = hdp_default("hadoop/mapred-site/maxtasks_per_job","-1")
+  $maxtasks_per_job = hdp_default("mapred-site/maxtasks.per.job","-1")
 
-  $scheduler_name = hdp_default("hadoop/mapred-site/scheduler_name","org.apache.hadoop.mapred.CapacityTaskScheduler")
+  $scheduler_name = hdp_default("mapred-site/scheduler.name","org.apache.hadoop.mapred.CapacityTaskScheduler")
 
   #### health_check
 
   $security_enabled = $hdp::params::security_enabled
 
-  $task_bin_exe = hdp_default("hadoop/health_check/task_bin_exe")
+  $task_bin_exe = hdp_default("task_bin_exe")
 
   $rca_enabled = hdp_default("rca_enabled", false)
   if ($rca_enabled == true) {

Modified: incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/params.pp
URL: http://svn.apache.org/viewvc/incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/params.pp?rev=1470084&r1=1470083&r2=1470084&view=diff
==============================================================================
--- incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/params.pp (original)
+++ incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hbase/manifests/params.pp Fri Apr 19 23:09:52 2013
@@ -25,67 +25,67 @@ class hdp-hbase::params() inherits hdp::
   $hbase_user = $hdp::params::hbase_user
   
   ### hbase-env
-  $hadoop_conf_dir = hdp_default("hadoop/hbase-env/hadoop_conf_dir")
+  $hadoop_conf_dir = hdp_default("hadoop_conf_dir")
   $conf_dir = $hdp::params::hbase_conf_dir
 
-  $hbase_log_dir = hdp_default("hadoop/hbase-env/hbase_log_dir","/var/log/hbase")
+  $hbase_log_dir = hdp_default("hbase_log_dir","/var/log/hbase")
 
-  $hbase_master_heapsize = hdp_default("hadoop/hbase-env/hbase_master_heapsize","1000m")
+  $hbase_master_heapsize = hdp_default("hbase_master_heapsize","1000m")
 
-  $hbase_pid_dir = hdp_default("hadoop/hbase-env/hbase_pid_dir","/var/run/hbase")
+  $hbase_pid_dir = hdp_default("hbase_pid_dir","/var/run/hbase")
 
-  $hbase_regionserver_heapsize = hdp_default("hadoop/hbase-env/hbase_regionserver_heapsize","1000m")
+  $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_hdfs_root_dir = hdp_default("hadoop/hbase-site/hbase_hdfs_root_dir","/apps/hbase/data")
+  $hbase_hdfs_root_dir = hdp_default("hbase-site/hbase.hdfs.root.dir","/apps/hbase/data")
 
-  $hbase_tmp_dir = hdp_default("hadoop/hbase-site/hbase_tmp_dir","$hbase_log_dir")
+  $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("hadoop/hbase-site/hdfs_enable_shortcircuit_read",true)
+  $hdfs_enable_shortcircuit_read = hdp_default("hbase-site/hdfs.enable.shortcircuit.read",true)
 
-  $hdfs_enable_shortcircuit_skipchecksum = hdp_default("hadoop/hbase-site/hdfs_enable_shortcircuit_skipchecksum",false)
+  $hdfs_enable_shortcircuit_skipchecksum = hdp_default("hbase-site/hdfs.enable.shortcircuit.skipchecksum",false)
 
-  $hdfs_support_append = hdp_default("hadoop/hbase-site/hdfs_support_append",true)
+  $hdfs_support_append = hdp_default("hbase-site/hdfs.support.append",true)
 
-  $hfile_blockcache_size = hdp_default("hadoop/hbase-site/hfile_blockcache_size","0.25")
+  $hfile_blockcache_size = hdp_default("hbase-site/hfile.blockcache.size","0.25")
 
-  $hfile_max_keyvalue_size = hdp_default("hadoop/hbase-site/hfile_max_keyvalue_size",10485760)
+  $hfile_max_keyvalue_size = hdp_default("hbase-site/hfile.max.keyvalue.size",10485760)
 
-  $zookeeper_sessiontimeout = hdp_default("hadoop/hbase-site/zookeeper_sessiontimeout",60000)
+  $zookeeper_sessiontimeout = hdp_default("hbase-site/zookeeper.sessiontimeout",60000)
 
-  $client_scannercaching = hdp_default("hadoop/hbase-site/client_scannercaching",100)
+  $client_scannercaching = hdp_default("hbase-site/client.scannercaching",100)
 
-  $hstore_blockingstorefiles = hdp_default("hadoop/hbase-site/hstore_blockingstorefiles",7)
+  $hstore_blockingstorefiles = hdp_default("hbase-site/hstore.blockingstorefiles",7)
 
-  $hstore_compactionthreshold = hdp_default("hadoop/hbase-site/hstore_compactionthreshold",3)
+  $hstore_compactionthreshold = hdp_default("hbase-site/hstore.compactionthreshold",3)
 
-  $hstorefile_maxsize = hdp_default("hadoop/hbase-site/hstorefile_maxsize",1073741824)
+  $hstorefile_maxsize = hdp_default("hbase-site/hstorefile.maxsize",1073741824)
 
-  $hregion_blockmultiplier = hdp_default("hadoop/hbase-site/hregion_blockmultiplier",2)
+  $hregion_blockmultiplier = hdp_default("hbase-site/hregion.blockmultiplier",2)
 
-  $hregion_memstoreflushsize = hdp_default("hadoop/hbase-site/hregion_memstoreflushsize",134217728)
+  $hregion_memstoreflushsize = hdp_default("hbase-site/hregion.memstoreflushsize",134217728)
 
-  $regionserver_handlers = hdp_default("hadoop/hbase-site/regionserver_handlers", 30)
+  $regionserver_handlers = hdp_default("hbase-site/regionserver.handlers", 30)
 
-  $hregion_majorcompaction = hdp_default("hadoop/hbase-site/hregion_majorcompaction", 86400000)
+  $hregion_majorcompaction = hdp_default("hbase-site/hregion.majorcompaction", 86400000)
 
-  $preloaded_mastercoprocessor_classes = hdp_default("hadoop/hbase-site/preloaded_mastercoprocessor_classes")
+  $preloaded_mastercoprocessor_classes = hdp_default("hbase-site/preloaded.mastercoprocessor.classes")
 
-  $preloaded_regioncoprocessor_classes = hdp_default("hadoop/hbase-site/preloaded_regioncoprocessor_classes")
+  $preloaded_regioncoprocessor_classes = hdp_default("hbase-site/preloaded.regioncoprocessor.classes")
 
-  $regionserver_memstore_lab = hdp_default("hadoop/hbase-site/regionserver_memstore_lab",true)
+  $regionserver_memstore_lab = hdp_default("hbase-site/regionserver.memstore.lab",true)
 
-  $regionserver_memstore_lowerlimit = hdp_default("hadoop/hbase-site/regionserver_memstore_lowerlimit","0.35")
+  $regionserver_memstore_lowerlimit = hdp_default("hbase-site/regionserver.memstore.lowerlimit","0.35")
 
-  $regionserver_memstore_upperlimit = hdp_default("hadoop/hbase-site/regionserver_memstore_upperlimit","0.4")
+  $regionserver_memstore_upperlimit = hdp_default("hbase-site/regionserver.memstore.upperlimit","0.4")
 
-  $hbase_client_jaas_config_file = hdp_default("hadoop/hbase-site/hbase_client_jaas_config_file", "${conf_dir}/hbase_client_jaas.conf")
-  $hbase_master_jaas_config_file = hdp_default("hadoop/hbase-site/hbase_master_jaas_config_file", "${conf_dir}/hbase_master_jaas.conf")
-  $hbase_regionserver_jaas_config_file = hdp_default("hadoop/hbase-site/hbase_regionserver_jaas_config_file", "${conf_dir}/hbase_regionserver_jaas.conf")
+  $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}")

Modified: incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/params.pp
URL: http://svn.apache.org/viewvc/incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/params.pp?rev=1470084&r1=1470083&r2=1470084&view=diff
==============================================================================
--- incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/params.pp (original)
+++ incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hcat/manifests/params.pp Fri Apr 19 23:09:52 2013
@@ -26,11 +26,11 @@ class hdp-hcat::params() inherits hdp::p
   $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("hadoop/hcat-env/hcat_dbroot",$hcat_lib)
+  $hcat_dbroot = hdp_default("hcat_dbroot",$hcat_lib)
 
-  $hcat_log_dir = hdp_default("hadoop/hcat-env/hcat_log_dir","/var/log/hcatalog")
+  $hcat_log_dir = hdp_default("hcat_log_dir","/var/log/hcatalog")
 
-  $hcat_pid_dir = hdp_default("hadoop/hcat-env/hcat_pid_dir","/var/run/hcatalog")
+  $hcat_pid_dir = hdp_default("hcat_pid_dir","/var/run/hcatalog")
 
   $keytab_path = hdp_default("keytab_path","/etc/security/keytabs")
 }

Modified: incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/params.pp
URL: http://svn.apache.org/viewvc/incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/params.pp?rev=1470084&r1=1470083&r2=1470084&view=diff
==============================================================================
--- incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/params.pp (original)
+++ incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-hive/manifests/params.pp Fri Apr 19 23:09:52 2013
@@ -22,8 +22,8 @@ class hdp-hive::params() inherits hdp::p
 {
 
   #TODO: will move to globals
-  $hive_metastore_user_name = hdp_default("hadoop/hive-site/hive_metastore_user_name","dbusername")
-  $hive_metastore_user_passwd = hdp_default("hadoop/hive-site/hive_metastore_user_passwd","dbpassword")
+  $hive_metastore_user_name = hdp_default("hive_metastore_user_name","dbusername")
+  $hive_metastore_user_passwd = hdp_default("hive_metastore_user_passwd","dbpassword")
 
   ### users
   $hive_user = $hdp::params::hive_user
@@ -44,16 +44,16 @@ class hdp-hive::params() inherits hdp::p
   ### hive-env
   $hive_conf_dir = $hdp::params::hive_conf_dir
 
-  $hive_dbroot = hdp_default("hadoop/hive-env/hive_dbroot",$hive_lib)
+  $hive_dbroot = hdp_default("hive_dbroot",$hive_lib)
 
-  $hive_log_dir = hdp_default("hadoop/hive-env/hive_log_dir","/var/log/hive")
+  $hive_log_dir = hdp_default("hive_log_dir","/var/log/hive")
 
-  $hive_pid_dir = hdp_default("hadoop/hive-env/hive_pid_dir","/var/run/hive")
-  $hive_pid = hdp_default("hadoop/hive-env/hive_pid","hive-server.pid")
+  $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("hadoop/hive-site/hive_database_name","hive")
+  $hive_database_name = hdp_default("hive-site/hive.database.name","hive")
 
   if ($hdp::params::security_enabled == true) {
     $hive_metastore_sasl_enabled = true
@@ -64,7 +64,7 @@ class hdp-hive::params() inherits hdp::p
   $keytab_path = hdp_default("keytab_path","/etc/security/keytabs")
 
   #TODO: using instead hive_server_host in hdp::params 
-  #$hive_metastore_server_host = hdp_default("hadoop/hive-site/hive_metastore_server_host")
+  #$hive_metastore_server_host = hdp_default("hive-site/hive.metastore.server.host")
   
   ###mysql connector
   $download_url = $hdp::params::gpl_artifacts_download_url

Modified: incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-oozie/manifests/params.pp
URL: http://svn.apache.org/viewvc/incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-oozie/manifests/params.pp?rev=1470084&r1=1470083&r2=1470084&view=diff
==============================================================================
--- incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-oozie/manifests/params.pp (original)
+++ incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-oozie/manifests/params.pp Fri Apr 19 23:09:52 2013
@@ -32,23 +32,23 @@ class hdp-oozie::params() inherits hdp::
   $hadoop_prefix = hdp_default("hadoop_prefix","/usr")
 
   ### oozie-env
-  $oozie_log_dir = hdp_default("hadoop/oozie-env/oozie_log_dir","/var/log/oozie")
+  $oozie_log_dir = hdp_default("oozie_log_dir","/var/log/oozie")
 
   $oozie_pid_dir = hdp_default("oozie_pid_dir","/var/run/oozie/")
-  $oozie_pid_file = hdp_default("hadoop/oozie-env/oozie_pid_file","$oozie_pid_dir/oozie.pid")
+  $oozie_pid_file = hdp_default("oozie_pid_file","$oozie_pid_dir/oozie.pid")
 
-  $oozie_data_dir = hdp_default("hadoop/oozie-env/oozie_data_dir","/var/data/oozie")
+  $oozie_data_dir = hdp_default("oozie_data_dir","/var/data/oozie")
 
-  $oozie_tmp_dir = hdp_default("hadoop/oozie-env/oozie_tmp_dir","/var/tmp/oozie")
+  $oozie_tmp_dir = hdp_default("oozie_tmp_dir","/var/tmp/oozie")
 
-  $oozie_lib_dir = hdp_default("hadoop/oozie-env/oozie_lib_dir","/var/lib/oozie/")
+  $oozie_lib_dir = hdp_default("oozie_lib_dir","/var/lib/oozie/")
   
-  $oozie_webapps_dir = hdp_default("hadoop/oozie-env/oozie_webapps_dir","/var/lib/oozie/oozie-server/webapps/")
+  $oozie_webapps_dir = hdp_default("oozie_webapps_dir","/var/lib/oozie/oozie-server/webapps/")
   
   ### oozie-site
   $keytab_path = hdp_default("keytab_path","/etc/security/keytabs")
-  $oozie_service_keytab = hdp_default("hadoop/oozie-site/oozie.service.HadoopAccessorService.keytab.file", "${keytab_path}/oozie.service.keytab")
-  $oozie_principal = hdp_default("hadoop/oozie-site/oozie.service.HadoopAccessorService.kerberos.principal", "oozie")
+  $oozie_service_keytab = hdp_default("oozie-site/oozie.service.HadoopAccessorService.keytab.file", "${keytab_path}/oozie.service.keytab")
+  $oozie_principal = hdp_default("oozie-site/oozie.service.HadoopAccessorService.kerberos.principal", "oozie")
 
   if ($security_enabled == true) {
     $oozie_sasl_enabled = "true"

Modified: incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-templeton/manifests/params.pp
URL: http://svn.apache.org/viewvc/incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-templeton/manifests/params.pp?rev=1470084&r1=1470083&r2=1470084&view=diff
==============================================================================
--- incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-templeton/manifests/params.pp (original)
+++ incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp-templeton/manifests/params.pp Fri Apr 19 23:09:52 2013
@@ -31,31 +31,30 @@ class hdp-templeton::params() inherits h
   $src_hive_tar_name = hdp_default("src_hive_tar_name","hive.tar.gz")
 
   ### templeton-env
-  $conf_dir = hdp_default("hadoop/templeton-env/conf_dir","/etc/hcatalog/conf")
+  $conf_dir = hdp_default("conf_dir","/etc/hcatalog/conf")
 
   ### templeton-env
-  $templeton_log_dir = hdp_default("hadoop/templeton-env/templeton_log_dir","/var/log/webhcat")
+  $templeton_log_dir = hdp_default("templeton_log_dir","/var/log/webhcat")
 
-  $templeton_pid_dir = hdp_default("hadoop/templeton-env/templeton_pid_dir","/var/run/webhcat")
+  $templeton_pid_dir = hdp_default("templeton_pid_dir","/var/run/webhcat")
 
-#  $templeton_jar_name= hdp_default("hadoop/templeton-env/templeton_jar_name","templeton-0.1.4.14.jar")
+#  $templeton_jar_name= hdp_default("templeton_jar_name","templeton-0.1.4.14.jar")
  
-#  $hadoop_prefix = hdp_default("hadoop/templeton-env/hadoop_prefix","/usr")
-#  $hive_prefix = hdp_default("hadoop/templeton-env/hive_prefix","/usr")
+#  $hadoop_prefix = hdp_default("hadoop_prefix","/usr")
+#  $hive_prefix = hdp_default("hive_prefix","/usr")
   
   ### templeton-site
-  $hadoop_conf_dir = hdp_default("hadoop/templeton-site/hadoop_conf_dir")
-  $templeton_jar = hdp_default("hadoop/templeton-site/templeton_jar","/usr/lib/hcatalog/share/webhcat/svr/webhcat.jar")
-  $zookeeper_jar = hdp_default("hadoop/templeton-site/zookeeper_jar","/usr/lib/zookeeper/zookeeper.jar")
-  $pig_tar_gz = hdp_default("hadoop/templeton-site/pig_tar_gz","$dest_pig_tar_name")
-  $pig_tar_name_hdfs = hdp_default("hadoop/templeton-site/pig_tar_name_hdfs","pig-0.9.2.14")
-
-  $hive_tar_gz = hdp_default("hadoop/templeton-site/hive_tar_gz","$dest_hive_tar_name")
-  $hive_tar_gz_name = hdp_default("hadoop/templeton-site/hive_tar_gz_name","hive-0.9.0.14")
-  $hive_metastore_sasl_enabled = hdp_default("hadoop/templeton-site/hive_metastore_sasl_enabled",false)
-
-  $templeton_metastore_principal = hdp_default("hadoop/templeton-site/templeton_metastore_principal")
+  $hadoop_conf_dir = hdp_default("webhcat-site/templeton.hadoop.conf.dir")
+  $templeton_jar = hdp_default("webhcat-site/templeton.jar","/usr/lib/hcatalog/share/webhcat/svr/webhcat.jar")
+  $zookeeper_jar = hdp_default("webhcat-site/zookeeper.jar","/usr/lib/zookeeper/zookeeper.jar")
+  $pig_tar_gz = hdp_default("webhcat-site/pig.tar.gz","$dest_pig_tar_name")
+  $pig_tar_name_hdfs = hdp_default("webhcat-site/pig.tar.name.hdfs","pig-0.9.2.14")
+
+  $hive_tar_gz = hdp_default("webhcat-site/hive.tar.gz","$dest_hive_tar_name")
+  $hive_tar_gz_name = hdp_default("webhcat-site/hive.tar.gz.name","hive-0.9.0.14")
+  $hive_metastore_sasl_enabled = hdp_default("webhcat-site/hive.metastore.sasl.enabled",false)
 
+  $templeton_metastore_principal = hdp_default("webhcat-site/templeton.metastore.principal")
   $keytab_path = $hdp::params::keytab_path
   
 }

Modified: incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/lib/puppet/parser/functions/hdp_default.rb
URL: http://svn.apache.org/viewvc/incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/lib/puppet/parser/functions/hdp_default.rb?rev=1470084&r1=1470083&r2=1470084&view=diff
==============================================================================
--- incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/lib/puppet/parser/functions/hdp_default.rb (original)
+++ incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/lib/puppet/parser/functions/hdp_default.rb Fri Apr 19 23:09:52 2013
@@ -22,9 +22,19 @@ module Puppet::Parser::Functions
   newfunction(:hdp_default, :type => :rvalue) do |args|
     args = function_hdp_args_as_array(args)
     scoped_var_name = args[0]
-    var_name = scoped_var_name.split("/").last
-    default = args[1]
-    val = lookupvar("::#{var_name}")
+    var_parts = scoped_var_name.split("/")
+    var_name = var_parts.last    
+    default = args[1]    
+    val = lookupvar("::#{var_name}")    
+    # Lookup value inside a hash map.
+    if var_parts.length > 1 and function_hdp_is_empty(val) and function_hdp_is_empty(lookupvar("configuration")) == false and function_hdp_is_empty(lookupvar("#{var_parts[-2]}")) == false
+      keyHash = var_parts[-2]
+      puts "keyHash  #{keyHash}"      
+      hashMap = lookupvar("#{keyHash}") 
+      puts "hashMap #{hashMap}"
+      puts "default #{default}"   
+      val = hashMap.fetch(var_name, default.to_s)      
+    end
     # To workaround string-boolean comparison issues,
     # ensure that we return boolean result if the default value
     # is also boolean

Modified: incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/manifests/init.pp
URL: http://svn.apache.org/viewvc/incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/manifests/init.pp?rev=1470084&r1=1470083&r2=1470084&view=diff
==============================================================================
--- incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/manifests/init.pp (original)
+++ incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/manifests/init.pp Fri Apr 19 23:09:52 2013
@@ -53,8 +53,8 @@ class hdp(
     $jobhistory_port = hdp_get_port_from_url($mapred-site["mapreduce.history.server.http.address"],"51111")
   }
 
-  $hbase_master_port = hdp_default("hadoop/hbase-site/hbase.master.info.port","60010")
-  $hbase_rs_port = hdp_default("hadoop/hbase-site/hbase.regionserver.info.port","60030")
+  $hbase_master_port = hdp_default("hbase-site/hbase.master.info.port","60010")
+  $hbase_rs_port = hdp_default("hbase-site/hbase.regionserver.info.port","60030")
   
   #TODO: think not needed and also there seems to be a puppet bug around this and ldap
   class { 'hdp::snmp': service_state => 'running'}

Modified: incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/manifests/params.pp
URL: http://svn.apache.org/viewvc/incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/manifests/params.pp?rev=1470084&r1=1470083&r2=1470084&view=diff
==============================================================================
--- incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/manifests/params.pp (original)
+++ incubator/ambari/trunk/ambari-agent/src/main/puppet/modules/hdp/manifests/params.pp Fri Apr 19 23:09:52 2013
@@ -25,6 +25,19 @@ class hdp::params()
   $NOTHING='NOTHING'
   $NOBODY_USER='nobody'
 
+  ###### environment variables
+  if (hdp_is_empty($configuration) == false) {
+    $core-site = $configuration['core-site']
+    $hbase-site = $configuration['hbase-site']
+    $hdfs-site = $configuration['hdfs-site']
+    $hive-site = $configuration['hive-site']
+    $hue-site = $configuration['hue-site']
+    $mapred-site = $configuration['mapred-site']
+    $oozie-site = $configuration['oozie-site']
+    $sqoop-site = $configuration['sqoop-site']
+    $webhcat-site = $configuration['webhcat-site']
+  }
+
   ##### global state defaults ####
   $cluster_service_state = hdp_default("cluster_service_state","running")
   $cluster_client_state = hdp_default("cluster_client_state","installed_and_configured")
@@ -170,7 +183,7 @@ class hdp::params()
   ############ Hdfs apps directories
   $hive_apps_whs_dir = hdp_default("hive_apps_whs_dir", "/apps/hive/warehouse")
   $webhcat_apps_dir = hdp_default("webhcat_apps_dir", "/apps/webhcat")
-  $hbase_hdfs_root_dir = hdp_default("hadoop/hbase-site/hbase_hdfs_root_dir","/apps/hbase/data")
+  $hbase_hdfs_root_dir = hdp_default("hbase-site/hbase.hdfs.root.dir","/apps/hbase/data")
 
   $user_group = hdp_default("user_group","hadoop")
 
@@ -225,7 +238,7 @@ class hdp::params()
   $exec_path = ["/bin","/usr/bin", "/usr/sbin"]
 
    #### params used on multiple modules
-  $dfs_data_dir = hdp_default("hadoop/hdfs-site/dfs_data_dir","/tmp/hadoop-hdfs/dfs/data")
+  $dfs_data_dir = hdp_default("hdfs-site/dfs.data.dir","/tmp/hadoop-hdfs/dfs/data")
 
   ### artifact dir
   $artifact_dir = hdp_default("artifact_dir","/tmp/HDP-artifacts/")
@@ -630,4 +643,3 @@ class hdp::params()
   $is_jtnode_master   = $::fqdn in $jtnode_host
   $is_hbase_master    = $::fqdn in $hbase_master_hosts
 }
-