deb-sahara/sahara/plugins/ambari/resources/configs-2.3.json
Sergey Reshetnyak 8d0eba8d0f Add base services support for HDP 2.2 / 2.3
This patch added support of base Hadoop services:

HDFS:
* NameNode
* DataNode
* SecondaryNameNode

YARN:
* ResourceManager
* NodeManager
* MapReduce History Server
* YARN Timeline Server

ZooKeeper:
* ZooKeeper Server

Supported features:
* Cinder
* Configs provisioning
* Swift integration

Also added scenario tests for plugin.

partially implements bp: hdp-22-support

Change-Id: I2e1188735132881cef1026624cca580ccc7bb2ee
2015-08-27 14:53:01 +03:00

1276 lines
72 KiB
JSON

{
"accumulo-env": {
"accumulo_gc_heapsize": "256",
"accumulo_instance_name": "hdp-accumulo-instance",
"accumulo_log_dir": "/var/log/accumulo",
"accumulo_master_heapsize": "1024",
"accumulo_monitor_bind_all": "false",
"accumulo_monitor_heapsize": "1024",
"accumulo_other_heapsize": "1024",
"accumulo_pid_dir": "/var/run/accumulo",
"accumulo_tserver_heapsize": "1536",
"accumulo_user": "accumulo",
"instance_secret": "pass",
"server_content": "#! /usr/bin/env bash export HADOOP_PREFIX={{hadoop_prefix}} export HADOOP_CONF_DIR={{hadoop_conf_dir}} export JAVA_HOME={{java64_home}} export ZOOKEEPER_HOME={{zookeeper_home}} export ACCUMULO_PID_DIR={{pid_dir}} export ACCUMULO_LOG_DIR={{log_dir}} export ACCUMULO_CONF_DIR={{server_conf_dir}} export ACCUMULO_TSERVER_OPTS=\"-Xmx{{accumulo_tserver_heapsize}}m -Xms{{accumulo_tserver_heapsize}}m\" export ACCUMULO_MASTER_OPTS=\"-Xmx{{accumulo_master_heapsize}}m -Xms{{accumulo_master_heapsize}}m\" export ACCUMULO_MONITOR_OPTS=\"-Xmx{{accumulo_monitor_heapsize}}m -Xms{{accumulo_monitor_heapsize}}m\" export ACCUMULO_GC_OPTS=\"-Xmx{{accumulo_gc_heapsize}}m -Xms{{accumulo_gc_heapsize}}m\" export ACCUMULO_GENERAL_OPTS=\"-XX:+UseConcMarkSweepGC -XX:CMSInitiatingOccupancyFraction=75 -Djava.net.preferIPv4Stack=true ${ACCUMULO_GENERAL_OPTS}\" export ACCUMULO_OTHER_OPTS=\"-Xmx{{accumulo_other_heapsize}}m -Xms{{accumulo_other_heapsize}}m ${ACCUMULO_OTHER_OPTS}\" export ACCUMULO_MONITOR_BIND_ALL={{monitor_bind_str}} # what do when the JVM runs out of heap memory export ACCUMULO_KILL_CMD='kill -9 %p'"
},
"accumulo-log4j": {
"audit_log_level": "OFF",
"debug_log_size": "512M",
"debug_num_logs": "10",
"info_log_size": "512M",
"info_num_logs": "10",
"monitor_forwarding_log_level": "WARN"
},
"accumulo-site": {
"gc.port.client": "50092",
"general.classpaths": "$ACCUMULO_HOME/lib/accumulo-server.jar, $ACCUMULO_HOME/lib/accumulo-core.jar, $ACCUMULO_HOME/lib/accumulo-start.jar, $ACCUMULO_HOME/lib/accumulo-fate.jar, $ACCUMULO_HOME/lib/accumulo-proxy.jar, $ACCUMULO_HOME/lib/[^.].*.jar, $ZOOKEEPER_HOME/zookeeper[^.].*.jar, $HADOOP_CONF_DIR, /usr/hdp/current/hadoop-client/[^.].*.jar, /usr/hdp/current/hadoop-client/lib/(?!slf4j)[^.].*.jar, /usr/hdp/current/hadoop-hdfs-client/[^.].*.jar, /usr/hdp/current/hadoop-mapreduce-client/[^.].*.jar, /usr/hdp/current/hadoop-yarn-client/[^.].*.jar, /usr/hdp/current/hadoop-yarn-client/lib/jersey.*.jar, /usr/hdp/current/hive-client/lib/hive-accumulo-handler.jar,",
"instance.volumes": "hdfs://%HOSTGROUP::host_group_1%:8020/apps/accumulo/data",
"instance.zookeeper.host": "%HOSTGROUP::host_group_1%:2181",
"instance.zookeeper.timeout": "30s",
"master.port.client": "9999",
"monitor.port.client": "50095",
"monitor.port.log4j": "4560",
"trace.port.client": "12234",
"trace.user": "trace",
"tserver.cache.data.size": "128M",
"tserver.cache.index.size": "256M",
"tserver.memory.maps.max": "1G",
"tserver.memory.maps.native.enabled": "true",
"tserver.port.client": "9997",
"tserver.sort.buffer.size": "200M",
"tserver.walog.max.size": "1G"
},
"ams-env": {
"ambari_metrics_user": "ams",
"metrics_collector_heapsize": "512m",
"metrics_collector_log_dir": "/var/log/ambari-metrics-collector",
"metrics_collector_pid_dir": "/var/run/ambari-metrics-collector",
"metrics_monitor_log_dir": "/var/log/ambari-metrics-monitor",
"metrics_monitor_pid_dir": "/var/run/ambari-metrics-monitor"
},
"ams-hbase-env": {
"hbase_log_dir": "/var/log/ambari-metrics-collector",
"hbase_master_heapsize": "1024m",
"hbase_master_maxperm_size": "128m",
"hbase_master_xmn_size": "256m",
"hbase_pid_dir": "/var/run/ambari-metrics-collector/",
"hbase_regionserver_heapsize": "1024m",
"hbase_regionserver_xmn_ratio": "0.2",
"max_open_files_limit": "32768",
"regionserver_xmn_size": "256m"
},
"ams-hbase-policy": {
"security.admin.protocol.acl": "*",
"security.client.protocol.acl": "*",
"security.masterregion.protocol.acl": "*"
},
"ams-hbase-security-site": {
"ams.zookeeper.keytab": "",
"ams.zookeeper.principal": "",
"hadoop.security.authentication": "",
"hbase.coprocessor.master.classes": "",
"hbase.coprocessor.region.classes": "",
"hbase.master.kerberos.principal": "",
"hbase.master.keytab.file": "",
"hbase.myclient.keytab": "",
"hbase.myclient.principal": "",
"hbase.regionserver.kerberos.principal": "",
"hbase.regionserver.keytab.file": "",
"hbase.security.authentication": "",
"hbase.security.authorization": "",
"hbase.zookeeper.property.authProvider.1": "",
"hbase.zookeeper.property.jaasLoginRenew": "",
"hbase.zookeeper.property.kerberos.removeHostFromPrincipal": "",
"hbase.zookeeper.property.kerberos.removeRealmFromPrincipal": "",
"zookeeper.znode.parent": ""
},
"ams-hbase-site": {
"hbase.client.scanner.caching": "10000",
"hbase.client.scanner.timeout.period": "900000",
"hbase.cluster.distributed": "false",
"hbase.hregion.majorcompaction": "0",
"hbase.hregion.memstore.block.multiplier": "4",
"hbase.hregion.memstore.flush.size": "134217728",
"hbase.hstore.blockingStoreFiles": "200",
"hbase.hstore.flusher.count": "2",
"hbase.local.dir": "${hbase.tmp.dir}/local",
"hbase.master.info.bindAddress": "0.0.0.0",
"hbase.master.info.port": "61310",
"hbase.master.port": "61300",
"hbase.master.wait.on.regionservers.mintostart": "1",
"hbase.regionserver.global.memstore.lowerLimit": "0.4",
"hbase.regionserver.global.memstore.upperLimit": "0.5",
"hbase.regionserver.info.port": "61330",
"hbase.regionserver.port": "61320",
"hbase.regionserver.thread.compaction.large": "2",
"hbase.regionserver.thread.compaction.small": "3",
"hbase.replication": "false",
"hbase.rootdir": "file:///var/lib/ambari-metrics-collector/hbase",
"hbase.snapshot.enabled": "false",
"hbase.tmp.dir": "/var/lib/ambari-metrics-collector/hbase-tmp",
"hbase.zookeeper.leaderport": "61388",
"hbase.zookeeper.peerport": "61288",
"hbase.zookeeper.property.clientPort": "61181",
"hbase.zookeeper.property.dataDir": "${hbase.tmp.dir}/zookeeper",
"hbase.zookeeper.quorum": "{{zookeeper_quorum_hosts}}",
"hbase_master_xmn_size": "128m",
"hfile.block.cache.size": "0.3",
"phoenix.groupby.maxCacheSize": "307200000",
"phoenix.query.maxGlobalMemoryPercentage": "15",
"phoenix.query.spoolThresholdBytes": "12582912",
"phoenix.query.timeoutMs": "1200000",
"phoenix.sequence.saltBuckets": "2",
"phoenix.spool.directory": "${hbase.tmp.dir}/phoenix-spool",
"zookeeper.session.timeout": "120000",
"zookeeper.session.timeout.localHBaseCluster": "20000"
},
"ams-site": {
"phoenix.query.maxGlobalMemoryPercentage": "25",
"phoenix.spool.directory": "/tmp",
"timeline.metrics.aggregator.checkpoint.dir": "/var/lib/ambari-metrics-collector/checkpoint",
"timeline.metrics.cluster.aggregator.daily.checkpointCutOffMultiplier": "1",
"timeline.metrics.cluster.aggregator.daily.disabled": "false",
"timeline.metrics.cluster.aggregator.daily.interval": "86400",
"timeline.metrics.cluster.aggregator.daily.ttl": "63072000",
"timeline.metrics.cluster.aggregator.hourly.checkpointCutOffMultiplier": "2",
"timeline.metrics.cluster.aggregator.hourly.disabled": "false",
"timeline.metrics.cluster.aggregator.hourly.interval": "3600",
"timeline.metrics.cluster.aggregator.hourly.ttl": "31536000",
"timeline.metrics.cluster.aggregator.minute.checkpointCutOffMultiplier": "2",
"timeline.metrics.cluster.aggregator.minute.disabled": "false",
"timeline.metrics.cluster.aggregator.minute.interval": "120",
"timeline.metrics.cluster.aggregator.minute.timeslice.interval": "30",
"timeline.metrics.cluster.aggregator.minute.ttl": "2592000",
"timeline.metrics.daily.aggregator.minute.interval": "86400",
"timeline.metrics.hbase.compression.scheme": "SNAPPY",
"timeline.metrics.hbase.data.block.encoding": "FAST_DIFF",
"timeline.metrics.host.aggregator.daily.checkpointCutOffMultiplier": "1",
"timeline.metrics.host.aggregator.daily.disabled": "false",
"timeline.metrics.host.aggregator.daily.ttl": "31536000",
"timeline.metrics.host.aggregator.hourly.checkpointCutOffMultiplier": "2",
"timeline.metrics.host.aggregator.hourly.disabled": "false",
"timeline.metrics.host.aggregator.hourly.interval": "3600",
"timeline.metrics.host.aggregator.hourly.ttl": "2592000",
"timeline.metrics.host.aggregator.minute.checkpointCutOffMultiplier": "2",
"timeline.metrics.host.aggregator.minute.disabled": "false",
"timeline.metrics.host.aggregator.minute.interval": "120",
"timeline.metrics.host.aggregator.minute.ttl": "604800",
"timeline.metrics.host.aggregator.ttl": "86400",
"timeline.metrics.service.checkpointDelay": "60",
"timeline.metrics.service.cluster.aggregator.appIds": "datanode,nodemanager,hbase",
"timeline.metrics.service.default.result.limit": "5760",
"timeline.metrics.service.operation.mode": "embedded",
"timeline.metrics.service.resultset.fetchSize": "2000",
"timeline.metrics.service.rpc.address": "0.0.0.0:60200",
"timeline.metrics.service.webapp.address": "0.0.0.0:6188"
},
"application-properties": {
"atlas.authentication.keytab": "/etc/security/keytabs/atlas.service.keytab",
"atlas.authentication.method": "simple",
"atlas.authentication.principal": "atlas",
"atlas.enableTLS": "false",
"atlas.graph.index.search.backend": "elasticsearch",
"atlas.graph.index.search.directory": "/var/lib/atlas/data/es",
"atlas.graph.index.search.elasticsearch.client-only": "false",
"atlas.graph.index.search.elasticsearch.local-mode": "true",
"atlas.graph.storage.backend": "berkeleyje",
"atlas.graph.storage.directory": "/var/lib/atlas/data/berkeley",
"atlas.http.authentication.enabled": "false",
"atlas.http.authentication.kerberos.keytab": "/etc/security/keytabs/spnego.service.keytab",
"atlas.http.authentication.kerberos.name.rules": "RULE:[1:$1@$0](.*@EXAMPLE.COM)s/@.*// DEFAULT",
"atlas.http.authentication.kerberos.principal": "HTTP/_HOST@EXAMPLE.COM",
"atlas.http.authentication.type": "simple",
"atlas.lineage.hive.process.inputs.name": "inputs",
"atlas.lineage.hive.process.outputs.name": "outputs",
"atlas.lineage.hive.process.type.name": "Process",
"atlas.lineage.hive.table.schema.query.Table": "Table where name='%s'\\, columns",
"atlas.lineage.hive.table.schema.query.hive_table": "hive_table where name='%s'\\, columns",
"atlas.lineage.hive.table.type.name": "DataSet",
"atlas.server.bind.address": "localhost"
},
"atlas-env": {
"metadata_classpath": "",
"metadata_data_dir": "/var/lib/atlas/data",
"metadata_expanded_war_dir": "./server/webapp",
"metadata_log_dir": "/var/log/atlas",
"metadata_opts": "-Xmx1024m",
"metadata_pid_dir": "/var/run/atlas",
"metadata_port": "21000",
"metadata_user": "atlas"
},
"capacity-scheduler": {
"yarn.scheduler.capacity.default.minimum-user-limit-percent": "100",
"yarn.scheduler.capacity.maximum-am-resource-percent": "0.2",
"yarn.scheduler.capacity.maximum-applications": "10000",
"yarn.scheduler.capacity.node-locality-delay": "40",
"yarn.scheduler.capacity.resource-calculator": "org.apache.hadoop.yarn.util.resource.DefaultResourceCalculator",
"yarn.scheduler.capacity.root.accessible-node-labels": "*",
"yarn.scheduler.capacity.root.acl_administer_queue": "*",
"yarn.scheduler.capacity.root.capacity": "100",
"yarn.scheduler.capacity.root.default.acl_administer_jobs": "*",
"yarn.scheduler.capacity.root.default.acl_submit_applications": "*",
"yarn.scheduler.capacity.root.default.capacity": "100",
"yarn.scheduler.capacity.root.default.maximum-capacity": "100",
"yarn.scheduler.capacity.root.default.state": "RUNNING",
"yarn.scheduler.capacity.root.default.user-limit-factor": "1",
"yarn.scheduler.capacity.root.queues": "default"
},
"cluster-env": {
"command_retry_enabled": "true",
"command_retry_max_time_in_sec": "600",
"commands_to_retry": "INSTALL,START",
"ignore_groupsusers_create": "false",
"kerberos_domain": "EXAMPLE.COM",
"repo_suse_rhel_template": "[{{repo_id}}] name={{repo_id}} {% if mirror_list %}mirrorlist={{mirror_list}}{% else %}baseurl={{base_url}}{% endif %} path=/ enabled=1 gpgcheck=0",
"repo_ubuntu_template": "{{package_type}} {{base_url}} {{components}}",
"security_enabled": "false",
"smokeuser": "ambari-qa",
"smokeuser_keytab": "/etc/security/keytabs/smokeuser.headless.keytab",
"user_group": "hadoop"
},
"core-site": {
"fs.defaultFS": "hdfs://%HOSTGROUP::host_group_1%:8020",
"fs.swift.impl": "org.apache.hadoop.fs.swift.snative.SwiftNativeFileSystem",
"fs.swift.service.sahara.auth.endpoint.prefix": "/endpoints/AUTH_",
"fs.swift.service.sahara.auth.url": "http://172.18.168.2:5000/v2.0/tokens/",
"fs.swift.service.sahara.http.port": "8080",
"fs.swift.service.sahara.https.port": "443",
"fs.swift.service.sahara.public": "true",
"fs.swift.service.sahara.tenant": "devs",
"fs.trash.interval": "360",
"ha.failover-controller.active-standby-elector.zk.op.retries": "120",
"hadoop.http.authentication.simple.anonymous.allowed": "true",
"hadoop.proxyuser.falcon.groups": "users",
"hadoop.proxyuser.falcon.hosts": "*",
"hadoop.proxyuser.hcat.groups": "users",
"hadoop.proxyuser.hcat.hosts": "%HOSTGROUP::host_group_2%",
"hadoop.proxyuser.hdfs.groups": "*",
"hadoop.proxyuser.hdfs.hosts": "*",
"hadoop.proxyuser.hive.groups": "users",
"hadoop.proxyuser.hive.hosts": "%HOSTGROUP::host_group_2%",
"hadoop.proxyuser.oozie.groups": "users",
"hadoop.proxyuser.oozie.hosts": "*",
"hadoop.security.auth_to_local": "DEFAULT",
"hadoop.security.authentication": "simple",
"hadoop.security.authorization": "false",
"hadoop.security.key.provider.path": "",
"io.compression.codecs": "org.apache.hadoop.io.compress.GzipCodec,org.apache.hadoop.io.compress.DefaultCodec,org.apache.hadoop.io.compress.SnappyCodec",
"io.file.buffer.size": "131072",
"io.serializations": "org.apache.hadoop.io.serializer.WritableSerialization",
"ipc.client.connect.max.retries": "50",
"ipc.client.connection.maxidletime": "30000",
"ipc.client.idlethreshold": "8000",
"ipc.server.tcpnodelay": "true",
"mapreduce.jobtracker.webinterface.trusted": "false",
"net.topology.script.file.name": "/etc/hadoop/conf/topology_script.py",
"proxyuser_group": "users"
},
"falcon-env": {
"falcon.embeddedmq": "true",
"falcon.embeddedmq.data": "/hadoop/falcon/embeddedmq/data",
"falcon.emeddedmq.port": "61616",
"falcon_local_dir": "/hadoop/falcon",
"falcon_log_dir": "/var/log/falcon",
"falcon_pid_dir": "/var/run/falcon",
"falcon_port": "15000",
"falcon_store_uri": "file:///hadoop/falcon/store",
"falcon_user": "falcon",
"supports_hive_dr": "true"
},
"falcon-runtime.properties": {
"*.domain": "${falcon.app.type}",
"*.log.cleanup.frequency.days.retention": "days(7)",
"*.log.cleanup.frequency.hours.retention": "minutes(1)",
"*.log.cleanup.frequency.minutes.retention": "hours(6)",
"*.log.cleanup.frequency.months.retention": "months(3)"
},
"falcon-startup.properties": {
"*.ConfigSyncService.impl": "org.apache.falcon.resource.ConfigSyncService",
"*.ProcessInstanceManager.impl": "org.apache.falcon.resource.InstanceManager",
"*.SchedulableEntityManager.impl": "org.apache.falcon.resource.SchedulableEntityManager",
"*.application.services": "org.apache.falcon.security.AuthenticationInitializationService,\\ org.apache.falcon.workflow.WorkflowJobEndNotificationService, \\ org.apache.falcon.service.ProcessSubscriberService,\\ org.apache.falcon.entity.store.ConfigurationStore,\\ org.apache.falcon.rerun.service.RetryService,\\ org.apache.falcon.rerun.service.LateRunService,\\ org.apache.falcon.service.LogCleanupService,\\ org.apache.falcon.metadata.MetadataMappingService",
"*.broker.impl.class": "org.apache.activemq.ActiveMQConnectionFactory",
"*.broker.ttlInMins": "4320",
"*.broker.url": "tcp://%HOSTGROUP::host_group_2%:61616",
"*.catalog.service.impl": "org.apache.falcon.catalog.HiveCatalogService",
"*.config.store.uri": "file:///hadoop/falcon/store",
"*.configstore.listeners": "org.apache.falcon.entity.v0.EntityGraph,\\ org.apache.falcon.entity.ColoClusterRelation,\\ org.apache.falcon.group.FeedGroupMap,\\ org.apache.falcon.service.SharedLibraryHostingService",
"*.domain": "${falcon.app.type}",
"*.entity.topic": "FALCON.ENTITY.TOPIC",
"*.falcon.authentication.type": "simple",
"*.falcon.cleanup.service.frequency": "days(1)",
"*.falcon.enableTLS": "false",
"*.falcon.graph.blueprints.graph": "com.thinkaurelius.titan.core.TitanFactory",
"*.falcon.graph.preserve.history": "false",
"*.falcon.graph.serialize.path": "/hadoop/falcon/data/lineage",
"*.falcon.graph.storage.backend": "berkeleyje",
"*.falcon.graph.storage.directory": "/hadoop/falcon/data/lineage/graphdb",
"*.falcon.http.authentication.blacklisted.users": "",
"*.falcon.http.authentication.cookie.domain": "EXAMPLE.COM",
"*.falcon.http.authentication.kerberos.name.rules": "DEFAULT",
"*.falcon.http.authentication.signature.secret": "falcon",
"*.falcon.http.authentication.simple.anonymous.allowed": "true",
"*.falcon.http.authentication.token.validity": "36000",
"*.falcon.http.authentication.type": "simple",
"*.falcon.security.authorization.admin.groups": "falcon",
"*.falcon.security.authorization.admin.users": "falcon,ambari-qa",
"*.falcon.security.authorization.enabled": "false",
"*.falcon.security.authorization.provider": "org.apache.falcon.security.DefaultAuthorizationProvider",
"*.falcon.security.authorization.superusergroup": "falcon",
"*.hive.shared.libs": "hive-exec,hive-metastore,hive-common,hive-service,hive-hcatalog-server-extensions,\\ hive-hcatalog-core,hive-jdbc,hive-webhcat-java-client",
"*.internal.queue.size": "1000",
"*.journal.impl": "org.apache.falcon.transaction.SharedFileSystemJournal",
"*.max.retry.failure.count": "1",
"*.oozie.feed.workflow.builder": "org.apache.falcon.workflow.OozieFeedWorkflowBuilder",
"*.oozie.process.workflow.builder": "org.apache.falcon.workflow.OozieProcessWorkflowBuilder",
"*.retry.recorder.path": "${falcon.log.dir}/retry",
"*.shared.libs": "activemq-core,ant,geronimo-j2ee-management,jms,json-simple,oozie-client,spring-jms,commons-lang3,commons-el",
"*.system.lib.location": "${falcon.home}/server/webapp/${falcon.app.type}/WEB-INF/lib",
"*.workflow.engine.impl": "org.apache.falcon.workflow.engine.OozieWorkflowEngine",
"prism.application.services": "org.apache.falcon.entity.store.ConfigurationStore",
"prism.configstore.listeners": "org.apache.falcon.entity.v0.EntityGraph,\\ org.apache.falcon.entity.ColoClusterRelation,\\ org.apache.falcon.group.FeedGroupMap"
},
"flume-env": {
"flume_conf_dir": "/etc/flume/conf",
"flume_log_dir": "/var/log/flume",
"flume_run_dir": "/var/run/flume",
"flume_user": "flume"
},
"gateway-site": {
"gateway.gateway.conf.dir": "deployments",
"gateway.hadoop.kerberos.secured": "false",
"gateway.path": "gateway",
"gateway.port": "8443",
"java.security.auth.login.config": "/etc/knox/conf/krb5JAASLogin.conf",
"java.security.krb5.conf": "/etc/knox/conf/krb5.conf",
"sun.security.krb5.debug": "true"
},
"hadoop-env": {
"dfs.datanode.data.dir.mount.file": "/etc/hadoop/conf/dfs_data_dir_mount.hist",
"dtnode_heapsize": "1024m",
"hadoop_heapsize": "1024",
"hadoop_pid_dir_prefix": "/var/run/hadoop",
"hadoop_root_logger": "INFO,RFA",
"hdfs_log_dir_prefix": "/var/log/hadoop",
"hdfs_user": "hdfs",
"keyserver_host": "",
"keyserver_port": "",
"namenode_heapsize": "1024m",
"namenode_opt_maxnewsize": "200m",
"namenode_opt_maxpermsize": "256m",
"namenode_opt_newsize": "200m",
"namenode_opt_permsize": "128m",
"nfsgateway_heapsize": "1024",
"proxyuser_group": "users"
},
"hadoop-policy": {
"security.admin.operations.protocol.acl": "hadoop",
"security.client.datanode.protocol.acl": "*",
"security.client.protocol.acl": "*",
"security.datanode.protocol.acl": "*",
"security.inter.datanode.protocol.acl": "*",
"security.inter.tracker.protocol.acl": "*",
"security.job.client.protocol.acl": "*",
"security.job.task.protocol.acl": "*",
"security.namenode.protocol.acl": "*",
"security.refresh.policy.protocol.acl": "hadoop",
"security.refresh.usertogroups.mappings.protocol.acl": "hadoop"
},
"hbase-env": {
"hbase_log_dir": "/var/log/hbase",
"hbase_master_heapsize": "1024m",
"hbase_pid_dir": "/var/run/hbase",
"hbase_regionserver_heapsize": "1024m",
"hbase_regionserver_xmn_max": "512",
"hbase_regionserver_xmn_ratio": "0.2",
"hbase_user": "hbase",
"override_hbase_uid": "true",
"phoenix_sql_enabled": "false"
},
"hbase-policy": {
"security.admin.protocol.acl": "*",
"security.client.protocol.acl": "*",
"security.masterregion.protocol.acl": "*"
},
"hbase-site": {
"dfs.domain.socket.path": "/var/lib/hadoop-hdfs/dn_socket",
"hbase.bulkload.staging.dir": "/apps/hbase/staging",
"hbase.client.keyvalue.maxsize": "1048576",
"hbase.client.retries.number": "35",
"hbase.client.scanner.caching": "100",
"hbase.cluster.distributed": "true",
"hbase.coprocessor.master.classes": "",
"hbase.coprocessor.region.classes": "org.apache.hadoop.hbase.security.access.SecureBulkLoadEndpoint",
"hbase.coprocessor.regionserver.classes": "",
"hbase.defaults.for.version.skip": "true",
"hbase.hregion.majorcompaction": "604800000",
"hbase.hregion.majorcompaction.jitter": "0.50",
"hbase.hregion.max.filesize": "10737418240",
"hbase.hregion.memstore.block.multiplier": "4",
"hbase.hregion.memstore.flush.size": "134217728",
"hbase.hregion.memstore.mslab.enabled": "true",
"hbase.hstore.blockingStoreFiles": "10",
"hbase.hstore.compaction.max": "10",
"hbase.hstore.compactionThreshold": "3",
"hbase.local.dir": "${hbase.tmp.dir}/local",
"hbase.master.info.bindAddress": "0.0.0.0",
"hbase.master.info.port": "16010",
"hbase.master.port": "16000",
"hbase.regionserver.global.memstore.size": "0.4",
"hbase.regionserver.handler.count": "30",
"hbase.regionserver.info.port": "16030",
"hbase.regionserver.port": "16020",
"hbase.regionserver.wal.codec": "org.apache.hadoop.hbase.regionserver.wal.WALCellCodec",
"hbase.rootdir": "hdfs://%HOSTGROUP::host_group_1%:8020/apps/hbase/data",
"hbase.rpc.controllerfactory.class": "",
"hbase.rpc.protection": "authentication",
"hbase.rpc.timeout": "90000",
"hbase.security.authentication": "simple",
"hbase.security.authorization": "false",
"hbase.superuser": "hbase",
"hbase.tmp.dir": "/tmp/hbase-${user.name}",
"hbase.zookeeper.property.clientPort": "2181",
"hbase.zookeeper.quorum": "%HOSTGROUP::host_group_1%",
"hbase.zookeeper.useMulti": "true",
"hfile.block.cache.size": "0.40",
"phoenix.functions.allowUserDefinedFunctions": "",
"phoenix.query.timeoutMs": "60000",
"zookeeper.session.timeout": "90000",
"zookeeper.znode.parent": "/hbase-unsecure"
},
"hdfs-site": {
"dfs.block.access.token.enable": "true",
"dfs.blockreport.initialDelay": "120",
"dfs.blocksize": "134217728",
"dfs.client.read.shortcircuit": "true",
"dfs.client.read.shortcircuit.streams.cache.size": "4096",
"dfs.client.retry.policy.enabled": "false",
"dfs.cluster.administrators": "hdfs",
"dfs.datanode.address": "0.0.0.0:50010",
"dfs.datanode.balance.bandwidthPerSec": "6250000",
"dfs.datanode.data.dir": "/hadoop/hdfs/data",
"dfs.datanode.data.dir.perm": "750",
"dfs.datanode.du.reserved": "1073741824",
"dfs.datanode.failed.volumes.tolerated": "0",
"dfs.datanode.http.address": "0.0.0.0:50075",
"dfs.datanode.https.address": "0.0.0.0:50475",
"dfs.datanode.ipc.address": "0.0.0.0:8010",
"dfs.datanode.max.transfer.threads": "1024",
"dfs.domain.socket.path": "/var/lib/hadoop-hdfs/dn_socket",
"dfs.encrypt.data.transfer.cipher.suites": "AES/CTR/NoPadding",
"dfs.encryption.key.provider.uri": "",
"dfs.heartbeat.interval": "3",
"dfs.hosts.exclude": "/etc/hadoop/conf/dfs.exclude",
"dfs.http.policy": "HTTP_ONLY",
"dfs.https.port": "50470",
"dfs.journalnode.edits.dir": "/hadoop/hdfs/journalnode",
"dfs.journalnode.http-address": "0.0.0.0:8480",
"dfs.journalnode.https-address": "0.0.0.0:8481",
"dfs.namenode.accesstime.precision": "0",
"dfs.namenode.audit.log.async": "true",
"dfs.namenode.avoid.read.stale.datanode": "true",
"dfs.namenode.avoid.write.stale.datanode": "true",
"dfs.namenode.checkpoint.dir": "/hadoop/hdfs/namesecondary",
"dfs.namenode.checkpoint.edits.dir": "${dfs.namenode.checkpoint.dir}",
"dfs.namenode.checkpoint.period": "21600",
"dfs.namenode.checkpoint.txns": "1000000",
"dfs.namenode.fslock.fair": "false",
"dfs.namenode.handler.count": "100",
"dfs.namenode.http-address": "%HOSTGROUP::host_group_1%:50070",
"dfs.namenode.https-address": "%HOSTGROUP::host_group_1%:50470",
"dfs.namenode.name.dir": "/hadoop/hdfs/namenode",
"dfs.namenode.name.dir.restore": "true",
"dfs.namenode.rpc-address": "%HOSTGROUP::host_group_1%:8020",
"dfs.namenode.safemode.threshold-pct": "0.999",
"dfs.namenode.secondary.http-address": "%HOSTGROUP::host_group_1%:50090",
"dfs.namenode.stale.datanode.interval": "30000",
"dfs.namenode.startup.delay.block.deletion.sec": "3600",
"dfs.namenode.write.stale.datanode.ratio": "1.0f",
"dfs.permissions.enabled": "true",
"dfs.permissions.superusergroup": "hdfs",
"dfs.replication": "3",
"dfs.replication.max": "50",
"dfs.support.append": "true",
"dfs.webhdfs.enabled": "true",
"fs.permissions.umask-mode": "022",
"nfs.exports.allowed.hosts": "* rw",
"nfs.file.dump.dir": "/tmp/.hdfs-nfs"
},
"hive-env": {
"cost_based_optimizer": "On",
"hcat_log_dir": "/var/log/webhcat",
"hcat_pid_dir": "/var/run/webhcat",
"hcat_user": "hcat",
"hive_database": "New MySQL Database",
"hive_database_name": "hive",
"hive_database_type": "mysql",
"hive_exec_orc_storage_strategy": "SPEED",
"hive_log_dir": "/var/log/hive",
"hive_pid_dir": "/var/run/hive",
"hive_security_authorization": "None",
"hive_timeline_logging_enabled": "true",
"hive_txn_acid": "off",
"hive_user": "hive",
"webhcat_user": "hcat"
},
"hive-site": {
"ambari.hive.db.schema.name": "hive",
"datanucleus.autoCreateSchema": "false",
"datanucleus.cache.level2.type": "none",
"hive.auto.convert.join": "true",
"hive.auto.convert.join.noconditionaltask": "true",
"hive.auto.convert.join.noconditionaltask.size": "59419306",
"hive.auto.convert.sortmerge.join": "true",
"hive.auto.convert.sortmerge.join.to.mapjoin": "false",
"hive.cbo.enable": "true",
"hive.cli.print.header": "false",
"hive.cluster.delegation.token.store.class": "org.apache.hadoop.hive.thrift.ZooKeeperTokenStore",
"hive.cluster.delegation.token.store.zookeeper.connectString": "%HOSTGROUP::host_group_1%:2181",
"hive.cluster.delegation.token.store.zookeeper.znode": "/hive/cluster/delegation",
"hive.compactor.abortedtxn.threshold": "1000",
"hive.compactor.check.interval": "300L",
"hive.compactor.delta.num.threshold": "10",
"hive.compactor.delta.pct.threshold": "0.1f",
"hive.compactor.initiator.on": "false",
"hive.compactor.worker.threads": "0",
"hive.compactor.worker.timeout": "86400L",
"hive.compute.query.using.stats": "true",
"hive.conf.restricted.list": "hive.security.authenticator.manager,hive.security.authorization.manager,hive.users.in.admin.role",
"hive.convert.join.bucket.mapjoin.tez": "false",
"hive.default.fileformat": "TextFile",
"hive.default.fileformat.managed": "TextFile",
"hive.enforce.bucketing": "false",
"hive.enforce.sorting": "true",
"hive.enforce.sortmergebucketmapjoin": "true",
"hive.exec.compress.intermediate": "false",
"hive.exec.compress.output": "false",
"hive.exec.dynamic.partition": "true",
"hive.exec.dynamic.partition.mode": "strict",
"hive.exec.failure.hooks": "org.apache.hadoop.hive.ql.hooks.ATSHook",
"hive.exec.max.created.files": "100000",
"hive.exec.max.dynamic.partitions": "5000",
"hive.exec.max.dynamic.partitions.pernode": "2000",
"hive.exec.orc.compression.strategy": "SPEED",
"hive.exec.orc.default.compress": "ZLIB",
"hive.exec.orc.default.stripe.size": "67108864",
"hive.exec.orc.encoding.strategy": "SPEED",
"hive.exec.parallel": "false",
"hive.exec.parallel.thread.number": "8",
"hive.exec.post.hooks": "org.apache.hadoop.hive.ql.hooks.ATSHook",
"hive.exec.pre.hooks": "org.apache.hadoop.hive.ql.hooks.ATSHook",
"hive.exec.reducers.bytes.per.reducer": "67108864",
"hive.exec.reducers.max": "1009",
"hive.exec.scratchdir": "/tmp/hive",
"hive.exec.submit.local.task.via.child": "true",
"hive.exec.submitviachild": "false",
"hive.execution.engine": "tez",
"hive.fetch.task.aggr": "false",
"hive.fetch.task.conversion": "more",
"hive.fetch.task.conversion.threshold": "1073741824",
"hive.limit.optimize.enable": "true",
"hive.limit.pushdown.memory.usage": "0.04",
"hive.map.aggr": "true",
"hive.map.aggr.hash.force.flush.memory.threshold": "0.9",
"hive.map.aggr.hash.min.reduction": "0.5",
"hive.map.aggr.hash.percentmemory": "0.5",
"hive.mapjoin.bucket.cache.size": "10000",
"hive.mapjoin.optimized.hashtable": "true",
"hive.mapred.reduce.tasks.speculative.execution": "false",
"hive.merge.mapfiles": "true",
"hive.merge.mapredfiles": "false",
"hive.merge.orcfile.stripe.level": "true",
"hive.merge.rcfile.block.level": "true",
"hive.merge.size.per.task": "256000000",
"hive.merge.smallfiles.avgsize": "16000000",
"hive.merge.tezfiles": "false",
"hive.metastore.authorization.storage.checks": "false",
"hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
"hive.metastore.client.connect.retry.delay": "5s",
"hive.metastore.client.socket.timeout": "1800s",
"hive.metastore.connect.retries": "24",
"hive.metastore.execute.setugi": "true",
"hive.metastore.failure.retries": "24",
"hive.metastore.kerberos.keytab.file": "/etc/security/keytabs/hive.service.keytab",
"hive.metastore.kerberos.principal": "hive/_HOST@EXAMPLE.COM",
"hive.metastore.pre.event.listeners": "org.apache.hadoop.hive.ql.security.authorization.AuthorizationPreEventListener",
"hive.metastore.sasl.enabled": "false",
"hive.metastore.server.max.threads": "100000",
"hive.metastore.uris": "thrift://%HOSTGROUP::host_group_2%:9083",
"hive.metastore.warehouse.dir": "/apps/hive/warehouse",
"hive.optimize.bucketmapjoin": "true",
"hive.optimize.bucketmapjoin.sortedmerge": "false",
"hive.optimize.constant.propagation": "true",
"hive.optimize.index.filter": "true",
"hive.optimize.metadataonly": "true",
"hive.optimize.null.scan": "true",
"hive.optimize.reducededuplication": "true",
"hive.optimize.reducededuplication.min.reducer": "4",
"hive.optimize.sort.dynamic.partition": "false",
"hive.orc.compute.splits.num.threads": "10",
"hive.orc.splits.include.file.footer": "false",
"hive.prewarm.enabled": "false",
"hive.prewarm.numcontainers": "3",
"hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
"hive.security.authorization.enabled": "false",
"hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdConfOnlyAuthorizerFactory",
"hive.security.metastore.authenticator.manager": "org.apache.hadoop.hive.ql.security.HadoopDefaultMetastoreAuthenticator",
"hive.security.metastore.authorization.auth.reads": "true",
"hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
"hive.server2.allow.user.substitution": "true",
"hive.server2.authentication": "NONE",
"hive.server2.authentication.spnego.keytab": "HTTP/_HOST@EXAMPLE.COM",
"hive.server2.authentication.spnego.principal": "/etc/security/keytabs/spnego.service.keytab",
"hive.server2.enable.doAs": "true",
"hive.server2.logging.operation.enabled": "true",
"hive.server2.logging.operation.log.location": "${system:java.io.tmpdir}/${system:user.name}/operation_logs",
"hive.server2.support.dynamic.service.discovery": "true",
"hive.server2.table.type.mapping": "CLASSIC",
"hive.server2.tez.default.queues": "default",
"hive.server2.tez.initialize.default.sessions": "false",
"hive.server2.tez.sessions.per.default.queue": "1",
"hive.server2.thrift.http.path": "cliservice",
"hive.server2.thrift.http.port": "10001",
"hive.server2.thrift.max.worker.threads": "500",
"hive.server2.thrift.port": "10000",
"hive.server2.thrift.sasl.qop": "auth",
"hive.server2.transport.mode": "binary",
"hive.server2.use.SSL": "false",
"hive.server2.zookeeper.namespace": "hiveserver2",
"hive.smbjoin.cache.rows": "10000",
"hive.stats.autogather": "true",
"hive.stats.dbclass": "fs",
"hive.stats.fetch.column.stats": "true",
"hive.stats.fetch.partition.stats": "true",
"hive.support.concurrency": "false",
"hive.tez.auto.reducer.parallelism": "true",
"hive.tez.container.size": "170",
"hive.tez.cpu.vcores": "-1",
"hive.tez.dynamic.partition.pruning": "true",
"hive.tez.dynamic.partition.pruning.max.data.size": "104857600",
"hive.tez.dynamic.partition.pruning.max.event.size": "1048576",
"hive.tez.input.format": "org.apache.hadoop.hive.ql.io.HiveInputFormat",
"hive.tez.java.opts": "-server -Djava.net.preferIPv4Stack=true -XX:NewRatio=8 -XX:+UseNUMA -XX:+UseParallelGC -XX:+PrintGCDetails -verbose:gc -XX:+PrintGCTimeStamps",
"hive.tez.log.level": "INFO",
"hive.tez.max.partition.factor": "2.0",
"hive.tez.min.partition.factor": "0.25",
"hive.tez.smb.number.waves": "0.5",
"hive.txn.manager": "org.apache.hadoop.hive.ql.lockmgr.DummyTxnManager",
"hive.txn.max.open.batch": "1000",
"hive.txn.timeout": "300",
"hive.user.install.directory": "/user/",
"hive.vectorized.execution.enabled": "true",
"hive.vectorized.execution.reduce.enabled": "false",
"hive.vectorized.groupby.checkinterval": "4096",
"hive.vectorized.groupby.flush.percent": "0.1",
"hive.vectorized.groupby.maxentries": "100000",
"hive.zookeeper.client.port": "2181",
"hive.zookeeper.namespace": "hive_zookeeper_namespace",
"hive.zookeeper.quorum": "%HOSTGROUP::host_group_1%:2181",
"javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
"javax.jdo.option.ConnectionURL": "jdbc:mysql://%HOSTGROUP::host_group_2%/hive?createDatabaseIfNotExist=true",
"javax.jdo.option.ConnectionUserName": "hive"
},
"hiveserver2-site": {
"hive.security.authorization.enabled": "false"
},
"kafka-broker": {
"auto.create.topics.enable": "true",
"auto.leader.rebalance.enable": "true",
"compression.type": "producer",
"controlled.shutdown.enable": "true",
"controlled.shutdown.max.retries": "3",
"controlled.shutdown.retry.backoff.ms": "5000",
"controller.message.queue.size": "10",
"controller.socket.timeout.ms": "30000",
"default.replication.factor": "1",
"delete.topic.enable": "false",
"fetch.purgatory.purge.interval.requests": "10000",
"kafka.ganglia.metrics.group": "kafka",
"kafka.ganglia.metrics.port": "8671",
"kafka.ganglia.metrics.reporter.enabled": "true",
"kafka.metrics.reporters": "{{kafka_metrics_reporters}}",
"kafka.timeline.metrics.host": "{{metric_collector_host}}",
"kafka.timeline.metrics.maxRowCacheSize": "10000",
"kafka.timeline.metrics.port": "{{metric_collector_port}}",
"kafka.timeline.metrics.reporter.enabled": "true",
"kafka.timeline.metrics.reporter.sendInterval": "5900",
"leader.imbalance.check.interval.seconds": "300",
"leader.imbalance.per.broker.percentage": "10",
"listeners": "PLAINTEXT://localhost:6667",
"log.cleanup.interval.mins": "10",
"log.dirs": "/kafka-logs",
"log.index.interval.bytes": "4096",
"log.index.size.max.bytes": "10485760",
"log.retention.bytes": "-1",
"log.retention.hours": "168",
"log.roll.hours": "168",
"log.segment.bytes": "1073741824",
"message.max.bytes": "1000000",
"min.insync.replicas": "1",
"num.io.threads": "8",
"num.network.threads": "3",
"num.partitions": "1",
"num.recovery.threads.per.data.dir": "1",
"num.replica.fetchers": "1",
"offset.metadata.max.bytes": "4096",
"offsets.commit.required.acks": "-1",
"offsets.commit.timeout.ms": "5000",
"offsets.load.buffer.size": "5242880",
"offsets.retention.check.interval.ms": "600000",
"offsets.retention.minutes": "86400000",
"offsets.topic.compression.codec": "0",
"offsets.topic.num.partitions": "50",
"offsets.topic.replication.factor": "3",
"offsets.topic.segment.bytes": "104857600",
"producer.purgatory.purge.interval.requests": "10000",
"queued.max.requests": "500",
"replica.fetch.max.bytes": "1048576",
"replica.fetch.min.bytes": "1",
"replica.fetch.wait.max.ms": "500",
"replica.high.watermark.checkpoint.interval.ms": "5000",
"replica.lag.max.messages": "4000",
"replica.lag.time.max.ms": "10000",
"replica.socket.receive.buffer.bytes": "65536",
"replica.socket.timeout.ms": "30000",
"socket.receive.buffer.bytes": "102400",
"socket.request.max.bytes": "104857600",
"socket.send.buffer.bytes": "102400",
"zookeeper.connect": "%HOSTGROUP::host_group_1%:2181",
"zookeeper.connection.timeout.ms": "15000",
"zookeeper.session.timeout.ms": "30000",
"zookeeper.sync.time.ms": "2000"
},
"kafka-env": {
"is_supported_kafka_ranger": "true",
"kafka_log_dir": "/var/log/kafka",
"kafka_pid_dir": "/var/run/kafka",
"kafka_user": "kafka"
},
"knox-env": {
"knox_group": "knox",
"knox_master_secret": "pass",
"knox_pid_dir": "/var/run/knox",
"knox_user": "knox"
},
"mahout-env": {
"mahout_user": "mahout"
},
"mapred-env": {
"jobhistory_heapsize": "900",
"mapred_log_dir_prefix": "/var/log/hadoop-mapreduce",
"mapred_pid_dir_prefix": "/var/run/hadoop-mapreduce",
"mapred_user": "mapred"
},
"mapred-site": {
"mapreduce.admin.map.child.java.opts": "-server -XX:NewRatio=8 -Djava.net.preferIPv4Stack=true -Dhdp.version=${hdp.version}",
"mapreduce.admin.reduce.child.java.opts": "-server -XX:NewRatio=8 -Djava.net.preferIPv4Stack=true -Dhdp.version=${hdp.version}",
"mapreduce.admin.user.env": "LD_LIBRARY_PATH=/usr/hdp/${hdp.version}/hadoop/lib/native:/usr/hdp/${hdp.version}/hadoop/lib/native/Linux-amd64-64",
"mapreduce.am.max-attempts": "2",
"mapreduce.application.classpath": "$PWD/mr-framework/hadoop/share/hadoop/mapreduce/*:$PWD/mr-framework/hadoop/share/hadoop/mapreduce/lib/*:$PWD/mr-framework/hadoop/share/hadoop/common/*:$PWD/mr-framework/hadoop/share/hadoop/common/lib/*:$PWD/mr-framework/hadoop/share/hadoop/yarn/*:$PWD/mr-framework/hadoop/share/hadoop/yarn/lib/*:$PWD/mr-framework/hadoop/share/hadoop/hdfs/*:$PWD/mr-framework/hadoop/share/hadoop/hdfs/lib/*:$PWD/mr-framework/hadoop/share/hadoop/tools/lib/*:/usr/hdp/${hdp.version}/hadoop/lib/hadoop-lzo-0.6.0.${hdp.version}.jar:/etc/hadoop/conf/secure",
"mapreduce.application.framework.path": "/hdp/apps/${hdp.version}/mapreduce/mapreduce.tar.gz#mr-framework",
"mapreduce.cluster.administrators": "hadoop",
"mapreduce.framework.name": "yarn",
"mapreduce.job.counters.max": "130",
"mapreduce.job.emit-timeline-data": "false",
"mapreduce.job.reduce.slowstart.completedmaps": "0.05",
"mapreduce.jobhistory.address": "%HOSTGROUP::host_group_1%:10020",
"mapreduce.jobhistory.bind-host": "0.0.0.0",
"mapreduce.jobhistory.done-dir": "/mr-history/done",
"mapreduce.jobhistory.intermediate-done-dir": "/mr-history/tmp",
"mapreduce.jobhistory.recovery.enable": "true",
"mapreduce.jobhistory.recovery.store.class": "org.apache.hadoop.mapreduce.v2.hs.HistoryServerLeveldbStateStoreService",
"mapreduce.jobhistory.recovery.store.leveldb.path": "/hadoop/mapreduce/jhs",
"mapreduce.jobhistory.webapp.address": "%HOSTGROUP::host_group_1%:19888",
"mapreduce.map.java.opts": "-Xmx410m",
"mapreduce.map.log.level": "INFO",
"mapreduce.map.memory.mb": "512",
"mapreduce.map.output.compress": "false",
"mapreduce.map.sort.spill.percent": "0.7",
"mapreduce.map.speculative": "false",
"mapreduce.output.fileoutputformat.compress": "false",
"mapreduce.output.fileoutputformat.compress.type": "BLOCK",
"mapreduce.reduce.input.buffer.percent": "0.0",
"mapreduce.reduce.java.opts": "-Xmx756m",
"mapreduce.reduce.log.level": "INFO",
"mapreduce.reduce.memory.mb": "1024",
"mapreduce.reduce.shuffle.fetch.retry.enabled": "1",
"mapreduce.reduce.shuffle.fetch.retry.interval-ms": "1000",
"mapreduce.reduce.shuffle.fetch.retry.timeout-ms": "30000",
"mapreduce.reduce.shuffle.input.buffer.percent": "0.7",
"mapreduce.reduce.shuffle.merge.percent": "0.66",
"mapreduce.reduce.shuffle.parallelcopies": "30",
"mapreduce.reduce.speculative": "false",
"mapreduce.shuffle.port": "13562",
"mapreduce.task.io.sort.factor": "100",
"mapreduce.task.io.sort.mb": "358",
"mapreduce.task.timeout": "300000",
"yarn.app.mapreduce.am.admin-command-opts": "-Dhdp.version=${hdp.version}",
"yarn.app.mapreduce.am.command-opts": "-Xmx410m",
"yarn.app.mapreduce.am.log.level": "INFO",
"yarn.app.mapreduce.am.resource.mb": "512",
"yarn.app.mapreduce.am.staging-dir": "/user"
},
"oozie-env": {
"oozie_admin_port": "11001",
"oozie_admin_users": "{oozie_user}, oozie-admin",
"oozie_data_dir": "/hadoop/oozie/data",
"oozie_database": "New Derby Database",
"oozie_derby_database": "Derby",
"oozie_heapsize": "2048m",
"oozie_hostname": "%HOSTGROUP::host_group_1%",
"oozie_log_dir": "/var/log/oozie",
"oozie_permsize": "256m",
"oozie_pid_dir": "/var/run/oozie",
"oozie_user": "oozie"
},
"oozie-site": {
"oozie.authentication.kerberos.name.rules": "",
"oozie.authentication.simple.anonymous.allowed": "true",
"oozie.authentication.type": "simple",
"oozie.base.url": "http://%HOSTGROUP::host_group_1%:11000/oozie",
"oozie.credentials.credentialclasses": "hcat=org.apache.oozie.action.hadoop.HCatCredentials,hive2=org.apache.oozie.action.hadoop.Hive2Credentials",
"oozie.db.schema.name": "oozie",
"oozie.service.AuthorizationService.security.enabled": "true",
"oozie.service.HadoopAccessorService.hadoop.configurations": "*=/etc/hadoop/conf",
"oozie.service.HadoopAccessorService.kerberos.enabled": "false",
"oozie.service.JPAService.jdbc.driver": "org.apache.derby.jdbc.EmbeddedDriver",
"oozie.service.JPAService.jdbc.username": "oozie",
"oozie.service.URIHandlerService.uri.handlers": "org.apache.oozie.dependency.FSURIHandler,org.apache.oozie.dependency.HCatURIHandler",
"oozie.services.ext": "org.apache.oozie.service.JMSAccessorService,org.apache.oozie.service.PartitionDependencyManagerService,org.apache.oozie.service.HCatAccessorService"
},
"ranger-hdfs-audit": {
"xasecure.audit.credential.provider.file": "jceks://file{{credential_file}}",
"xasecure.audit.destination.db": "false",
"xasecure.audit.destination.db.batch.filespool.dir": "/var/log/hadoop/hdfs/audit/db/spool",
"xasecure.audit.destination.db.jdbc.driver": "{{jdbc_driver}}",
"xasecure.audit.destination.db.jdbc.url": "{{audit_jdbc_url}}",
"xasecure.audit.destination.db.user": "{{xa_audit_db_user}}",
"xasecure.audit.destination.hdfs": "true",
"xasecure.audit.destination.hdfs.batch.filespool.dir": "/var/log/hadoop/hdfs/audit/hdfs/spool",
"xasecure.audit.destination.hdfs.dir": "hdfs://NAMENODE_HOSTNAME:8020/ranger/audit",
"xasecure.audit.destination.solr": "false",
"xasecure.audit.destination.solr.batch.filespool.dir": "/var/log/hadoop/hdfs/audit/solr/spool",
"xasecure.audit.destination.solr.urls": "{{ranger_audit_solr_urls}}",
"xasecure.audit.destination.solr.zookeepers": "none",
"xasecure.audit.is.enabled": "true",
"xasecure.audit.provider.summary.enabled": "false"
},
"ranger-hdfs-plugin-properties": {
"REPOSITORY_CONFIG_USERNAME": "hadoop",
"common.name.for.certificate": "",
"hadoop.rpc.protection": "",
"policy_user": "ambari-qa",
"ranger-hdfs-plugin-enabled": "No"
},
"ranger-hdfs-policymgr-ssl": {
"xasecure.policymgr.clientssl.keystore": "/usr/hdp/current/hadoop-client/conf/ranger-plugin-keystore.jks",
"xasecure.policymgr.clientssl.keystore.credential.file": "jceks://file{{credential_file}}",
"xasecure.policymgr.clientssl.truststore": "/usr/hdp/current/hadoop-client/conf/ranger-plugin-truststore.jks",
"xasecure.policymgr.clientssl.truststore.credential.file": "jceks://file{{credential_file}}"
},
"ranger-hdfs-security": {
"ranger.plugin.hdfs.policy.cache.dir": "/etc/ranger/{{repo_name}}/policycache",
"ranger.plugin.hdfs.policy.pollIntervalMs": "30000",
"ranger.plugin.hdfs.policy.rest.ssl.config.file": "/etc/hadoop/conf/ranger-policymgr-ssl.xml",
"ranger.plugin.hdfs.policy.rest.url": "{{policymgr_mgr_url}}",
"ranger.plugin.hdfs.policy.source.impl": "org.apache.ranger.admin.client.RangerAdminRESTClient",
"ranger.plugin.hdfs.service.name": "{{repo_name}}",
"xasecure.add-hadoop-authorization": "true"
},
"ranger-yarn-audit": {
"xasecure.audit.credential.provider.file": "jceks://file{{credential_file}}",
"xasecure.audit.destination.db": "false",
"xasecure.audit.destination.db.batch.filespool.dir": "/var/log/hadoop/yarn/audit/db/spool",
"xasecure.audit.destination.db.jdbc.driver": "{{jdbc_driver}}",
"xasecure.audit.destination.db.jdbc.url": "{{audit_jdbc_url}}",
"xasecure.audit.destination.db.user": "{{xa_audit_db_user}}",
"xasecure.audit.destination.hdfs": "true",
"xasecure.audit.destination.hdfs.batch.filespool.dir": "/var/log/hadoop/yarn/audit/hdfs/spool",
"xasecure.audit.destination.hdfs.dir": "hdfs://NAMENODE_HOSTNAME:8020/ranger/audit",
"xasecure.audit.destination.solr": "false",
"xasecure.audit.destination.solr.batch.filespool.dir": "/var/log/hadoop/yarn/audit/solr/spool",
"xasecure.audit.destination.solr.urls": "{{ranger_audit_solr_urls}}",
"xasecure.audit.destination.solr.zookeepers": "none",
"xasecure.audit.is.enabled": "true",
"xasecure.audit.provider.summary.enabled": "false"
},
"ranger-yarn-plugin-properties": {
"REPOSITORY_CONFIG_USERNAME": "yarn",
"common.name.for.certificate": "",
"hadoop.rpc.protection": "",
"policy_user": "ambari-qa",
"ranger-yarn-plugin-enabled": "No"
},
"ranger-yarn-policymgr-ssl": {
"xasecure.policymgr.clientssl.keystore": "/usr/hdp/current/hadoop-client/conf/ranger-yarn-plugin-keystore.jks",
"xasecure.policymgr.clientssl.keystore.credential.file": "jceks://file{{credential_file}}",
"xasecure.policymgr.clientssl.truststore": "/usr/hdp/current/hadoop-client/conf/ranger-yarn-plugin-truststore.jks",
"xasecure.policymgr.clientssl.truststore.credential.file": "jceks://file{{credential_file}}"
},
"ranger-yarn-security": {
"ranger.plugin.yarn.policy.cache.dir": "/etc/ranger/{{repo_name}}/policycache",
"ranger.plugin.yarn.policy.pollIntervalMs": "30000",
"ranger.plugin.yarn.policy.rest.ssl.config.file": "/etc/hadoop/conf/ranger-policymgr-ssl-yarn.xml",
"ranger.plugin.yarn.policy.rest.url": "{{policymgr_mgr_url}}",
"ranger.plugin.yarn.policy.source.impl": "org.apache.ranger.admin.client.RangerAdminRESTClient",
"ranger.plugin.yarn.service.name": "{{repo_name}}"
},
"spark-defaults": {
"spark.driver.extraJavaOptions": "-Dhdp.version={{hdp_full_version}}",
"spark.history.kerberos.keytab": "none",
"spark.history.kerberos.principal": "none",
"spark.history.provider": "org.apache.spark.deploy.yarn.history.YarnHistoryProvider",
"spark.history.ui.port": "18080",
"spark.yarn.am.extraJavaOptions": "-Dhdp.version={{hdp_full_version}}",
"spark.yarn.applicationMaster.waitTries": "10",
"spark.yarn.containerLauncherMaxThreads": "25",
"spark.yarn.driver.memoryOverhead": "384",
"spark.yarn.executor.memoryOverhead": "384",
"spark.yarn.historyServer.address": "{{spark_history_server_host}}:{{spark_history_ui_port}}",
"spark.yarn.max.executor.failures": "3",
"spark.yarn.preserve.staging.files": "false",
"spark.yarn.queue": "default",
"spark.yarn.scheduler.heartbeat.interval-ms": "5000",
"spark.yarn.services": "org.apache.spark.deploy.yarn.history.YarnHistoryService",
"spark.yarn.submit.file.replication": "3"
},
"spark-env": {
"spark_group": "spark",
"spark_log_dir": "/var/log/spark",
"spark_pid_dir": "/var/run/spark",
"spark_user": "spark"
},
"sqoop-env": {
"jdbc_drivers": "",
"sqoop_user": "sqoop"
},
"ssl-client": {
"ssl.client.keystore.location": "/etc/security/clientKeys/keystore.jks",
"ssl.client.keystore.type": "jks",
"ssl.client.truststore.location": "/etc/security/clientKeys/all.jks",
"ssl.client.truststore.reload.interval": "10000",
"ssl.client.truststore.type": "jks"
},
"ssl-server": {
"ssl.server.keystore.location": "/etc/security/serverKeys/keystore.jks",
"ssl.server.keystore.type": "jks",
"ssl.server.truststore.location": "/etc/security/serverKeys/all.jks",
"ssl.server.truststore.reload.interval": "10000",
"ssl.server.truststore.type": "jks"
},
"storm-env": {
"jmxremote_port": "56431",
"nimbus_seeds_supported": "true",
"storm_log_dir": "/var/log/storm",
"storm_pid_dir": "/var/run/storm",
"storm_user": "storm"
},
"storm-site": {
"_storm.min.ruid": "null",
"_storm.thrift.nonsecure.transport": "backtype.storm.security.auth.SimpleTransportPlugin",
"_storm.thrift.secure.transport": "backtype.storm.security.auth.kerberos.KerberosSaslTransportPlugin",
"dev.zookeeper.path": "/tmp/dev-storm-zookeeper",
"drpc.childopts": "-Xmx768m _JAAS_PLACEHOLDER",
"drpc.invocations.port": "3773",
"drpc.port": "3772",
"drpc.queue.size": "128",
"drpc.request.timeout.secs": "600",
"drpc.worker.threads": "64",
"java.library.path": "/usr/local/lib:/opt/local/lib:/usr/lib:/usr/hdp/current/storm-client/lib",
"logviewer.appender.name": "A1",
"logviewer.childopts": "-Xmx128m _JAAS_PLACEHOLDER",
"logviewer.port": "8000",
"metrics.reporter.register": "org.apache.hadoop.metrics2.sink.storm.StormTimelineMetricsReporter",
"nimbus.cleanup.inbox.freq.secs": "600",
"nimbus.file.copy.expiration.secs": "600",
"nimbus.inbox.jar.expiration.secs": "3600",
"nimbus.monitor.freq.secs": "10",
"nimbus.reassign": "true",
"nimbus.seeds": "['%HOSTGROUP::host_group_2%']",
"nimbus.supervisor.timeout.secs": "60",
"nimbus.task.launch.secs": "120",
"nimbus.task.timeout.secs": "30",
"nimbus.thrift.max_buffer_size": "1048576",
"nimbus.thrift.port": "6627",
"nimbus.topology.validator": "backtype.storm.nimbus.DefaultTopologyValidator",
"storm.cluster.mode": "distributed",
"storm.local.dir": "/hadoop/storm",
"storm.local.mode.zmq": "false",
"storm.log.dir": "{{log_dir}}",
"storm.messaging.netty.buffer_size": "5242880",
"storm.messaging.netty.client_worker_threads": "1",
"storm.messaging.netty.max_retries": "30",
"storm.messaging.netty.max_wait_ms": "1000",
"storm.messaging.netty.min_wait_ms": "100",
"storm.messaging.netty.server_worker_threads": "1",
"storm.messaging.transport": "backtype.storm.messaging.netty.Context",
"storm.thrift.transport": "{{storm_thrift_transport}}",
"storm.zookeeper.connection.timeout": "15000",
"storm.zookeeper.port": "2181",
"storm.zookeeper.retry.interval": "1000",
"storm.zookeeper.retry.intervalceiling.millis": "30000",
"storm.zookeeper.retry.times": "5",
"storm.zookeeper.root": "/storm",
"storm.zookeeper.servers": "['%HOSTGROUP::host_group_1%']",
"storm.zookeeper.session.timeout": "20000",
"supervisor.heartbeat.frequency.secs": "5",
"supervisor.monitor.frequency.secs": "3",
"supervisor.slots.ports": "[6700, 6701]",
"supervisor.worker.start.timeout.secs": "120",
"supervisor.worker.timeout.secs": "30",
"task.heartbeat.frequency.secs": "3",
"task.refresh.poll.secs": "10",
"topology.acker.executors": "null",
"topology.builtin.metrics.bucket.size.secs": "60",
"topology.debug": "false",
"topology.disruptor.wait.strategy": "com.lmax.disruptor.BlockingWaitStrategy",
"topology.enable.message.timeouts": "true",
"topology.error.throttle.interval.secs": "10",
"topology.executor.receive.buffer.size": "1024",
"topology.executor.send.buffer.size": "1024",
"topology.fall.back.on.java.serialization": "true",
"topology.kryo.factory": "backtype.storm.serialization.DefaultKryoFactory",
"topology.max.error.report.per.interval": "5",
"topology.max.replication.wait.time.sec": "{{actual_topology_max_replication_wait_time_sec}}",
"topology.max.replication.wait.time.sec.default": "60",
"topology.max.spout.pending": "null",
"topology.max.task.parallelism": "null",
"topology.message.timeout.secs": "30",
"topology.metrics.consumer.register": "[{'class': 'org.apache.hadoop.metrics2.sink.storm.StormTimelineMetricsSink', 'parallelism.hint': 1}]",
"topology.min.replication.count": "{{actual_topology_min_replication_count}}",
"topology.min.replication.count.default": "1",
"topology.optimize": "true",
"topology.receiver.buffer.size": "8",
"topology.skip.missing.kryo.registrations": "false",
"topology.sleep.spout.wait.strategy.time.ms": "1",
"topology.spout.wait.strategy": "backtype.storm.spout.SleepSpoutWaitStrategy",
"topology.state.synchronization.timeout.secs": "60",
"topology.stats.sample.rate": "0.05",
"topology.tick.tuple.freq.secs": "null",
"topology.transfer.buffer.size": "1024",
"topology.trident.batch.emit.interval.millis": "500",
"topology.tuple.serializer": "backtype.storm.serialization.types.ListDelegateSerializer",
"topology.worker.childopts": "null",
"topology.worker.shared.thread.pool.size": "4",
"topology.workers": "1",
"transactional.zookeeper.port": "null",
"transactional.zookeeper.root": "/transactional",
"transactional.zookeeper.servers": "null",
"ui.childopts": "-Xmx768m _JAAS_PLACEHOLDER",
"ui.filter": "null",
"ui.port": "8744",
"worker.heartbeat.frequency.secs": "1",
"zmq.hwm": "0",
"zmq.linger.millis": "5000",
"zmq.threads": "1"
},
"tez-env": {
"tez_user": "tez"
},
"tez-site": {
"tez.am.am-rm.heartbeat.interval-ms.max": "250",
"tez.am.container.idle.release-timeout-max.millis": "20000",
"tez.am.container.idle.release-timeout-min.millis": "10000",
"tez.am.container.reuse.enabled": "true",
"tez.am.container.reuse.locality.delay-allocation-millis": "250",
"tez.am.container.reuse.non-local-fallback.enabled": "false",
"tez.am.container.reuse.rack-fallback.enabled": "true",
"tez.am.launch.cluster-default.cmd-opts": "-server -Djava.net.preferIPv4Stack=true -Dhdp.version=${hdp.version}",
"tez.am.launch.cmd-opts": "-XX:+PrintGCDetails -verbose:gc -XX:+PrintGCTimeStamps -XX:+UseNUMA -XX:+UseParallelGC",
"tez.am.launch.env": "LD_LIBRARY_PATH=/usr/hdp/${hdp.version}/hadoop/lib/native:/usr/hdp/${hdp.version}/hadoop/lib/native/Linux-amd64-64",
"tez.am.log.level": "INFO",
"tez.am.max.app.attempts": "2",
"tez.am.maxtaskfailures.per.node": "10",
"tez.am.resource.memory.mb": "1536",
"tez.am.tez-ui.history-url.template": "__HISTORY_URL_BASE__?viewPath=%2F%23%2Ftez-app%2F__APPLICATION_ID__",
"tez.am.view-acls": "*",
"tez.cluster.additional.classpath.prefix": "/usr/hdp/${hdp.version}/hadoop/lib/hadoop-lzo-0.6.0.${hdp.version}.jar:/etc/hadoop/conf/secure",
"tez.counters.max": "2000",
"tez.counters.max.groups": "1000",
"tez.generate.debug.artifacts": "false",
"tez.grouping.max-size": "1073741824",
"tez.grouping.min-size": "16777216",
"tez.grouping.split-waves": "1.7",
"tez.history.logging.service.class": "org.apache.tez.dag.history.logging.ats.ATSHistoryLoggingService",
"tez.lib.uris": "/hdp/apps/${hdp.version}/tez/tez.tar.gz",
"tez.runtime.compress": "true",
"tez.runtime.compress.codec": "org.apache.hadoop.io.compress.SnappyCodec",
"tez.runtime.convert.user-payload.to.history-text": "false",
"tez.runtime.io.sort.mb": "272",
"tez.runtime.optimize.local.fetch": "true",
"tez.runtime.pipelined.sorter.sort.threads": "2",
"tez.runtime.sorter.class": "PIPELINED",
"tez.runtime.unordered.output.buffer.size-mb": "100",
"tez.session.am.dag.submit.timeout.secs": "300",
"tez.session.client.timeout.secs": "-1",
"tez.shuffle-vertex-manager.max-src-fraction": "0.4",
"tez.shuffle-vertex-manager.min-src-fraction": "0.2",
"tez.staging-dir": "/tmp/${user.name}/staging",
"tez.task.am.heartbeat.counter.interval-ms.max": "4000",
"tez.task.generate.counters.per.io": "true",
"tez.task.get-task.sleep.interval-ms.max": "200",
"tez.task.launch.cluster-default.cmd-opts": "-server -Djava.net.preferIPv4Stack=true -Dhdp.version=${hdp.version}",
"tez.task.launch.cmd-opts": "-XX:+PrintGCDetails -verbose:gc -XX:+PrintGCTimeStamps -XX:+UseNUMA -XX:+UseParallelGC",
"tez.task.launch.env": "LD_LIBRARY_PATH=/usr/hdp/${hdp.version}/hadoop/lib/native:/usr/hdp/${hdp.version}/hadoop/lib/native/Linux-amd64-64",
"tez.task.max-events-per-heartbeat": "500",
"tez.task.resource.memory.mb": "1536",
"tez.use.cluster.hadoop-libs": "false"
},
"webhcat-site": {
"templeton.exec.timeout": "60000",
"templeton.hadoop": "/usr/hdp/${hdp.version}/hadoop/bin/hadoop",
"templeton.hadoop.conf.dir": "/etc/hadoop/conf",
"templeton.hcat": "/usr/hdp/${hdp.version}/hive/bin/hcat",
"templeton.hcat.home": "hive.tar.gz/hive/hcatalog",
"templeton.hive.archive": "hdfs:///hdp/apps/${hdp.version}/hive/hive.tar.gz",
"templeton.hive.extra.files": "/usr/hdp/${hdp.version}/tez/conf/tez-site.xml,/usr/hdp/${hdp.version}/tez,/usr/hdp/${hdp.version}/tez/lib",
"templeton.hive.home": "hive.tar.gz/hive",
"templeton.hive.path": "hive.tar.gz/hive/bin/hive",
"templeton.hive.properties": "hive.metastore.local=false,hive.metastore.uris=thrift://%HOSTGROUP::host_group_2%:9083,hive.metastore.sasl.enabled=false,hive.metastore.execute.setugi=true",
"templeton.jar": "/usr/hdp/${hdp.version}/hive/share/webhcat/svr/lib/hive-webhcat-*.jar",
"templeton.libjars": "/usr/hdp/${hdp.version}/zookeeper/zookeeper.jar,/usr/hdp/${hdp.version}/hive/lib/hive-common.jar",
"templeton.override.enabled": "false",
"templeton.pig.archive": "hdfs:///hdp/apps/${hdp.version}/pig/pig.tar.gz",
"templeton.pig.path": "pig.tar.gz/pig/bin/pig",
"templeton.port": "50111",
"templeton.python": "${env.PYTHON_CMD}",
"templeton.sqoop.archive": "hdfs:///hdp/apps/${hdp.version}/sqoop/sqoop.tar.gz",
"templeton.sqoop.home": "sqoop.tar.gz/sqoop",
"templeton.sqoop.path": "sqoop.tar.gz/sqoop/bin/sqoop",
"templeton.storage.class": "org.apache.hive.hcatalog.templeton.tool.ZooKeeperStorage",
"templeton.streaming.jar": "hdfs:///hdp/apps/${hdp.version}/mapreduce/hadoop-streaming.jar",
"templeton.zookeeper.hosts": "%HOSTGROUP::host_group_1%:2181"
},
"yarn-env": {
"apptimelineserver_heapsize": "1024",
"is_supported_yarn_ranger": "true",
"min_user_id": "1000",
"nodemanager_heapsize": "1024",
"resourcemanager_heapsize": "1024",
"yarn_cgroups_enabled": "false",
"yarn_heapsize": "1024",
"yarn_log_dir_prefix": "/var/log/hadoop-yarn",
"yarn_pid_dir_prefix": "/var/run/hadoop-yarn",
"yarn_user": "yarn"
},
"yarn-site": {
"hadoop.registry.rm.enabled": "true",
"hadoop.registry.zk.quorum": "%HOSTGROUP::host_group_1%:2181",
"yarn.acl.enable": "false",
"yarn.admin.acl": "yarn",
"yarn.application.classpath": "$HADOOP_CONF_DIR,/usr/hdp/current/hadoop-client/*,/usr/hdp/current/hadoop-client/lib/*,/usr/hdp/current/hadoop-hdfs-client/*,/usr/hdp/current/hadoop-hdfs-client/lib/*,/usr/hdp/current/hadoop-yarn-client/*,/usr/hdp/current/hadoop-yarn-client/lib/*",
"yarn.client.nodemanager-connect.max-wait-ms": "60000",
"yarn.client.nodemanager-connect.retry-interval-ms": "10000",
"yarn.http.policy": "HTTP_ONLY",
"yarn.log-aggregation-enable": "true",
"yarn.log-aggregation.retain-seconds": "2592000",
"yarn.log.server.url": "http://%HOSTGROUP::host_group_1%:19888/jobhistory/logs",
"yarn.node-labels.enabled": "false",
"yarn.node-labels.fs-store.retry-policy-spec": "2000, 500",
"yarn.node-labels.fs-store.root-dir": "/system/yarn/node-labels",
"yarn.nodemanager.address": "0.0.0.0:45454",
"yarn.nodemanager.admin-env": "MALLOC_ARENA_MAX=$MALLOC_ARENA_MAX",
"yarn.nodemanager.aux-services": "mapreduce_shuffle",
"yarn.nodemanager.aux-services.mapreduce_shuffle.class": "org.apache.hadoop.mapred.ShuffleHandler",
"yarn.nodemanager.bind-host": "0.0.0.0",
"yarn.nodemanager.container-executor.class": "org.apache.hadoop.yarn.server.nodemanager.DefaultContainerExecutor",
"yarn.nodemanager.container-monitor.interval-ms": "3000",
"yarn.nodemanager.delete.debug-delay-sec": "0",
"yarn.nodemanager.disk-health-checker.max-disk-utilization-per-disk-percentage": "90",
"yarn.nodemanager.disk-health-checker.min-free-space-per-disk-mb": "1000",
"yarn.nodemanager.disk-health-checker.min-healthy-disks": "0.25",
"yarn.nodemanager.health-checker.interval-ms": "135000",
"yarn.nodemanager.health-checker.script.timeout-ms": "60000",
"yarn.nodemanager.linux-container-executor.cgroups.hierarchy": "hadoop-yarn",
"yarn.nodemanager.linux-container-executor.cgroups.mount": "false",
"yarn.nodemanager.linux-container-executor.cgroups.strict-resource-usage": "false",
"yarn.nodemanager.linux-container-executor.group": "hadoop",
"yarn.nodemanager.linux-container-executor.resources-handler.class": "org.apache.hadoop.yarn.server.nodemanager.util.DefaultLCEResourcesHandler",
"yarn.nodemanager.local-dirs": "/hadoop/yarn/local",
"yarn.nodemanager.log-aggregation.compression-type": "gz",
"yarn.nodemanager.log-aggregation.debug-enabled": "false",
"yarn.nodemanager.log-aggregation.num-log-files-per-app": "30",
"yarn.nodemanager.log-aggregation.roll-monitoring-interval-seconds": "-1",
"yarn.nodemanager.log-dirs": "/hadoop/yarn/log",
"yarn.nodemanager.log.retain-second": "604800",
"yarn.nodemanager.recovery.dir": "{{yarn_log_dir_prefix}}/nodemanager/recovery-state",
"yarn.nodemanager.recovery.enabled": "true",
"yarn.nodemanager.remote-app-log-dir": "/app-logs",
"yarn.nodemanager.remote-app-log-dir-suffix": "logs",
"yarn.nodemanager.resource.cpu-vcores": "8",
"yarn.nodemanager.resource.memory-mb": "5120",
"yarn.nodemanager.resource.percentage-physical-cpu-limit": "80",
"yarn.nodemanager.vmem-check-enabled": "false",
"yarn.nodemanager.vmem-pmem-ratio": "2.1",
"yarn.resourcemanager.address": "%HOSTGROUP::host_group_1%:8050",
"yarn.resourcemanager.admin.address": "%HOSTGROUP::host_group_1%:8141",
"yarn.resourcemanager.am.max-attempts": "2",
"yarn.resourcemanager.bind-host": "0.0.0.0",
"yarn.resourcemanager.connect.max-wait.ms": "900000",
"yarn.resourcemanager.connect.retry-interval.ms": "30000",
"yarn.resourcemanager.fs.state-store.retry-policy-spec": "2000, 500",
"yarn.resourcemanager.fs.state-store.uri": "",
"yarn.resourcemanager.ha.enabled": "false",
"yarn.resourcemanager.hostname": "%HOSTGROUP::host_group_1%",
"yarn.resourcemanager.nodes.exclude-path": "/etc/hadoop/conf/yarn.exclude",
"yarn.resourcemanager.recovery.enabled": "true",
"yarn.resourcemanager.resource-tracker.address": "%HOSTGROUP::host_group_1%:8025",
"yarn.resourcemanager.scheduler.address": "%HOSTGROUP::host_group_1%:8030",
"yarn.resourcemanager.scheduler.class": "org.apache.hadoop.yarn.server.resourcemanager.scheduler.capacity.CapacityScheduler",
"yarn.resourcemanager.scheduler.monitor.enable": "false",
"yarn.resourcemanager.state-store.max-completed-applications": "${yarn.resourcemanager.max-completed-applications}",
"yarn.resourcemanager.store.class": "org.apache.hadoop.yarn.server.resourcemanager.recovery.ZKRMStateStore",
"yarn.resourcemanager.system-metrics-publisher.dispatcher.pool-size": "10",
"yarn.resourcemanager.system-metrics-publisher.enabled": "true",
"yarn.resourcemanager.webapp.address": "%HOSTGROUP::host_group_1%:8088",
"yarn.resourcemanager.webapp.delegation-token-auth-filter.enabled": "false",
"yarn.resourcemanager.webapp.https.address": "%HOSTGROUP::host_group_1%:8090",
"yarn.resourcemanager.work-preserving-recovery.enabled": "true",
"yarn.resourcemanager.work-preserving-recovery.scheduling-wait-ms": "10000",
"yarn.resourcemanager.zk-acl": "world:anyone:rwcda",
"yarn.resourcemanager.zk-address": "%HOSTGROUP::host_group_1%:2181",
"yarn.resourcemanager.zk-num-retries": "1000",
"yarn.resourcemanager.zk-retry-interval-ms": "1000",
"yarn.resourcemanager.zk-state-store.parent-path": "/rmstore",
"yarn.resourcemanager.zk-timeout-ms": "10000",
"yarn.scheduler.maximum-allocation-mb": "5120",
"yarn.scheduler.maximum-allocation-vcores": "8",
"yarn.scheduler.minimum-allocation-mb": "512",
"yarn.scheduler.minimum-allocation-vcores": "1",
"yarn.timeline-service.address": "%HOSTGROUP::host_group_1%:10200",
"yarn.timeline-service.bind-host": "0.0.0.0",
"yarn.timeline-service.client.max-retries": "30",
"yarn.timeline-service.client.retry-interval-ms": "1000",
"yarn.timeline-service.enabled": "true",
"yarn.timeline-service.generic-application-history.store-class": "org.apache.hadoop.yarn.server.applicationhistoryservice.NullApplicationHistoryStore",
"yarn.timeline-service.http-authentication.simple.anonymous.allowed": "true",
"yarn.timeline-service.http-authentication.type": "simple",
"yarn.timeline-service.leveldb-state-store.path": "/hadoop/yarn/timeline",
"yarn.timeline-service.leveldb-timeline-store.path": "/hadoop/yarn/timeline",
"yarn.timeline-service.leveldb-timeline-store.read-cache-size": "104857600",
"yarn.timeline-service.leveldb-timeline-store.start-time-read-cache-size": "10000",
"yarn.timeline-service.leveldb-timeline-store.start-time-write-cache-size": "10000",
"yarn.timeline-service.leveldb-timeline-store.ttl-interval-ms": "300000",
"yarn.timeline-service.recovery.enabled": "true",
"yarn.timeline-service.state-store-class": "org.apache.hadoop.yarn.server.timeline.recovery.LeveldbTimelineStateStore",
"yarn.timeline-service.store-class": "org.apache.hadoop.yarn.server.timeline.LeveldbTimelineStore",
"yarn.timeline-service.ttl-enable": "true",
"yarn.timeline-service.ttl-ms": "2678400000",
"yarn.timeline-service.webapp.address": "%HOSTGROUP::host_group_1%:8188",
"yarn.timeline-service.webapp.https.address": "%HOSTGROUP::host_group_1%:8190"
},
"zoo.cfg": {
"autopurge.purgeInterval": "24",
"autopurge.snapRetainCount": "30",
"clientPort": "2181",
"dataDir": "/hadoop/zookeeper",
"initLimit": "10",
"syncLimit": "5",
"tickTime": "2000"
},
"zookeeper-env": {
"zk_log_dir": "/var/log/zookeeper",
"zk_pid_dir": "/var/run/zookeeper",
"zk_user": "zookeeper"
}
}