You are viewing a plain text version of this content. The canonical link for it is here.
Posted to dev@ambari.apache.org by "Vladimir Tkhir (JIRA)" <ji...@apache.org> on 2013/09/12 15:22:52 UTC

[jira] [Updated] (AMBARI-3195) WebHCat install and start fails when adding service after initial cluster install

     [ https://issues.apache.org/jira/browse/AMBARI-3195?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

Vladimir Tkhir updated AMBARI-3195:
-----------------------------------

    Attachment: AMBARI-3195.patch

Attached patch
                
> WebHCat install and start fails when adding service after initial cluster install
> ---------------------------------------------------------------------------------
>
>                 Key: AMBARI-3195
>                 URL: https://issues.apache.org/jira/browse/AMBARI-3195
>             Project: Ambari
>          Issue Type: Bug
>          Components: agent
>            Reporter: Vladimir Tkhir
>            Assignee: Vladimir Tkhir
>         Attachments: AMBARI-3195.patch
>
>
> Steps to reproduce:
> # install cluster HDFS and YARN(MapReduce)
> # add Hive, HCatalog, WebHCat services with following REST API calls:
> {code}
> curl -u admin:admin -X POST -d '[{"ServiceInfo":{"service_name":"HIVE"}},{"ServiceInfo":{"service_name":"HCATALOG"}},{"ServiceInfo":{"service_name":"WEBHCAT"}}]' http://host1:8080/api/v1/clusters/cl/services
> curl -u admin:admin -X PUT -d '{"Clusters":{"desired_configs":{"type":"global","tag":"version3","properties":{"dfs_namenode_name_dir":"/hadoop/hdfs/namenode","namenode_heapsize":"1024m","namenode_opt_newsize":"200m","dfs_namenode_checkpoint_dir":"/hadoop/hdfs/namesecondary","dfs_datanode_data_dir":"/hadoop/hdfs/data","dtnode_heapsize":"1024m","dfs_datanode_failed_volume_tolerated":"0","dfs_webhdfs_enabled":"true","hadoop_heapsize":"1024","datanode_du_reserved":"1","dfs_namenode_checkpoint_period":"21600","fs_checkpoint_size":"0.5","hdfs_log_dir_prefix":"/var/log/hadoop","hadoop_pid_dir_prefix":"/var/run/hadoop","namenode_opt_maxnewsize":"640m","dfs_exclude":"dfs.exclude","dfs_replication":"3","dfs_block_local_path_access_user":"hbase","dfs_datanode_data_dir_perm":"750","security_enabled":"false","namenode_formatted_mark_dir":"/var/run/hadoop/hdfs/namenode/formatted/","hcat_conf_dir":"","hdfs_enable_shortcircuit_read":"true","yarn_heapsize":"1024","resourcemanager_heapsize":"1024","nodemanager_heapsize":"1024","yarn_log_dir_prefix":"/var/log/hadoop-yarn","yarn_pid_dir_prefix":"/var/run/hadoop-yarn","yarn_nodemanager_local-dirs":"/hadoop/yarn","mapreduce_tasktracker_map_tasks_maximum":"4","mapreduce_map_memory_mb":"1536","mapreduce_reduce_memory_mb":"2048","mapreduce_task_io_sort_mb":"200","mapreduce_userlog_retainhours":"24","maxtasks_per_job":"-1","scheduler_name":"org.apache.hadoop.mapred.CapacityTaskScheduler","mapreduce_jobtracker_system_dir":"/mapred/system","mapred_log_dir_prefix":"/var/log/hadoop-mapreduce","mapred_pid_dir_prefix":"/var/run/hadoop-mapreduce","mapred_hosts_include":"mapred.include","task_controller":"org.apache.hadoop.mapred.DefaultTaskController","mapred_hosts_exclude":"mapred.exclude","mapred_jobstatus_dir":"file:////mapred/jobstatus","hive_ambari_database":"MySQL","hive_database":"New MySQL Database","hive_hostname":"host1","hive_database_name":"hive","hive_metastore_user_name":"hive","hive_metastore_user_passwd":"test","hive_jdbc_connection_url":"jdbc:mysql://host1/hive?createDatabaseIfNotExist=true","hive_metastore_port":"9083","hive_lib":"/usr/lib/hive/lib/","hive_conf_dir":"/etc/hive/conf","hive_dbroot":"/usr/lib/hive/lib","hive_log_dir":"/var/log/hive","hive_pid_dir":"/var/run/hive","mysql_connector_url":"${download_url}/mysql-connector-java-5.1.18.zip","hive_aux_jars_path":"/usr/lib/hcatalog/share/hcatalog/hcatalog-core.jar","hcat_log_dir":"/var/log/webhcat","hcat_pid_dir":"/var/run/webhcat","hbase_conf_dir":"/etc/hbase","proxyuser_group":"users","dfs_datanode_address":"50010","dfs_datanode_http_address":"50075","gpl_artifacts_download_url":"","apache_artifacts_download_url":"","ganglia_runtime_dir":"/var/run/ganglia/hdp","java64_home":"/usr/jdk64/jdk1.6.0_31","run_dir":"/var/run/hadoop","hadoop_conf_dir":"/etc/hadoop/conf","hdfs_user":"hdfs","mapred_user":"mapred","yarn_user":"yarn","hbase_user":"hbase","hive_user":"hive","hcat_user":"hcat","webhcat_user":"hcat","oozie_user":"oozie","zk_user":"zookeeper","gmetad_user":"nobody","gmond_user":"nobody","nagios_user":"nagios","nagios_group":"nagios","smokeuser":"ambari-qa","user_group":"hadoop","rrdcached_base_dir":"/var/lib/ganglia/rrds","hive_database_type":"mysql","hive_jdbc_driver":"com.mysql.jdbc.Driver"}}}}' http://host1:8080/api/v1/clusters/cl
> curl -u admin:admin -X PUT -d '{"Clusters":{"desired_configs":{"type":"hive-site","tag":"version1","properties":{"fs.file.impl.disable.cache":"true","fs.hdfs.impl.disable.cache":"true","hadoop.clientside.fs.operations":"true","hive.auto.convert.join":"true","hive.auto.convert.join.noconditionaltask":"true","hive.auto.convert.join.noconditionaltask.size":"1000000000","hive.auto.convert.sortmerge.join":"true","hive.auto.convert.sortmerge.join.noconditionaltask":"true","hive.enforce.bucketing":"true","hive.enforce.sorting":"true","hive.map.aggr":"true","hive.mapjoin.bucket.cache.size":"10000","hive.mapred.reduce.tasks.speculative.execution":"false","hive.metastore.cache.pinobjtypes":"Table,Database,Type,FieldSchema,Order","hive.metastore.client.socket.timeout":"60","hive.metastore.execute.setugi":"true","hive.metastore.local":"false","hive.metastore.warehouse.dir":"/apps/hive/warehouse","hive.optimize.bucketmapjoin":"true","hive.optimize.bucketmapjoin.sortedmerge":"true","hive.optimize.index.filter":"true","hive.optimize.mapjoin.mapreduce":"true","hive.optimize.reducededuplication":"true","hive.optimize.reducededuplication.min.reducer":"1","hive.security.authorization.enabled":"false","hive.security.authorization.manager":"org.apache.hadoop.hive.ql.security.authorization.DefaultHiveAuthorizationProvider","hive.semantic.analyzer.factory.impl":"org.apache.hivealog.cli.HCatSemanticAnalyzerFactory","hive.server2.enable.doAs":"true","hive.vectorized.execution.enabled":"false","javax.jdo.option.ConnectionDriverName":"com.mysql.jdbc.Driver","javax.jdo.option.ConnectionUserName":"hive","javax.jdo.option.ConnectionPassword":"test","javax.jdo.option.ConnectionURL":"jdbc:mysql://host1/hive?createDatabaseIfNotExist=true","hive.metastore.uris":"thrift://host1:9083"}}}}' http://host1:8080/api/v1/clusters/cl
> curl -u admin:admin -X PUT -d '{"Clusters":{"desired_configs":{"type":"webhcat-site","tag":"version1","properties":{"templeton.exec.timeout":"60000","templeton.hadoop":"/usr/bin/hadoop","templeton.hadoop.conf.dir":"/etc/hadoop/conf","templeton.hcat":"/usr/bin/hcat","templeton.hive.archive":"hdfs:///apps/webhcat/hive.tar.gz","templeton.hive.path":"hive.tar.gz/hive/bin/hive","templeton.jar":"/usr/lib/hcatalog/share/webhcat/svr/webhcat.jar","templeton.libjars":"/usr/lib/zookeeper/zookeeper.jar","templeton.override.enabled":"false","templeton.pig.archive":"hdfs:///apps/webhcat/pig.tar.gz","templeton.pig.path":"pig.tar.gz/pig/bin/pig","templeton.port":"50111","templeton.storage.class":"org.apache.hcatalog.templeton.tool.ZooKeeperStorage","templeton.streaming.jar":"hdfs:///apps/webhcat/hadoop-streaming.jar","templeton.hive.properties":"hive.metastore.local=false,hive.metastore.uris=thrift://host1:9083,hive.metastore.sasl.enabled=yes,hive.metastore.execute.setugi=true,hive.metastore.warehouse.dir=/apps/hive/warehouse","templeton.zookeeper.hosts":"null"}}}}' http://host1:8080/api/v1/clusters/cl
> curl -u admin:admin -X POST -d '{"components":[{"ServiceComponentInfo":{"component_name":"HIVE_SERVER"}},{"ServiceComponentInfo":{"component_name":"HIVE_METASTORE"}},{"ServiceComponentInfo":{"component_name":"HIVE_CLIENT"}},{"ServiceComponentInfo":{"component_name":"MYSQL_SERVER"}}]}' http://host1:8080/api/v1/clusters/cl/services?ServiceInfo/service_name=HIVE
> curl -u admin:admin -X POST -d '{"components":[{"ServiceComponentInfo":{"component_name":"HCAT"}}]}' http://host1:8080/api/v1/clusters/cl/services?ServiceInfo/service_name=HCATALOG
> curl -u admin:admin -X POST -d '{"components":[{"ServiceComponentInfo":{"component_name":"WEBHCAT_SERVER"}}]}' http://host1:8080/api/v1/clusters/cl/services?ServiceInfo/service_name=WEBHCAT
> curl -u admin:admin -X POST -d '{"host_components":[{"HostRoles":{"component_name":"HIVE_SERVER"}}]}' http://host1:8080/api/v1/clusters/cl/hosts?Hosts/host_name=host1
> curl -u admin:admin -X POST -d '{"host_components":[{"HostRoles":{"component_name":"HIVE_METASTORE"}}]}' http://host1:8080/api/v1/clusters/cl/hosts?Hosts/host_name=host1
> curl -u admin:admin -X POST -d '{"host_components":[{"HostRoles":{"component_name":"WEBHCAT_SERVER"}}]}' http://host1:8080/api/v1/clusters/cl/hosts?Hosts/host_name=host1
> curl -u admin:admin -X POST -d '{"host_components":[{"HostRoles":{"component_name":"HIVE_CLIENT"}}]}' http://host1:8080/api/v1/clusters/cl/hosts?Hosts/host_name=host1
> curl -u admin:admin -X POST -d '{"host_components":[{"HostRoles":{"component_name":"HCAT"}}]}' http://host1:8080/api/v1/clusters/cl/hosts?Hosts/host_name=host1
> curl -u admin:admin -X POST -d '{"host_components":[{"HostRoles":{"component_name":"MYSQL_SERVER"}}]}' http://host1:8080/api/v1/clusters/cl/hosts?Hosts/host_name=host1
> {code}
> # install new components
> {code}
> curl -u admin:admin -X PUT -d '{"RequestInfo": {"context" :"Install Services"}, "Body": {"ServiceInfo": {"state": "INSTALLED"}}}' http://host1:8080/api/v1/clusters/cl/services?ServiceInfo/state=INIT
> {code}
> # start new components
> {code}
> curl -u admin:admin -X PUT -d '{"RequestInfo":{"context":"Start Services"},"Body":{"ServiceInfo":{"state":"STARTED"}}}' http://host1:8080/api/v1/clusters/cl/services?ServiceInfo/state=INSTALLED&params/run_smoke_test=true&params/reconfigure_client=false
> {code}
> # get error:
> Parameter path failed: File paths must be fully qualified, not 'undef' at /var/lib/ambari-agent/puppet/modules/hdp/manifests/init.pp

--
This message is automatically generated by JIRA.
If you think it was sent incorrectly, please contact your JIRA administrators
For more information on JIRA, see: http://www.atlassian.com/software/jira