You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by sm...@apache.org on 2016/03/15 19:01:50 UTC

[1/3] ambari git commit: AMBARI-15360. HiveInteractive. (1). Code for 'Hive Server Interactive' and related 'Tez' binaries installation. (2). Parameter declaration in 'params_linux' and 'status_params' related to 'Hive Server Interactive' (Swapan Shridha

Repository: ambari
Updated Branches:
  refs/heads/trunk c44300ea6 -> 63baf1844


http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.2/configs/hive-upgrade.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.2/configs/hive-upgrade.json b/ambari-server/src/test/python/stacks/2.2/configs/hive-upgrade.json
index 9122a69..ee93b74 100644
--- a/ambari-server/src/test/python/stacks/2.2/configs/hive-upgrade.json
+++ b/ambari-server/src/test/python/stacks/2.2/configs/hive-upgrade.json
@@ -10,6 +10,7 @@
         },
         "hive-log4j": {},
         "hive-site": {},
+        "hive-interactive-site": {},
         "hive-exec-log4j": {},
         "core-site": {
             "final": {
@@ -292,6 +293,160 @@
             "hive.compactor.check.interval": "300L",
             "hive.compactor.delta.pct.threshold": "0.1f"
         },
+        "hive-interactive-site": {
+            "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+            "hive.fetch.task.aggr": "false",
+            "hive.execution.engine": "mr",
+            "hive.tez.java.opts": "-server -Xmx546m -Djava.net.preferIPv4Stack=true -XX:NewRatio=8 -XX:+UseNUMA -XX:+UseParallelGC -XX:+PrintGCDetails -verbose:gc -XX:+PrintGCTimeStamps",
+            "hive.server2.table.type.mapping": "CLASSIC",
+            "hive.tez.min.partition.factor": "0.25",
+            "hive.tez.cpu.vcores": "-1",
+            "hive.conf.restricted.list": "hive.security.authenticator.manager,hive.security.authorization.manager,hive.users.in.admin.role",
+            "hive.stats.dbclass": "fs",
+            "hive.tez.auto.reducer.parallelism": "false",
+            "hive.auto.convert.sortmerge.join.to.mapjoin": "false",
+            "hive.server2.thrift.http.path": "cliservice",
+            "hive.exec.scratchdir": "/tmp/hive",
+            "hive.exec.post.hooks": "org.apache.hadoop.hive.ql.hooks.ATSHook",
+            "hive.zookeeper.namespace": "hive_zookeeper_namespace",
+            "hive.cbo.enable": "true",
+            "hive.optimize.index.filter": "true",
+            "hive.optimize.bucketmapjoin": "true",
+            "hive.mapjoin.bucket.cache.size": "10000",
+            "hive.limit.optimize.enable": "true",
+            "hive.fetch.task.conversion.threshold": "1073741824",
+            "hive.exec.max.dynamic.partitions": "5000",
+            "hive.metastore.sasl.enabled": "false",
+            "hive.txn.manager": "org.apache.hadoop.hive.ql.lockmgr.DummyTxnManager",
+            "hive.optimize.constant.propagation": "true",
+            "hive.exec.submitviachild": "false",
+            "hive.metastore.kerberos.principal": "hive/_HOST@EXAMPLE.COM",
+            "hive.txn.max.open.batch": "1000",
+            "hive.exec.compress.output": "false",
+            "hive.merge.size.per.task": "256000000",
+            "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+            "hive.merge.mapfiles": "true",
+            "hive.compactor.initiator.on": "false",
+            "hive.mapjoin.optimized.hashtable": "true",
+            "hive.optimize.metadataonly": "true",
+            "hive.tez.dynamic.partition.pruning.max.event.size": "1048576",
+            "hive.server2.thrift.max.worker.threads": "500",
+            "hive.optimize.sort.dynamic.partition": "false",
+            "hive.server2.thrift.http.port": "10501",
+            "hive.metastore.pre.event.listeners": "org.apache.hadoop.hive.ql.security.authorization.AuthorizationPreEventListener",
+            "hive.metastore.failure.retries": "24",
+            "hive.merge.smallfiles.avgsize": "16000000",
+            "hive.tez.max.partition.factor": "2.0",
+            "hive.server2.transport.mode": "binary",
+            "hive.tez.container.size": "682",
+            "hive.optimize.bucketmapjoin.sortedmerge": "false",
+            "hive.compactor.worker.threads": "0",
+            "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider,org.apache.hadoop.hive.ql.security.authorization.MetaStoreAuthzAPIAuthorizerEmbedOnly",
+            "hive.server2.thrift.port": "10500",
+            "hive.map.aggr.hash.percentmemory": "0.5",
+            "hive.user.install.directory": "/user/",
+            "hive.compute.query.using.stats": "true",
+            "hive.merge.rcfile.block.level": "true",
+            "hive.map.aggr": "true",
+            "hive.metastore.client.connect.retry.delay": "5s",
+            "hive.security.authorization.enabled": "false",
+            "hive.map.aggr.hash.force.flush.memory.threshold": "0.9",
+            "hive.server2.tez.default.queues": "default",
+            "hive.prewarm.enabled": "false",
+            "hive.exec.reducers.max": "1009",
+            "hive.metastore.kerberos.keytab.file": "/etc/security/keytabs/hive.service.keytab",
+            "hive.stats.fetch.partition.stats": "true",
+            "hive.cli.print.header": "false",
+            "hive.server2.thrift.sasl.qop": "auth",
+            "hive.server2.support.dynamic.service.discovery": "true",
+            "hive.fetch.task.conversion": "more",
+            "hive.exec.reducers.bytes.per.reducer": "67108864",
+            "hive.compactor.abortedtxn.threshold": "1000",
+            "hive.tez.dynamic.partition.pruning.max.data.size": "104857600",
+            "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+            "hive.metastore.client.socket.timeout": "1800s",
+            "hive.server2.zookeeper.namespace": "hiveserver2",
+            "hive.prewarm.numcontainers": "10",
+            "hive.vectorized.groupby.flush.percent": "0.1",
+            "hive.server2.enable.doAs": "true",
+            "hive.security.metastore.authenticator.manager": "org.apache.hadoop.hive.ql.security.HadoopDefaultMetastoreAuthenticator",
+            "hive.server2.use.SSL": "false",
+            "hive.enforce.bucketing": "true",
+            "hive.server2.authentication.spnego.keytab": "HTTP/_HOST@EXAMPLE.COM",
+            "hive.mapred.reduce.tasks.speculative.execution": "false",
+            "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+            "hive.exec.dynamic.partition.mode": "nonstrict",
+            "hive.auto.convert.sortmerge.join": "true",
+            "hive.zookeeper.quorum": "c6402.ambari.apache.org:2181,c6403.ambari.apache.org:2181,c6401.ambari.apache.org:2181",
+            "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdConfOnlyAuthorizerFactory",
+            "hive.exec.parallel": "false",
+            "hive.stats.fetch.column.stats": "false",
+            "hive.enforce.sorting": "true",
+            "hive.txn.timeout": "300",
+            "hive.metastore.authorization.storage.checks": "false",
+            "hive.exec.orc.default.stripe.size": "67108864",
+            "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+            "hive.server2.logging.operation.enabled": "true",
+            "hive.merge.tezfiles": "false",
+            "hive.exec.parallel.thread.number": "8",
+            "hive.auto.convert.join.noconditionaltask": "true",
+            "hive.server2.authentication.spnego.principal": "/etc/security/keytabs/spnego.service.keytab",
+            "hive.compactor.worker.timeout": "86400L",
+            "hive.optimize.null.scan": "true",
+            "hive.server2.tez.initialize.default.sessions": "false",
+            "datanucleus.cache.level2.type": "none",
+            "hive.stats.autogather": "true",
+            "hive.auto.convert.join": "true",
+            "hive.exec.submit.local.task.via.child": "true",
+            "hive.merge.mapredfiles": "false",
+            "hive.vectorized.execution.enabled": "true",
+            "hive.cluster.delegation.token.store.zookeeper.connectString": "c6402.ambari.apache.org:2181,c6403.ambari.apache.org:2181,c6401.ambari.apache.org:2181",
+            "hive.vectorized.execution.reduce.enabled": "false",
+            "hive.optimize.reducededuplication": "true",
+            "hive.server2.tez.sessions.per.default.queue": "1",
+            "hive.exec.max.dynamic.partitions.pernode": "2000",
+            "hive.tez.dynamic.partition.pruning": "true",
+            "hive.limit.pushdown.memory.usage": "0.04",
+            "hive.security.metastore.authorization.auth.reads": "true",
+            "ambari.hive.db.schema.name": "hive",
+            "hive.vectorized.groupby.checkinterval": "4096",
+            "hive.smbjoin.cache.rows": "10000",
+            "hive.metastore.execute.setugi": "true",
+            "hive.zookeeper.client.port": "2181",
+            "hive.vectorized.groupby.maxentries": "100000",
+            "hive.cluster.delegation.token.store.class": "org.apache.hadoop.hive.thrift.ZooKeeperTokenStore",
+            "hive.cluster.delegation.token.store.zookeeper.znode": "/hive/cluster/delegation",
+            "javax.jdo.option.ConnectionPassword": "password",
+            "hive.exec.max.created.files": "100000",
+            "hive.map.aggr.hash.min.reduction": "0.5",
+            "hive.orc.splits.include.file.footer": "false",
+            "hive.exec.pre.hooks": "org.apache.hadoop.hive.ql.hooks.ATSHook",
+            "hive.merge.orcfile.stripe.level": "true",
+            "hive.exec.orc.default.compress": "ZLIB",
+            "hive.server2.allow.user.substitution": "true",
+            "hive.metastore.connect.retries": "24",
+            "hive.metastore.server.max.threads": "100000",
+            "hive.exec.orc.compression.strategy": "SPEED",
+            "hive.optimize.reducededuplication.min.reducer": "4",
+            "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9084",
+            "hive.enforce.sortmergebucketmapjoin": "true",
+            "hive.auto.convert.join.noconditionaltask.size": "238026752",
+            "javax.jdo.option.ConnectionUserName": "hive",
+            "hive.tez.log.level": "INFO",
+            "hive.compactor.delta.num.threshold": "10",
+            "hive.exec.dynamic.partition": "true",
+            "hive.server2.authentication": "NONE",
+            "hive.exec.compress.intermediate": "false",
+            "hive.orc.compute.splits.num.threads": "10",
+            "hive.tez.smb.number.waves": "0.5",
+            "hive.convert.join.bucket.mapjoin.tez": "false",
+            "hive.server2.logging.operation.log.location": "/tmp/hive/operation_logs",
+            "hive.tez.input.format": "org.apache.hadoop.hive.ql.io.HiveInputFormat",
+            "hive.exec.failure.hooks": "org.apache.hadoop.hive.ql.hooks.ATSHook",
+            "hive.support.concurrency": "false",
+            "hive.compactor.check.interval": "300L",
+            "hive.compactor.delta.pct.threshold": "0.1f"
+        },
         "hive-exec-log4j": {
             "content": "\n# Licensed to the Apache Software Foundation (ASF) under one\n# or more contributor license agreements.  See the NOTICE file\n# distributed with this work for additional information\n# regarding copyright ownership.  The ASF licenses this file\n# to you under the Apache License, Version 2.0 (the\n# \"License\"); you may not use this file except in compliance\n# with the License.  You may obtain a copy of the License at\n#\n#     http://www.apache.org/licenses/LICENSE-2.0\n#\n# Unless required by applicable law or agreed to in writing, software\n# distributed under the License is distributed on an \"AS IS\" BASIS,\n# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.\n# See the License for the specific language governing permissions and\n# limitations under the License.\n\n# Define some default values that can be overridden by system properties\n\nhive.log.threshold=ALL\nhive.root.logger=INFO,FA\nhive.log.dir=${java.io.tmpdir}/${user.na
 me}\nhive.query.id=hadoop\nhive.log.file=${hive.query.id}.log\n\n# Define the root logger to the system property \"hadoop.root.logger\".\nlog4j.rootLogger=${hive.root.logger}, EventCounter\n\n# Logging Threshold\nlog4j.threshhold=${hive.log.threshold}\n\n#\n# File Appender\n#\n\nlog4j.appender.FA=org.apache.log4j.FileAppender\nlog4j.appender.FA.File=${hive.log.dir}/${hive.log.file}\nlog4j.appender.FA.layout=org.apache.log4j.PatternLayout\n\n# Pattern format: Date LogLevel LoggerName LogMessage\n#log4j.appender.DRFA.layout.ConversionPattern=%d{ISO8601} %p %c: %m%n\n# Debugging Pattern format\nlog4j.appender.FA.layout.ConversionPattern=%d{ISO8601} %-5p %c{2} (%F:%M(%L)) - %m%n\n\n\n#\n# console\n# Add \"console\" to rootlogger above if you want to use this\n#\n\nlog4j.appender.console=org.apache.log4j.ConsoleAppender\nlog4j.appender.console.target=System.err\nlog4j.appender.console.layout=org.apache.log4j.PatternLayout\nlog4j.appender.console.layout.ConversionPattern=%d{yy/MM/dd HH:mm
 :ss} %p %c{2}: %m%n\n\n#custom logging levels\n#log4j.logger.xxx=DEBUG\n\n#\n# Event Counter Appender\n# Sends counts of logging messages at different severity levels to Hadoop Metrics.\n#\nlog4j.appender.EventCounter=org.apache.hadoop.hive.shims.HiveEventCounter\n\n\nlog4j.category.DataNucleus=ERROR,FA\nlog4j.category.Datastore=ERROR,FA\nlog4j.category.Datastore.Schema=ERROR,FA\nlog4j.category.JPOX.Datastore=ERROR,FA\nlog4j.category.JPOX.Plugin=ERROR,FA\nlog4j.category.JPOX.MetaData=ERROR,FA\nlog4j.category.JPOX.Query=ERROR,FA\nlog4j.category.JPOX.General=ERROR,FA\nlog4j.category.JPOX.Enhancer=ERROR,FA\n\n\n# Silence useless ZK logs\nlog4j.logger.org.apache.zookeeper.server.NIOServerCnxn=WARN,FA\nlog4j.logger.org.apache.zookeeper.ClientCnxnSocketNIO=WARN,FA"
         },
@@ -441,6 +596,9 @@
         "hive-site": {
             "tag": "version1"
         },
+        "hive-interactive-site": {
+            "tag": "version1"
+        },
         "webhcat-site": {
             "tag": "version1"
         },


[3/3] ambari git commit: AMBARI-15409. Add tez-interactive-site.xml for 'tez_hive2'. (used by hive2). (Swapan Shridhar via smohanty)

Posted by sm...@apache.org.
AMBARI-15409. Add tez-interactive-site.xml for 'tez_hive2'. (used by hive2). (Swapan Shridhar via smohanty)


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/63baf184
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/63baf184
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/63baf184

Branch: refs/heads/trunk
Commit: 63baf1844c3e1cae8e08f2417b7baba7bb30310c
Parents: 82ac281
Author: Sumit Mohanty <sm...@hortonworks.com>
Authored: Tue Mar 15 10:52:14 2016 -0700
Committer: Sumit Mohanty <sm...@hortonworks.com>
Committed: Tue Mar 15 10:52:14 2016 -0700

----------------------------------------------------------------------
 .../HIVE/configuration/tez-interactive-site.xml | 307 +++++++++++++++++++
 1 file changed, 307 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/63baf184/ambari-server/src/main/resources/stacks/HDP/2.6/services/HIVE/configuration/tez-interactive-site.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/HIVE/configuration/tez-interactive-site.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/HIVE/configuration/tez-interactive-site.xml
new file mode 100644
index 0000000..c4dee3e
--- /dev/null
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/HIVE/configuration/tez-interactive-site.xml
@@ -0,0 +1,307 @@
+<?xml version="1.0"?>
+<!--
+  Licensed to the Apache Software Foundation (ASF) under one
+  or more contributor license agreements.  See the NOTICE file
+  distributed with this work for additional information
+  regarding copyright ownership.  The ASF licenses this file
+  to you under the Apache License, Version 2.0 (the
+  "License"); you may not use this file except in compliance
+  with the License.  You may obtain a copy of the License at
+
+       http://www.apache.org/licenses/LICENSE-2.0
+
+  Unless required by applicable law or agreed to in writing, software
+  distributed under the License is distributed on an "AS IS" BASIS,
+  WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+  See the License for the specific language governing permissions and
+  limitations under the License.
+-->
+
+<configuration supports_final="true">
+
+  <property>
+    <name>tez.am.am-rm.heartbeat.interval-ms.max</name>
+    <value>250</value>
+  </property>
+
+  <property>
+    <name>tez.am.container.idle.release-timeout-max.millis</name>
+    <value>20000</value>
+  </property>
+
+  <property>
+    <name>tez.am.container.idle.release-timeout-min.millis</name>
+    <value>10000</value>
+  </property>
+
+  <property>
+    <name>tez.am.container.reuse.enabled</name>
+    <value>true</value>
+  </property>
+
+  <property>
+    <name>tez.am.container.reuse.locality.delay-allocation-millis</name>
+    <value>250</value>
+  </property>
+
+  <property>
+    <name>tez.am.container.reuse.non-local-fallback.enabled</name>
+    <value>false</value>
+  </property>
+
+  <property>
+    <name>tez.am.container.reuse.rack-fallback.enabled</name>
+    <value>true</value>
+  </property>
+
+  <property>
+    <name>tez.am.launch.cluster-default.cmd-opts</name>
+    <value>-server -Djava.net.preferIPv4Stack=true -Dhdp.version=${hdp.version}</value>
+  </property>
+
+  <property>
+    <name>tez.am.launch.cmd-opts</name>
+    <value>-XX:+PrintGCDetails -verbose:gc -XX:+PrintGCTimeStamps -XX:+UseNUMA -XX:+UseG1GC -XX:+ResizeTLAB</value>
+  </property>
+
+  <property>
+    <name>tez.am.launch.env</name>
+    <value>LD_LIBRARY_PATH=/usr/hdp/${hdp.version}/hadoop/lib/native:/usr/hdp/${hdp.version}/hadoop/lib/native/Linux-amd64-64</value>
+  </property>
+
+  <property>
+    <name>tez.am.log.level</name>
+    <value>INFO</value>
+  </property>
+
+  <property>
+    <name>tez.am.max.app.attempts</name>
+    <value>2</value>
+  </property>
+
+  <property>
+    <name>tez.am.maxtaskfailures.per.node</name>
+    <value>10</value>
+  </property>
+
+  <property>
+    <name>tez.am.resource.memory.mb</name>
+    <value>512</value>
+  </property>
+
+  <property>
+    <name>tez.am.tez-ui.history-url.template</name>
+    <value>__HISTORY_URL_BASE__?viewPath=%2F%23%2Ftez-app%2F__APPLICATION_ID__</value>
+  </property>
+
+  <property>
+    <name>tez.am.view-acls</name>
+    <value>*</value>
+  </property>
+
+  <property>
+    <name>tez.cluster.additional.classpath.prefix</name>
+    <value>/usr/hdp/${hdp.version}/hadoop/lib/hadoop-lzo-0.6.0.${hdp.version}.jar:/etc/hadoop/conf/secure</value>
+  </property>
+
+  <property>
+    <name>tez.counters.max</name>
+    <value>5000</value>
+  </property>
+
+  <property>
+    <name>tez.counters.max.groups</name>
+    <value>1000</value>
+  </property>
+
+  <property>
+    <name>tez.generate.debug.artifacts</name>
+    <value>false</value>
+  </property>
+
+  <property>
+    <name>tez.grouping.max-size</name>
+    <value>1073741824</value>
+  </property>
+
+  <property>
+    <name>tez.grouping.min-size</name>
+    <value>16777216</value>
+  </property>
+
+  <property>
+    <name>tez.grouping.split-waves</name>
+    <value>1.7</value>
+  </property>
+
+  <property>
+    <name>tez.history.logging.service.class</name>
+    <value>org.apache.tez.dag.history.logging.ats.ATSV15HistoryLoggingService</value>
+  </property>
+
+  <property>
+    <name>tez.lib.uris</name>
+    <value>/hdp/apps/${hdp.version}/tez/tez.tar.gz</value>
+  </property>
+
+  <property>
+    <name>tez.runtime.compress</name>
+    <value>true</value>
+  </property>
+
+  <property>
+    <name>tez.runtime.compress.codec</name>
+    <value>org.apache.hadoop.io.compress.SnappyCodec</value>
+  </property>
+
+  <property>
+    <name>tez.runtime.convert.user-payload.to.history-text</name>
+    <value>false</value>
+  </property>
+
+  <property>
+    <name>tez.runtime.io.sort.mb</name>
+    <value>102</value>
+  </property>
+
+  <property>
+    <name>tez.runtime.optimize.local.fetch</name>
+    <value>true</value>
+  </property>
+
+  <property>
+    <name>tez.runtime.pipelined.sorter.sort.threads</name>
+    <value>2</value>
+  </property>
+
+  <property>
+    <name>tez.runtime.sorter.class</name>
+    <value>PIPELINED</value>
+  </property>
+
+  <property>
+    <name>tez.runtime.unordered.output.buffer.size-mb</name>
+    <value>19</value>
+  </property>
+
+  <property>
+    <name>tez.session.am.dag.submit.timeout.secs</name>
+    <value>600</value>
+  </property>
+
+  <property>
+    <name>tez.session.client.timeout.secs</name>
+    <value>-1</value>
+  </property>
+
+  <property>
+    <name>tez.shuffle-vertex-manager.max-src-fraction</name>
+    <value>0.4</value>
+  </property>
+
+  <property>
+    <name>tez.shuffle-vertex-manager.min-src-fraction</name>
+    <value>0.2</value>
+  </property>
+
+  <property>
+    <name>tez.staging-dir</name>
+    <value>/tmp/${user.name}/staging</value>
+  </property>
+
+  <property>
+    <name>tez.task.am.heartbeat.counter.interval-ms.max</name>
+    <value>4000</value>
+  </property>
+
+  <property>
+    <name>tez.task.generate.counters.per.io</name>
+    <value>true</value>
+  </property>
+
+  <property>
+    <name>tez.task.get-task.sleep.interval-ms.max</name>
+    <value>200</value>
+  </property>
+
+  <property>
+    <name>tez.task.launch.cluster-default.cmd-opts</name>
+    <value>-server -Djava.net.preferIPv4Stack=true -Dhdp.version=${hdp.version}</value>
+  </property>
+
+  <property>
+    <name>tez.task.launch.cmd-opts</name>
+    <value>-XX:+PrintGCDetails -verbose:gc -XX:+PrintGCTimeStamps -XX:+UseNUMA -XX:+UseG1GC -XX:+ResizeTLAB</value>
+  </property>
+
+  <property>
+    <name>tez.task.launch.env</name>
+    <value>LD_LIBRARY_PATH=/usr/hdp/${hdp.version}/hadoop/lib/native:/usr/hdp/${hdp.version}/hadoop/lib/native/Linux-amd64-64</value>
+  </property>
+
+  <property>
+    <name>tez.task.max-events-per-heartbeat</name>
+    <value>500</value>
+  </property>
+
+  <property>
+    <name>tez.task.resource.memory.mb</name>
+    <value>256</value>
+  </property>
+
+  <property>
+    <name>tez.tez-ui.history-url.base</name>
+    <value>http://c7001.ambari.apache.org:8080/#/main/views/TEZ/0.7.0.2.3.4.0-1310/TEZ_CLUSTER_INSTANCE</value>
+  </property>
+
+  <property>
+    <name>tez.use.cluster.hadoop-libs</name>
+    <value>false</value>
+  </property>
+
+  <!-- Old settings - potentially useful to change values for LLAP -->
+  <property>
+    <name>tez.dag.recovery.enabled</name>
+    <value>true</value>
+  </property>
+  <property>
+    <name>tez.dag.recovery.max.unflushed.events</name>
+    <value>150000</value>
+  </property>
+  <property>
+    <name>tez.dag.recovery.flush.interval.secs</name>
+    <value>60</value>
+  </property>
+
+  <property>
+    <name>tez.runtime.shuffle.parallel.copies</name>
+    <value>4</value>
+  </property>
+
+  <property>
+    <name>tez.runtime.shuffle.keep-alive.enabled</name>
+    <value>true</value>
+  </property>
+
+  <!-- End of old settings -->
+
+  <!-- New Settings -->
+  <property>
+    <name>tez.runtime.report.partition.stats</name>
+    <value>true</value>
+  </property>
+  <property>
+    <name>tez.runtime.pipelined-shuffle.enabled</name>
+    <value>false</value>
+  </property>
+  <property>
+    <name>tez.runtime.pipelined.sorter.lazy-allocate.memory</name>
+    <value>true</value>
+  </property>
+  <property>
+    <name>tez.grouping.node.local.only</name>
+    <value>true</value>
+  </property>
+  <!-- End of new settings -->
+
+</configuration>


[2/3] ambari git commit: AMBARI-15360. HiveInteractive. (1). Code for 'Hive Server Interactive' and related 'Tez' binaries installation. (2). Parameter declaration in 'params_linux' and 'status_params' related to 'Hive Server Interactive' (Swapan Shridha

Posted by sm...@apache.org.
AMBARI-15360. HiveInteractive. (1). Code for 'Hive Server Interactive' and related 'Tez' binaries installation. (2). Parameter declaration in 'params_linux' and 'status_params' related to 'Hive Server Interactive' (Swapan Shridhar via smohanty)


Project: http://git-wip-us.apache.org/repos/asf/ambari/repo
Commit: http://git-wip-us.apache.org/repos/asf/ambari/commit/82ac281e
Tree: http://git-wip-us.apache.org/repos/asf/ambari/tree/82ac281e
Diff: http://git-wip-us.apache.org/repos/asf/ambari/diff/82ac281e

Branch: refs/heads/trunk
Commit: 82ac281ee69040ded0ed7800587d75cb36173345
Parents: c44300e
Author: Sumit Mohanty <sm...@hortonworks.com>
Authored: Tue Mar 15 10:49:39 2016 -0700
Committer: Sumit Mohanty <sm...@hortonworks.com>
Committed: Tue Mar 15 10:49:39 2016 -0700

----------------------------------------------------------------------
 .../main/python/ambari_agent/AmbariConfig.py    |   1 +
 .../libraries/functions/conf_select.py          |   6 +
 .../libraries/functions/stack_select.py         |   1 +
 .../package/scripts/hive_server_interactive.py  |  33 ++--
 .../0.12.0.2.0/package/scripts/params_linux.py  |  20 ++-
 .../0.12.0.2.0/package/scripts/status_params.py |  17 +-
 .../stacks/HDP/2.6/services/HIVE/metainfo.xml   | 104 ++++++++++++
 .../python/stacks/2.0.6/configs/default.json    |  49 ++++++
 .../stacks/2.0.6/configs/default_client.json    |  49 +++++-
 .../2.0.6/configs/default_hive_nn_ha.json       |  51 +++++-
 .../2.0.6/configs/default_hive_nn_ha_2.json     |  51 +++++-
 .../2.0.6/configs/default_hive_non_hdfs.json    |  51 +++++-
 .../2.0.6/configs/default_no_install.json       |  53 +++++-
 .../python/stacks/2.0.6/configs/secured.json    |  56 ++++++-
 .../stacks/2.0.6/configs/secured_client.json    |  55 ++++++-
 .../hooks/after-INSTALL/test_after_install.py   |  16 ++
 .../test/python/stacks/2.1/configs/default.json |  49 +++++-
 .../2.1/configs/hive-metastore-upgrade.json     | 162 ++++++++++++++++++-
 .../test/python/stacks/2.1/configs/secured.json |  55 ++++++-
 .../python/stacks/2.2/configs/hive-upgrade.json | 158 ++++++++++++++++++
 20 files changed, 999 insertions(+), 38 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-agent/src/main/python/ambari_agent/AmbariConfig.py
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/python/ambari_agent/AmbariConfig.py b/ambari-agent/src/main/python/ambari_agent/AmbariConfig.py
index 01e8daa..7ce5b2b 100644
--- a/ambari-agent/src/main/python/ambari_agent/AmbariConfig.py
+++ b/ambari-agent/src/main/python/ambari_agent/AmbariConfig.py
@@ -90,6 +90,7 @@ servicesToPidNames = {
   'KERBEROS_SERVER': 'kadmind.pid',
   'HIVE_SERVER': 'hive-server.pid',
   'HIVE_METASTORE': 'hive.pid',
+  'HIVE_SERVER_INTERACTIVE' : 'hive-interactive.pid',
   'MYSQL_SERVER': 'mysqld.pid',
   'HUE_SERVER': '/var/run/hue/supervisor.pid',
   'WEBHCAT_SERVER': 'webhcat.pid',

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-common/src/main/python/resource_management/libraries/functions/conf_select.py
----------------------------------------------------------------------
diff --git a/ambari-common/src/main/python/resource_management/libraries/functions/conf_select.py b/ambari-common/src/main/python/resource_management/libraries/functions/conf_select.py
index b970353..770595f 100644
--- a/ambari-common/src/main/python/resource_management/libraries/functions/conf_select.py
+++ b/ambari-common/src/main/python/resource_management/libraries/functions/conf_select.py
@@ -69,6 +69,12 @@ PACKAGE_DIRS = {
       "current_dir": "/usr/hdp/current/hive-client/conf"
     }
   ],
+  "hive2": [
+    {
+      "conf_dir": "/etc/hive2/conf",
+      "current_dir": "/usr/hdp/current/hive-server2-hive2/conf"
+    }
+  ],
   "kafka": [
     {
       "conf_dir": "/etc/kafka/conf",

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-common/src/main/python/resource_management/libraries/functions/stack_select.py
----------------------------------------------------------------------
diff --git a/ambari-common/src/main/python/resource_management/libraries/functions/stack_select.py b/ambari-common/src/main/python/resource_management/libraries/functions/stack_select.py
index c94d956..4a8eeb9 100644
--- a/ambari-common/src/main/python/resource_management/libraries/functions/stack_select.py
+++ b/ambari-common/src/main/python/resource_management/libraries/functions/stack_select.py
@@ -58,6 +58,7 @@ SERVER_ROLE_DIRECTORY_MAP = {
   'HBASE_REGIONSERVER' : 'hbase-regionserver',
   'HIVE_METASTORE' : 'hive-metastore',
   'HIVE_SERVER' : 'hive-server2',
+  'HIVE_SERVER_INTERACTIVE' : 'hive-server2-hive2',
   'WEBHCAT_SERVER' : 'hive-webhcat',
   'KAFKA_BROKER' : 'kafka-broker',
   'KNOX_GATEWAY' : 'knox-server',

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/hive_server_interactive.py
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/hive_server_interactive.py b/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/hive_server_interactive.py
index 3a90164..8a4e7e6 100644
--- a/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/hive_server_interactive.py
+++ b/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/hive_server_interactive.py
@@ -32,61 +32,52 @@ from resource_management.libraries.functions.security_commons import build_expec
     cached_kinit_executor, get_params_from_filesystem, validate_security_config_properties, \
     FILE_TYPE_XML
 from ambari_commons import OSCheck, OSConst
-if OSCheck.is_windows_family():
-    from resource_management.libraries.functions.windows_service_utils import check_windows_service_status
 from setup_ranger_hive import setup_ranger_hive
 from ambari_commons.os_family_impl import OsFamilyImpl
 from ambari_commons.constants import UPGRADE_TYPE_ROLLING
 from resource_management.core.logger import Logger
 
 import hive_server_upgrade
-from hive import hive
-from hive_service import hive_service
-
 
 class HiveServerInteractive(Script):
     def install(self, env):
-        pass
+      import params
+      self.install_packages(env)
 
     def configure(self, env):
-        pass
-
+      pass
 
 @OsFamilyImpl(os_family=OSConst.WINSRV_FAMILY)
 class HiveServerWindows(HiveServerInteractive):
     def start(self, env):
-        pass
+      pass
 
     def stop(self, env):
-        pass
+      pass
 
     def status(self, env):
-        pass
+      pass
 
 
 @OsFamilyImpl(os_family=OsFamilyImpl.DEFAULT)
 class HiveServerDefault(HiveServerInteractive):
     def get_stack_to_component(self):
-        pass
+      return {"HDP": "hive-server2-hive2"}
 
     def start(self, env, upgrade_type=None):
-        pass
-
+      pass
 
     def stop(self, env, upgrade_type=None):
-        pass
-
+      pass
 
     def status(self, env):
-        pass
-
+      pass
 
     def pre_upgrade_restart(self, env, upgrade_type=None):
-        pass
-
+      pass
 
     def security_status(self, env):
-        pass
+      pass
 
 
 if __name__ == "__main__":

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/params_linux.py
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/params_linux.py b/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/params_linux.py
index c5e61e6..215e012 100644
--- a/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/params_linux.py
+++ b/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/params_linux.py
@@ -80,6 +80,11 @@ hive_bin = '/usr/lib/hive/bin'
 hive_lib = '/usr/lib/hive/lib/'
 hive_var_lib = '/var/lib/hive'
 
+# Hive Interactive related paths
+hive_interactive_bin = '/usr/lib/hive2/bin'
+hive_interactive_lib = '/usr/lib/hive2/lib/'
+hive_interactive_var_lib = '/var/lib/hive2'
+
 # These tar folders were used in HDP 2.1
 hadoop_streaming_jars = '/usr/lib/hadoop-mapreduce/hadoop-streaming-*.jar'
 pig_tar_file = '/usr/share/HDP-webhcat/pig.tar.gz'
@@ -88,6 +93,7 @@ sqoop_tar_file = '/usr/share/HDP-webhcat/sqoop*.tar.gz'
 
 hive_specific_configs_supported = False
 hive_etc_dir_prefix = "/etc/hive"
+hive_interactive_etc_dir_prefix = "/etc/hive2"
 limits_conf_dir = "/etc/security/limits.d"
 
 hive_user_nofile_limit = default("/configurations/hive-env/hive_user_nofile_limit", "32000")
@@ -102,6 +108,7 @@ hive_conf_dir = status_params.hive_conf_dir
 hive_config_dir = status_params.hive_config_dir
 hive_client_conf_dir = status_params.hive_client_conf_dir
 hive_server_conf_dir = status_params.hive_server_conf_dir
+hive_interactive_conf_dir = status_params.hive_server_interactive_conf_dir
 
 hcat_conf_dir = '/etc/hive-hcatalog/conf'
 config_dir = '/etc/hive-webhcat/conf'
@@ -122,14 +129,17 @@ if Script.is_stack_greater_or_equal("2.2"):
   hive_specific_configs_supported = True
 
   component_directory = status_params.component_directory
+  component_directory_interactive = status_params.component_directory_interactive
   hadoop_home = '/usr/hdp/current/hadoop-client'
   hive_bin = format('/usr/hdp/current/{component_directory}/bin')
+  hive_interactive_bin = format('/usr/hdp/current/{component_directory_interactive}/bin')
   hive_lib = format('/usr/hdp/current/{component_directory}/lib')
+  hive_interactive_lib = format('/usr/hdp/current/{component_directory_interactive}/lib')
 
   # there are no client versions of these, use server versions directly
   hcat_lib = '/usr/hdp/current/hive-webhcat/share/hcatalog'
   webhcat_bin_dir = '/usr/hdp/current/hive-webhcat/sbin'
-  
+
   # --- Tarballs ---
   # DON'T CHANGE THESE VARIABLE NAMES
   # Values don't change from those in copy_tarball.py
@@ -276,6 +286,7 @@ hive_server2_keytab = config['configurations']['hive-site']['hive.server2.authen
 hive_log_dir = config['configurations']['hive-env']['hive_log_dir']
 hive_pid_dir = status_params.hive_pid_dir
 hive_pid = status_params.hive_pid
+hive_interactive_pid = status_params.hive_interactive_pid
 
 #Default conf dir for client
 hive_conf_dirs_list = [hive_client_conf_dir]
@@ -299,6 +310,7 @@ artifact_dir = format("{tmp_dir}/AMBARI-artifacts/")
 yarn_log_dir_prefix = config['configurations']['yarn-env']['yarn_log_dir_prefix']
 
 target = format("{hive_lib}/{jdbc_jar_name}")
+target_interactive = format("{hive_interactive_lib}/{jdbc_jar_name}")
 jars_in_hive_lib = format("{hive_lib}/*.jar")
 
 start_hiveserver2_path = format("{tmp_dir}/start_hiveserver2_script")
@@ -393,9 +405,13 @@ hive_authorization_enabled = config['configurations']['hive-site']['hive.securit
 
 mysql_jdbc_driver_jar = "/usr/share/java/mysql-connector-java.jar"
 
+hive_site_config = dict(config['configurations']['hive-site'])
 
+hive_interactive_hosts = default('/clusterHostInfo/hive-server2-hive2_hosts', [])
+has_hive_interactive = len(hive_interactive_hosts) > 0
+if has_hive_interactive:
+  hive_interactive_site_config = dict(config['configurations']['hive-interactive-site'])
 
-hive_site_config = dict(config['configurations']['hive-site'])
 ########################################################
 ############# Atlas related params #####################
 ########################################################

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/status_params.py
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/status_params.py b/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/status_params.py
index d0924b9..7aeac24 100644
--- a/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/status_params.py
+++ b/ambari-server/src/main/resources/common-services/HIVE/0.12.0.2.0/package/scripts/status_params.py
@@ -34,10 +34,12 @@ SERVER_ROLE_DIRECTORY_MAP = {
   'HIVE_SERVER' : 'hive-server2',
   'WEBHCAT_SERVER' : 'hive-webhcat',
   'HIVE_CLIENT' : 'hive-client',
-  'HCAT' : 'hive-client'
+  'HCAT' : 'hive-client',
+  'HIVE_SERVER_INTERACTIVE' : 'hive-server2-hive2'
 }
 
 component_directory = Script.get_component_from_role(SERVER_ROLE_DIRECTORY_MAP, "HIVE_CLIENT")
+component_directory_interactive = Script.get_component_from_role(SERVER_ROLE_DIRECTORY_MAP, "HIVE_SERVER_INTERACTIVE")
 
 config = Script.get_config()
 
@@ -49,7 +51,7 @@ if OSCheck.is_windows_family():
 else:
   hive_pid_dir = config['configurations']['hive-env']['hive_pid_dir']
   hive_pid = 'hive-server.pid'
-
+  hive_interactive_pid = 'hive-interactive.pid'
   hive_metastore_pid = 'hive.pid'
 
   hcat_pid_dir = config['configurations']['hive-env']['hcat_pid_dir'] #hcat_pid_dir
@@ -75,11 +77,13 @@ else:
   hadoop_bin_dir = stack_select.get_hadoop_dir("bin")
   webhcat_conf_dir = '/etc/hive-webhcat/conf'
   hive_etc_dir_prefix = "/etc/hive"
+  hive_interactive_etc_dir_prefix = "/etc/hive2"
   hive_conf_dir = "/etc/hive/conf"
   hive_client_conf_dir = "/etc/hive/conf"
 
   # !!! required by ranger to be at this location unless HDP 2.3+
   hive_server_conf_dir = "/etc/hive/conf.server"
+  hive_server_interactive_conf_dir = "/etc/hive2/conf.server"
 
   # HDP 2.2+
   if Script.is_stack_greater_or_equal("2.2"):
@@ -92,11 +96,16 @@ else:
     # ranger is only compatible with this location on HDP 2.3+, not HDP 2.2
     hive_server_conf_dir = format("/usr/hdp/current/{component_directory}/conf/conf.server")
 
+
     # this is NOT a typo.  HDP-2.3 configs for hcatalog/webhcat point to a
     # specific directory which is NOT called 'conf'
     webhcat_conf_dir = '/usr/hdp/current/hive-webhcat/etc/webhcat'
     hive_conf_dir = hive_server_conf_dir
 
+  if Script.is_stack_greater_or_equal("2.6"):
+    hive_server_interactive_conf_dir = format("/usr/hdp/current/{component_directory_interactive}/conf/conf.server")
+
   hive_config_dir = hive_client_conf_dir
-  if 'role' in config and config['role'] in ["HIVE_SERVER", "HIVE_METASTORE"]:
-    hive_config_dir = hive_server_conf_dir
+
+  if 'role' in config and config['role'] in ["HIVE_SERVER", "HIVE_METASTORE", "HIVE_SERVER_INTERACTIVE"]:
+    hive_config_dir = hive_server_conf_dir
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/main/resources/stacks/HDP/2.6/services/HIVE/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/HIVE/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/HIVE/metainfo.xml
index 459845b..ff0f318 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/HIVE/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/HIVE/metainfo.xml
@@ -112,6 +112,110 @@
         <service>PIG</service>
         <service>SLIDER</service>
       </requiredServices>
+      <osSpecifics>
+        <osSpecific>
+          <osFamily>any</osFamily>
+          <packages>
+            <package>
+              <name>mysql-connector-java</name>
+              <skipUpgrade>true</skipUpgrade>
+              <condition>should_install_mysl_connector</condition>
+            </package>
+          </packages>
+        </osSpecific>
+        <osSpecific>
+          <osFamily>redhat7,amazon2015,redhat6,suse11</osFamily>
+          <packages>
+            <package>
+              <name>hive_${stack_version}</name>
+            </package>
+            <package>
+              <name>hive_${stack_version}-hcatalog</name>
+            </package>
+            <package>
+              <name>hive_${stack_version}-webhcat</name>
+            </package>
+            <package>
+              <name>atlas-metadata_${stack_version}-hive-plugin</name>
+              <condition>should_install_hive_atlas</condition>
+            </package>
+            <package>
+              <name>hive2_${stack_version}</name>
+            </package>
+            <package>
+              <name>tez_hive2_${stack_version}</name>
+            </package>
+          </packages>
+        </osSpecific>
+        <osSpecific>
+          <osFamily>amazon2015,redhat6,suse11</osFamily>
+          <packages>
+            <package>
+              <name>mysql</name>
+              <skipUpgrade>true</skipUpgrade>
+              <condition>should_install_mysql</condition>
+            </package>
+          </packages>
+        </osSpecific>
+        <osSpecific>
+          <osFamily>redhat7</osFamily>
+          <packages>
+            <package>
+              <name>mysql-community-release</name>
+              <skipUpgrade>true</skipUpgrade>
+              <condition>should_install_mysql</condition>
+            </package>
+            <package>
+              <name>mysql-community-server</name>
+              <skipUpgrade>true</skipUpgrade>
+              <condition>should_install_mysql</condition>
+            </package>
+          </packages>
+        </osSpecific>
+        <osSpecific>
+          <osFamily>debian7,ubuntu12,ubuntu14</osFamily>
+          <packages>
+            <package>
+              <name>hive-${stack_version}</name>
+            </package>
+            <package>
+              <name>hive-${stack_version}-hcatalog</name>
+            </package>
+            <package>
+              <name>hive-${stack_version}-webhcat</name>
+            </package>
+            <package>
+              <name>atlas-metadata-${stack_version}-hive-plugin</name>
+              <condition>should_install_hive_atlas</condition>
+            </package>
+            <package>
+              <name>hive2_${stack_version}</name>
+            </package>
+            <package>
+              <name>tez_hive2_${stack_version}</name>
+            </package>
+          </packages>
+        </osSpecific>
+        <osSpecific>
+          <osFamily>amazon2015,redhat6,debian7,ubuntu12,ubuntu14</osFamily>
+          <packages>
+            <package>
+              <name>mysql-server</name>
+              <skipUpgrade>true</skipUpgrade>
+              <condition>should_install_mysql</condition>
+            </package>
+          </packages>
+        </osSpecific>
+        <osSpecific>
+          <osFamily>suse11</osFamily>
+          <packages>
+            <package>
+              <name>mysql-client</name>
+              <skipUpgrade>true</skipUpgrade>
+            </package>
+          </packages>
+        </osSpecific>
+      </osSpecifics>
     </service>
   </services>
 </metainfo>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.0.6/configs/default.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.0.6/configs/default.json b/ambari-server/src/test/python/stacks/2.0.6/configs/default.json
index 7b87d40..b23d4b9 100644
--- a/ambari-server/src/test/python/stacks/2.0.6/configs/default.json
+++ b/ambari-server/src/test/python/stacks/2.0.6/configs/default.json
@@ -390,6 +390,45 @@
             "hive.optimize.mapjoin.mapreduce": "true",
             "hive.exec.scratchdir" : "/custompath/tmp/hive"
         },
+        "hive-interactive-site": {
+            "hive.enforce.sorting": "true",
+            "javax.jdo.option.ConnectionPassword": "!`\"' 1",
+            "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+            "hive.optimize.bucketmapjoin.sortedmerge": "true",
+            "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "fs.file.impl.disable.cache": "true",
+            "hive.auto.convert.join.noconditionaltask": "true",
+            "hive.map.aggr": "true",
+            "hive.optimize.index.filter": "true",
+            "hive.security.authorization.enabled": "false",
+            "hive.optimize.reducededuplication.min.reducer": "1",
+            "hive.optimize.bucketmapjoin": "true",
+            "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9084",
+            "hive.mapjoin.bucket.cache.size": "10000",
+            "hive.auto.convert.join.noconditionaltask.size": "1000000000",
+            "hive.vectorized.execution.enabled": "false",
+            "javax.jdo.option.ConnectionUserName": "hive",
+            "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+            "hive.optimize.reducededuplication": "true",
+            "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+            "hive.metastore.client.socket.timeout": "60",
+            "hive.auto.convert.join": "true",
+            "hive.enforce.bucketing": "true",
+            "hive.mapred.reduce.tasks.speculative.execution": "false",
+            "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+            "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+            "hive.auto.convert.sortmerge.join": "true",
+            "fs.hdfs.impl.disable.cache": "true",
+            "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "ambari.hive.db.schema.name": "hive",
+            "hive.metastore.execute.setugi": "true",
+            "hive.auto.convert.sortmerge.join.noconditionaltask": "true",
+            "hive.server2.enable.doAs": "true",
+            "hive.server2.authentication": "NOSASL",
+            "hive.server2.transport.mode": "binary",
+            "hive.optimize.mapjoin.mapreduce": "true",
+            "hive.exec.scratchdir" : "/custompath/tmp/hive"
+        },
 		"ranger-hive-plugin-properties": {
             "XAAUDIT.HDFS.DESTINTATION_FLUSH_INTERVAL_SECONDS": "900",
             "XAAUDIT.HDFS.DESTINATION_DIRECTORY": "hdfs://__REPLACE__NAME_NODE_HOST:8020/ranger/audit/%app-type%/%time:yyyyMMdd%",
@@ -965,6 +1004,13 @@
           "javax.jdo.option.ConnectionDriverName": "true",
           "hive.optimize.bucketmapjoin.sortedmerge": "true"
         }
+      },
+      "hive-interactive-site": {
+        "final": {
+          "javax.jdo.option.ConnectionPassword": "true",
+          "javax.jdo.option.ConnectionDriverName": "true",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true"
+        }
       }
     },
     "configurationTags": {
@@ -1031,6 +1077,9 @@
         "hive-site": {
             "tag": "version1"
         },
+        "hive-interactive-site": {
+            "tag": "version1"
+        },
         "hdfs-log4j": {
             "tag": "version1"
         },

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.0.6/configs/default_client.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.0.6/configs/default_client.json b/ambari-server/src/test/python/stacks/2.0.6/configs/default_client.json
index b1cc572..d5f9d19 100644
--- a/ambari-server/src/test/python/stacks/2.0.6/configs/default_client.json
+++ b/ambari-server/src/test/python/stacks/2.0.6/configs/default_client.json
@@ -401,7 +401,44 @@
             "hive.server2.enable.doAs": "true",
             "hive.server2.transport.mode": "binary",
             "hive.optimize.mapjoin.mapreduce": "true"
-        }, 
+        },
+        "hive-interactive-site": {
+            "hive.enforce.sorting": "true",
+            "javax.jdo.option.ConnectionPassword": "!`\"' 1",
+            "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+            "hive.optimize.bucketmapjoin.sortedmerge": "true",
+            "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "fs.file.impl.disable.cache": "true",
+            "hive.auto.convert.join.noconditionaltask": "true",
+            "hive.map.aggr": "true",
+            "hive.optimize.index.filter": "true",
+            "hive.security.authorization.enabled": "false",
+            "hive.optimize.reducededuplication.min.reducer": "1",
+            "hive.optimize.bucketmapjoin": "true",
+            "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9084",
+            "hive.mapjoin.bucket.cache.size": "10000",
+            "hive.auto.convert.join.noconditionaltask.size": "1000000000",
+            "hive.vectorized.execution.enabled": "false",
+            "javax.jdo.option.ConnectionUserName": "hive",
+            "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+            "hive.optimize.reducededuplication": "true",
+            "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+            "hive.metastore.client.socket.timeout": "60",
+            "hive.auto.convert.join": "true",
+            "hive.enforce.bucketing": "true",
+            "hive.mapred.reduce.tasks.speculative.execution": "false",
+            "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+            "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+            "hive.auto.convert.sortmerge.join": "true",
+            "fs.hdfs.impl.disable.cache": "true",
+            "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "ambari.hive.db.schema.name": "hive",
+            "hive.metastore.execute.setugi": "true",
+            "hive.auto.convert.sortmerge.join.noconditionaltask": "true",
+            "hive.server2.enable.doAs": "true",
+            "hive.server2.transport.mode": "binary",
+            "hive.optimize.mapjoin.mapreduce": "true"
+        },
         "yarn-site": {
             "yarn.nodemanager.disk-health-checker.min-healthy-disks": "0.25", 
             "yarn.nodemanager.container-executor.class": "org.apache.hadoop.yarn.server.nodemanager.DefaultContainerExecutor", 
@@ -680,6 +717,13 @@
           "javax.jdo.option.ConnectionDriverName": "true",
           "hive.optimize.bucketmapjoin.sortedmerge": "true"
         }
+      },
+      "hive-interactive-site": {
+        "final": {
+          "javax.jdo.option.ConnectionPassword": "true",
+          "javax.jdo.option.ConnectionDriverName": "true",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true"
+        }
       }
     },
     "configurationTags": {
@@ -716,6 +760,9 @@
         "hive-site": {
             "tag": "version1"
         },
+        "hive-interactive-site": {
+            "tag": "version1"
+        },
         "hdfs-log4j": {
             "tag": "version1"
         },

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_nn_ha.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_nn_ha.json b/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_nn_ha.json
index 66f103b..808c914 100644
--- a/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_nn_ha.json
+++ b/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_nn_ha.json
@@ -212,7 +212,46 @@
             "hive.server2.transport.mode": "binary",
             "hive.optimize.mapjoin.mapreduce": "true",
             "hive.exec.scratchdir" : "hdfs://c6402.ambari.apache.org:8020/tmp/hive"
-        }, 
+        },
+        "hive-interactive-site": {
+          "hive.enforce.sorting": "true",
+          "javax.jdo.option.ConnectionPassword": "!`\"' 1",
+          "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true",
+          "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+          "fs.file.impl.disable.cache": "true",
+          "hive.auto.convert.join.noconditionaltask": "true",
+          "hive.map.aggr": "true",
+          "hive.optimize.index.filter": "true",
+          "hive.security.authorization.enabled": "false",
+          "hive.optimize.reducededuplication.min.reducer": "1",
+          "hive.optimize.bucketmapjoin": "true",
+          "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9084",
+          "hive.mapjoin.bucket.cache.size": "10000",
+          "hive.auto.convert.join.noconditionaltask.size": "1000000000",
+          "hive.vectorized.execution.enabled": "false",
+          "javax.jdo.option.ConnectionUserName": "hive",
+          "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+          "hive.optimize.reducededuplication": "true",
+          "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+          "hive.metastore.client.socket.timeout": "60",
+          "hive.auto.convert.join": "true",
+          "hive.enforce.bucketing": "true",
+          "hive.mapred.reduce.tasks.speculative.execution": "false",
+          "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+          "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+          "hive.auto.convert.sortmerge.join": "true",
+          "fs.hdfs.impl.disable.cache": "true",
+          "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+          "ambari.hive.db.schema.name": "hive",
+          "hive.metastore.execute.setugi": "true",
+          "hive.auto.convert.sortmerge.join.noconditionaltask": "true",
+          "hive.server2.enable.doAs": "true",
+          "hive.server2.authentication": "NOSASL",
+          "hive.server2.transport.mode": "binary",
+          "hive.optimize.mapjoin.mapreduce": "true",
+          "hive.exec.scratchdir" : "hdfs://c6402.ambari.apache.org:8020/tmp/hive"
+        },
         "ranger-hive-plugin-properties": {
             "XAAUDIT.HDFS.DESTINTATION_FLUSH_INTERVAL_SECONDS": "900", 
             "XAAUDIT.HDFS.DESTINATION_DIRECTORY": "hdfs://__REPLACE__NAME_NODE_HOST:8020/ranger/audit/%app-type%/%time:yyyyMMdd%", 
@@ -510,6 +549,13 @@
           "javax.jdo.option.ConnectionDriverName": "true",
           "hive.optimize.bucketmapjoin.sortedmerge": "true"
         }
+      },
+      "hive-interactive-site": {
+        "final": {
+          "javax.jdo.option.ConnectionPassword": "true",
+          "javax.jdo.option.ConnectionDriverName": "true",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true"
+        }
       }
     },
     "configurationTags": {
@@ -546,6 +592,9 @@
         "hive-site": {
             "tag": "version1"
         },
+        "hive-interactive-site": {
+          "tag": "version1"
+        },
         "hdfs-log4j": {
             "tag": "version1"
         },

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_nn_ha_2.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_nn_ha_2.json b/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_nn_ha_2.json
index d2f5a05..9757db6 100644
--- a/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_nn_ha_2.json
+++ b/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_nn_ha_2.json
@@ -214,7 +214,46 @@
             "hive.server2.transport.mode": "binary",
             "hive.optimize.mapjoin.mapreduce": "true",
             "hive.exec.scratchdir" : "hdfs://mycluster/tmp/hive2"
-        }, 
+        },
+        "hive-interactive-site": {
+          "hive.enforce.sorting": "true",
+          "javax.jdo.option.ConnectionPassword": "!`\"' 1",
+          "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true",
+          "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+          "fs.file.impl.disable.cache": "true",
+          "hive.auto.convert.join.noconditionaltask": "true",
+          "hive.map.aggr": "true",
+          "hive.optimize.index.filter": "true",
+          "hive.security.authorization.enabled": "false",
+          "hive.optimize.reducededuplication.min.reducer": "1",
+          "hive.optimize.bucketmapjoin": "true",
+          "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9084",
+          "hive.mapjoin.bucket.cache.size": "10000",
+          "hive.auto.convert.join.noconditionaltask.size": "1000000000",
+          "hive.vectorized.execution.enabled": "false",
+          "javax.jdo.option.ConnectionUserName": "hive",
+          "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+          "hive.optimize.reducededuplication": "true",
+          "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+          "hive.metastore.client.socket.timeout": "60",
+          "hive.auto.convert.join": "true",
+          "hive.enforce.bucketing": "true",
+          "hive.mapred.reduce.tasks.speculative.execution": "false",
+          "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+          "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+          "hive.auto.convert.sortmerge.join": "true",
+          "fs.hdfs.impl.disable.cache": "true",
+          "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+          "ambari.hive.db.schema.name": "hive",
+          "hive.metastore.execute.setugi": "true",
+          "hive.auto.convert.sortmerge.join.noconditionaltask": "true",
+          "hive.server2.enable.doAs": "true",
+          "hive.server2.authentication": "NOSASL",
+          "hive.server2.transport.mode": "binary",
+          "hive.optimize.mapjoin.mapreduce": "true",
+          "hive.exec.scratchdir" : "hdfs://mycluster/tmp/hive2"
+        },
         "ranger-hive-plugin-properties": {
             "XAAUDIT.HDFS.DESTINTATION_FLUSH_INTERVAL_SECONDS": "900", 
             "XAAUDIT.HDFS.DESTINATION_DIRECTORY": "hdfs://__REPLACE__NAME_NODE_HOST:8020/ranger/audit/%app-type%/%time:yyyyMMdd%", 
@@ -512,6 +551,13 @@
           "javax.jdo.option.ConnectionDriverName": "true",
           "hive.optimize.bucketmapjoin.sortedmerge": "true"
         }
+      },
+      "hive-interactive-site": {
+        "final": {
+          "javax.jdo.option.ConnectionPassword": "true",
+          "javax.jdo.option.ConnectionDriverName": "true",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true"
+        }
       }
     },
     "configurationTags": {
@@ -548,6 +594,9 @@
         "hive-site": {
             "tag": "version1"
         },
+        "hive-interactive-site": {
+          "tag": "version1"
+        },
         "hdfs-log4j": {
             "tag": "version1"
         },

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_non_hdfs.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_non_hdfs.json b/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_non_hdfs.json
index 4648ffc..6d92182 100644
--- a/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_non_hdfs.json
+++ b/ambari-server/src/test/python/stacks/2.0.6/configs/default_hive_non_hdfs.json
@@ -378,7 +378,46 @@
             "hive.server2.transport.mode": "binary",
             "hive.optimize.mapjoin.mapreduce": "true",
             "hive.exec.scratchdir" : "/custompath/tmp/hive"
-        }, 
+        },
+        "hive-interactive-site": {
+            "hive.enforce.sorting": "true",
+            "javax.jdo.option.ConnectionPassword": "!`\"' 1",
+            "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+            "hive.optimize.bucketmapjoin.sortedmerge": "true",
+            "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "fs.file.impl.disable.cache": "true",
+            "hive.auto.convert.join.noconditionaltask": "true",
+            "hive.map.aggr": "true",
+            "hive.optimize.index.filter": "true",
+            "hive.security.authorization.enabled": "false",
+            "hive.optimize.reducededuplication.min.reducer": "1",
+            "hive.optimize.bucketmapjoin": "true",
+            "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9084",
+            "hive.mapjoin.bucket.cache.size": "10000",
+            "hive.auto.convert.join.noconditionaltask.size": "1000000000",
+            "hive.vectorized.execution.enabled": "false",
+            "javax.jdo.option.ConnectionUserName": "hive",
+            "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+            "hive.optimize.reducededuplication": "true",
+            "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+            "hive.metastore.client.socket.timeout": "60",
+            "hive.auto.convert.join": "true",
+            "hive.enforce.bucketing": "true",
+            "hive.mapred.reduce.tasks.speculative.execution": "false",
+            "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+            "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+            "hive.auto.convert.sortmerge.join": "true",
+            "fs.hdfs.impl.disable.cache": "true",
+            "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "ambari.hive.db.schema.name": "hive",
+            "hive.metastore.execute.setugi": "true",
+            "hive.auto.convert.sortmerge.join.noconditionaltask": "true",
+            "hive.server2.enable.doAs": "true",
+            "hive.server2.authentication": "NOSASL",
+            "hive.server2.transport.mode": "binary",
+            "hive.optimize.mapjoin.mapreduce": "true",
+            "hive.exec.scratchdir" : "/custompath/tmp/hive"
+        },
 		"ranger-hive-plugin-properties": {
             "XAAUDIT.HDFS.DESTINTATION_FLUSH_INTERVAL_SECONDS": "900", 
             "XAAUDIT.HDFS.DESTINATION_DIRECTORY": "hdfs://__REPLACE__NAME_NODE_HOST:8020/ranger/audit/%app-type%/%time:yyyyMMdd%", 
@@ -926,6 +965,13 @@
           "javax.jdo.option.ConnectionDriverName": "true",
           "hive.optimize.bucketmapjoin.sortedmerge": "true"
         }
+      },
+      "hive-interactive-site": {
+        "final": {
+          "javax.jdo.option.ConnectionPassword": "true",
+          "javax.jdo.option.ConnectionDriverName": "true",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true"
+        }
       }
     },
     "configurationTags": {
@@ -986,6 +1032,9 @@
         "hive-site": {
             "tag": "version1"
         },
+        "hive-interactive-site": {
+            "tag": "version1"
+        },
         "hdfs-log4j": {
             "tag": "version1"
         },

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.0.6/configs/default_no_install.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.0.6/configs/default_no_install.json b/ambari-server/src/test/python/stacks/2.0.6/configs/default_no_install.json
index 4d58ded..f6bf98e 100644
--- a/ambari-server/src/test/python/stacks/2.0.6/configs/default_no_install.json
+++ b/ambari-server/src/test/python/stacks/2.0.6/configs/default_no_install.json
@@ -380,7 +380,46 @@
             "hive.server2.transport.mode": "binary",
             "hive.optimize.mapjoin.mapreduce": "true",
             "hive.exec.scratchdir" : "/custompath/tmp/hive"
-        }, 
+        },
+        "hive-interactive-site": {
+            "hive.enforce.sorting": "true",
+            "javax.jdo.option.ConnectionPassword": "!`\"' 1",
+            "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+            "hive.optimize.bucketmapjoin.sortedmerge": "true",
+            "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "fs.file.impl.disable.cache": "true",
+            "hive.auto.convert.join.noconditionaltask": "true",
+            "hive.map.aggr": "true",
+            "hive.optimize.index.filter": "true",
+            "hive.security.authorization.enabled": "false",
+            "hive.optimize.reducededuplication.min.reducer": "1",
+            "hive.optimize.bucketmapjoin": "true",
+            "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9084",
+            "hive.mapjoin.bucket.cache.size": "10000",
+            "hive.auto.convert.join.noconditionaltask.size": "1000000000",
+            "hive.vectorized.execution.enabled": "false",
+            "javax.jdo.option.ConnectionUserName": "hive",
+            "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+            "hive.optimize.reducededuplication": "true",
+            "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+            "hive.metastore.client.socket.timeout": "60",
+            "hive.auto.convert.join": "true",
+            "hive.enforce.bucketing": "true",
+            "hive.mapred.reduce.tasks.speculative.execution": "false",
+            "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+            "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+            "hive.auto.convert.sortmerge.join": "true",
+            "fs.hdfs.impl.disable.cache": "true",
+            "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "ambari.hive.db.schema.name": "hive",
+            "hive.metastore.execute.setugi": "true",
+            "hive.auto.convert.sortmerge.join.noconditionaltask": "true",
+            "hive.server2.enable.doAs": "true",
+            "hive.server2.authentication": "NOSASL",
+            "hive.server2.transport.mode": "binary",
+            "hive.optimize.mapjoin.mapreduce": "true",
+            "hive.exec.scratchdir" : "/custompath/tmp/hive"
+        },
         "ranger-hive-plugin-properties": {
             "XAAUDIT.HDFS.DESTINTATION_FLUSH_INTERVAL_SECONDS": "900", 
             "XAAUDIT.HDFS.DESTINATION_DIRECTORY": "hdfs://__REPLACE__NAME_NODE_HOST:8020/ranger/audit/%app-type%/%time:yyyyMMdd%", 
@@ -735,6 +774,13 @@
           "javax.jdo.option.ConnectionDriverName": "true",
           "hive.optimize.bucketmapjoin.sortedmerge": "true"
         }
+      },
+      "hive-interactive-site": {
+        "final": {
+          "javax.jdo.option.ConnectionPassword": "true",
+          "javax.jdo.option.ConnectionDriverName": "true",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true"
+        }
       }
     },
     "configurationTags": {
@@ -771,6 +817,9 @@
         "hive-site": {
             "tag": "version1"
         },
+        "hive-interactive-site": {
+            "tag": "version1"
+        },
         "hdfs-log4j": {
             "tag": "version1"
         },
@@ -840,7 +889,7 @@
         ], 
         "supervisor_hosts": [
             "c6401.ambari.apache.org", 
-            "c6402.ambari.apache.org"
+            "c6pache.org"
         ], 
         "ganglia_monitor_hosts": [
             "c6401.ambari.apache.org", 

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.0.6/configs/secured.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.0.6/configs/secured.json b/ambari-server/src/test/python/stacks/2.0.6/configs/secured.json
index 289d6b2..e053ca0 100644
--- a/ambari-server/src/test/python/stacks/2.0.6/configs/secured.json
+++ b/ambari-server/src/test/python/stacks/2.0.6/configs/secured.json
@@ -491,7 +491,51 @@
             "hive.server2.transport.mode": "binary",
             "hive.server2.authentication.kerberos.keytab": "/etc/security/keytabs/hive.service.keytab",
             "hive.exec.scratchdir" : "/custompath/tmp/hive"
-        }, 
+        },
+        "hive-interactive-site": {
+            "hive.enforce.sorting": "true",
+            "javax.jdo.option.ConnectionPassword": "!`\"' 1",
+            "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+            "hive.optimize.bucketmapjoin.sortedmerge": "true",
+            "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "fs.file.impl.disable.cache": "true",
+            "hive.auto.convert.join.noconditionaltask": "true",
+            "hive.server2.authentication.kerberos.principal": "hive/_HOST@EXAMPLE.COM",
+            "hive.optimize.bucketmapjoin": "true",
+            "hive.map.aggr": "true",
+            "hive.optimize.index.filter": "true",
+            "hive.security.authorization.enabled": "true",
+            "hive.optimize.reducededuplication": "true",
+            "hive.metastore.kerberos.keytab.file": "/etc/security/keytabs/hive.service.keytab",
+            "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9084",
+            "hive.mapjoin.bucket.cache.size": "10000",
+            "hive.auto.convert.join.noconditionaltask.size": "1000000000",
+            "hive.vectorized.execution.enabled": "false",
+            "javax.jdo.option.ConnectionUserName": "hive",
+            "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+            "hive.server2.authentication": "KERBEROS",
+            "hive.metastore.sasl.enabled": "true",
+            "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+            "hive.metastore.client.socket.timeout": "60",
+            "hive.metastore.kerberos.principal": "hive/_HOST@EXAMPLE.COM",
+            "hive.optimize.reducededuplication.min.reducer": "1",
+            "hive.auto.convert.join": "true",
+            "hive.enforce.bucketing": "true",
+            "hive.mapred.reduce.tasks.speculative.execution": "false",
+            "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+            "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+            "hive.auto.convert.sortmerge.join": "true",
+            "fs.hdfs.impl.disable.cache": "true",
+            "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "ambari.hive.db.schema.name": "hive",
+            "hive.metastore.execute.setugi": "true",
+            "hive.auto.convert.sortmerge.join.noconditionaltask": "true",
+            "hive.server2.enable.doAs": "true",
+            "hive.optimize.mapjoin.mapreduce": "true",
+            "hive.server2.transport.mode": "binary",
+            "hive.server2.authentication.kerberos.keytab": "/etc/security/keytabs/hive.service.keytab",
+            "hive.exec.scratchdir" : "/custompath/tmp/hive"
+        },
         "yarn-site": {
             "yarn.nodemanager.disk-health-checker.min-healthy-disks": "0.25", 
             "yarn.nodemanager.container-executor.class": "org.apache.hadoop.yarn.server.nodemanager.LinuxContainerExecutor", 
@@ -841,6 +885,13 @@
           "javax.jdo.option.ConnectionDriverName": "true",
           "hive.optimize.bucketmapjoin.sortedmerge": "true"
         }
+      },
+      "hive-interactive-site": {
+        "final": {
+          "javax.jdo.option.ConnectionPassword": "true",
+          "javax.jdo.option.ConnectionDriverName": "true",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true"
+        }
       }
     },
     "configurationTags": {
@@ -877,6 +928,9 @@
         "hive-site": {
             "tag": "version1389972945450"
         },
+        "hive-interactive-site": {
+            "tag": "version1389972945450"
+        },
         "hdfs-log4j": {
             "tag": "version1389972945450"
         },

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.0.6/configs/secured_client.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.0.6/configs/secured_client.json b/ambari-server/src/test/python/stacks/2.0.6/configs/secured_client.json
index 9c5dae3..48e9756 100644
--- a/ambari-server/src/test/python/stacks/2.0.6/configs/secured_client.json
+++ b/ambari-server/src/test/python/stacks/2.0.6/configs/secured_client.json
@@ -442,7 +442,50 @@
             "hive.optimize.mapjoin.mapreduce": "true",
             "hive.server2.transport.mode": "binary",
             "hive.server2.authentication.kerberos.keytab": "/etc/security/keytabs/hive.service.keytab"
-        }, 
+        },
+        "hive-interactive-site": {
+            "hive.enforce.sorting": "true",
+            "javax.jdo.option.ConnectionPassword": "!`\"' 1",
+            "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+            "hive.optimize.bucketmapjoin.sortedmerge": "true",
+            "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "fs.file.impl.disable.cache": "true",
+            "hive.auto.convert.join.noconditionaltask": "true",
+            "hive.server2.authentication.kerberos.principal": "hive/_HOST@EXAMPLE.COM",
+            "hive.optimize.bucketmapjoin": "true",
+            "hive.map.aggr": "true",
+            "hive.optimize.index.filter": "true",
+            "hive.security.authorization.enabled": "true",
+            "hive.optimize.reducededuplication": "true",
+            "hive.metastore.kerberos.keytab.file": "/etc/security/keytabs/hive.service.keytab",
+            "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9084",
+            "hive.mapjoin.bucket.cache.size": "10000",
+            "hive.auto.convert.join.noconditionaltask.size": "1000000000",
+            "hive.vectorized.execution.enabled": "false",
+            "javax.jdo.option.ConnectionUserName": "hive",
+            "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+            "hive.server2.authentication": "KERBEROS",
+            "hive.metastore.sasl.enabled": "true",
+            "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+            "hive.metastore.client.socket.timeout": "60",
+            "hive.metastore.kerberos.principal": "hive/_HOST@EXAMPLE.COM",
+            "hive.optimize.reducededuplication.min.reducer": "1",
+            "hive.auto.convert.join": "true",
+            "hive.enforce.bucketing": "true",
+            "hive.mapred.reduce.tasks.speculative.execution": "false",
+            "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+            "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+            "hive.auto.convert.sortmerge.join": "true",
+            "fs.hdfs.impl.disable.cache": "true",
+            "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "ambari.hive.db.schema.name": "hive",
+            "hive.metastore.execute.setugi": "true",
+            "hive.auto.convert.sortmerge.join.noconditionaltask": "true",
+            "hive.server2.enable.doAs": "true",
+            "hive.optimize.mapjoin.mapreduce": "true",
+            "hive.server2.transport.mode": "binary",
+            "hive.server2.authentication.kerberos.keytab": "/etc/security/keytabs/hive.service.keytab"
+        },
         "yarn-site": {
             "yarn.nodemanager.disk-health-checker.min-healthy-disks": "0.25", 
             "yarn.nodemanager.container-executor.class": "org.apache.hadoop.yarn.server.nodemanager.LinuxContainerExecutor", 
@@ -703,6 +746,13 @@
           "javax.jdo.option.ConnectionDriverName": "true",
           "hive.optimize.bucketmapjoin.sortedmerge": "true"
         }
+      },
+      "hive-interactive-site": {
+        "final": {
+          "javax.jdo.option.ConnectionPassword": "true",
+          "javax.jdo.option.ConnectionDriverName": "true",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true"
+        }
       }
     },
     "configurationTags": {
@@ -739,6 +789,9 @@
         "hive-site": {
             "tag": "version1389972945450"
         },
+        "hive-interactive-site": {
+            "tag": "version1389972945450"
+        },
         "hdfs-log4j": {
             "tag": "version1389972945450"
         },

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.0.6/hooks/after-INSTALL/test_after_install.py
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.0.6/hooks/after-INSTALL/test_after_install.py b/ambari-server/src/test/python/stacks/2.0.6/hooks/after-INSTALL/test_after_install.py
index 749e73b..31dac56 100644
--- a/ambari-server/src/test/python/stacks/2.0.6/hooks/after-INSTALL/test_after_install.py
+++ b/ambari-server/src/test/python/stacks/2.0.6/hooks/after-INSTALL/test_after_install.py
@@ -88,6 +88,14 @@ class TestHookAfterInstall(RMFTestCase):
     self.assertResourceCalled('Link', '/etc/ranger/kms/conf',
         to = '/usr/hdp/current/ranger-kms/conf',)
 
+    self.assertResourceCalled('Execute', ('cp', '-R', '-p', '/etc/hive2/conf', '/etc/hive2/conf.backup'),
+                              not_if = 'test -e /etc/hive2/conf.backup',
+                              sudo = True)
+    self.assertResourceCalled('Directory', '/etc/hive2/conf',
+                            action = ['delete'])
+    self.assertResourceCalled('Link', '/etc/hive2/conf',
+                            to = '/usr/hdp/current/hive-server2-hive2/conf')
+
     self.assertResourceCalled('Execute', ('cp', '-R', '-p', '/etc/zookeeper/conf', '/etc/zookeeper/conf.backup'),
         not_if = 'test -e /etc/zookeeper/conf.backup',
         sudo = True)
@@ -329,6 +337,14 @@ class TestHookAfterInstall(RMFTestCase):
     self.assertResourceCalled('Link', '/etc/ranger/kms/conf',
         to = '/usr/hdp/current/ranger-kms/conf',)
 
+    self.assertResourceCalled('Execute', ('cp', '-R', '-p', '/etc/hive2/conf', '/etc/hive2/conf.backup'),
+                              not_if = 'test -e /etc/hive2/conf.backup',
+                              sudo = True)
+    self.assertResourceCalled('Directory', '/etc/hive2/conf',
+                              action = ['delete'])
+    self.assertResourceCalled('Link', '/etc/hive2/conf',
+                              to = '/usr/hdp/current/hive-server2-hive2/conf')
+
     self.assertResourceCalled('Execute', ('cp', '-R', '-p', '/etc/zookeeper/conf', '/etc/zookeeper/conf.backup'),
         not_if = 'test -e /etc/zookeeper/conf.backup',
         sudo = True)

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.1/configs/default.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.1/configs/default.json b/ambari-server/src/test/python/stacks/2.1/configs/default.json
index de5eee9..a6bcc24 100644
--- a/ambari-server/src/test/python/stacks/2.1/configs/default.json
+++ b/ambari-server/src/test/python/stacks/2.1/configs/default.json
@@ -522,7 +522,44 @@
             "hive.server2.enable.doAs": "true",
             "hive.server2.transport.mode": "binary",
             "hive.optimize.mapjoin.mapreduce": "true"
-        }, 
+        },
+        "hive-interactive-site": {
+            "hive.enforce.sorting": "true",
+            "javax.jdo.option.ConnectionPassword": "aaa",
+            "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+            "hive.optimize.bucketmapjoin.sortedmerge": "true",
+            "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "fs.file.impl.disable.cache": "true",
+            "hive.auto.convert.join.noconditionaltask": "true",
+            "hive.map.aggr": "true",
+            "hive.optimize.index.filter": "true",
+            "hive.security.authorization.enabled": "false",
+            "hive.optimize.reducededuplication.min.reducer": "1",
+            "hive.optimize.bucketmapjoin": "true",
+            "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9084",
+            "hive.mapjoin.bucket.cache.size": "10000",
+            "hive.auto.convert.join.noconditionaltask.size": "1000000000",
+            "hive.vectorized.execution.enabled": "false",
+            "javax.jdo.option.ConnectionUserName": "hive",
+            "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+            "hive.optimize.reducededuplication": "true",
+            "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+            "hive.metastore.client.socket.timeout": "60",
+            "hive.auto.convert.join": "true",
+            "hive.enforce.bucketing": "true",
+            "hive.mapred.reduce.tasks.speculative.execution": "false",
+            "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+            "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+            "hive.auto.convert.sortmerge.join": "true",
+            "fs.hdfs.impl.disable.cache": "true",
+            "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "ambari.hive.db.schema.name": "hive",
+            "hive.metastore.execute.setugi": "true",
+            "hive.auto.convert.sortmerge.join.noconditionaltask": "true",
+            "hive.server2.enable.doAs": "true",
+            "hive.server2.transport.mode": "binary",
+            "hive.optimize.mapjoin.mapreduce": "true"
+        },
         "yarn-site": {
             "yarn.nodemanager.disk-health-checker.min-healthy-disks": "0.25", 
             "yarn.nodemanager.container-executor.class": "org.apache.hadoop.yarn.server.nodemanager.DefaultContainerExecutor", 
@@ -816,6 +853,13 @@
           "javax.jdo.option.ConnectionDriverName": "true",
           "hive.optimize.bucketmapjoin.sortedmerge": "true"
         }
+      },
+      "hive-interactive-site": {
+        "final": {
+          "javax.jdo.option.ConnectionPassword": "true",
+          "javax.jdo.option.ConnectionDriverName": "true",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true"
+        }
       }
     },
     "configurationTags": {
@@ -852,6 +896,9 @@
         "hive-site": {
             "tag": "version1"
         },
+        "hive-interactive-site": {
+            "tag": "version1"
+        },
         "hdfs-log4j": {
             "tag": "version1"
         },

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.1/configs/hive-metastore-upgrade.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.1/configs/hive-metastore-upgrade.json b/ambari-server/src/test/python/stacks/2.1/configs/hive-metastore-upgrade.json
index 26b0559..6a3a94a 100644
--- a/ambari-server/src/test/python/stacks/2.1/configs/hive-metastore-upgrade.json
+++ b/ambari-server/src/test/python/stacks/2.1/configs/hive-metastore-upgrade.json
@@ -247,7 +247,167 @@
             "hive.support.concurrency": "false", 
             "hive.compactor.check.interval": "300L", 
             "hive.compactor.delta.pct.threshold": "0.1f"
-        }, 
+        },
+        "hive-interactive-site": {
+            "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+            "hive.fetch.task.aggr": "false",
+            "hive.execution.engine": "tez",
+            "hive.tez.java.opts": "-server -Djava.net.preferIPv4Stack=true -XX:NewRatio=8 -XX:+UseNUMA -XX:+UseParallelGC -XX:+PrintGCDetails -verbose:gc -XX:+PrintGCTimeStamps",
+            "hive.server2.table.type.mapping": "CLASSIC",
+            "hive.tez.min.partition.factor": "0.25",
+            "hive.tez.cpu.vcores": "-1",
+            "hive.conf.restricted.list": "hive.security.authenticator.manager,hive.security.authorization.manager,hive.users.in.admin.role",
+            "hive.stats.dbclass": "fs",
+            "hive.tez.auto.reducer.parallelism": "true",
+            "hive.auto.convert.sortmerge.join.to.mapjoin": "false",
+            "hive.server2.thrift.http.path": "cliservice",
+            "hive.exec.scratchdir": "/tmp/hive",
+            "hive.exec.post.hooks": "org.apache.hadoop.hive.ql.hooks.ATSHook",
+            "hive.zookeeper.namespace": "hive_zookeeper_namespace",
+            "hive.cbo.enable": "true",
+            "hive.optimize.index.filter": "true",
+            "hive.optimize.bucketmapjoin": "true",
+            "hive.mapjoin.bucket.cache.size": "10000",
+            "hive.limit.optimize.enable": "true",
+            "hive.fetch.task.conversion.threshold": "1073741824",
+            "hive.exec.max.dynamic.partitions": "5000",
+            "hive.metastore.sasl.enabled": "false",
+            "hive.txn.manager": "org.apache.hadoop.hive.ql.lockmgr.DummyTxnManager",
+            "hive.optimize.constant.propagation": "true",
+            "hive.exec.submitviachild": "false",
+            "hive.metastore.kerberos.principal": "hive/_HOST@EXAMPLE.COM",
+            "hive.txn.max.open.batch": "1000",
+            "hive.exec.compress.output": "false",
+            "hive.merge.size.per.task": "256000000",
+            "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+            "hive.merge.mapfiles": "true",
+            "hive.compactor.initiator.on": "false",
+            "hive.mapjoin.optimized.hashtable": "true",
+            "hive.default.fileformat": "TextFile",
+            "hive.optimize.metadataonly": "true",
+            "hive.tez.dynamic.partition.pruning.max.event.size": "1048576",
+            "hive.server2.thrift.max.worker.threads": "500",
+            "hive.optimize.sort.dynamic.partition": "false",
+            "hive.server2.thrift.http.port": "10001",
+            "hive.metastore.pre.event.listeners": "org.apache.hadoop.hive.ql.security.authorization.AuthorizationPreEventListener",
+            "hive.metastore.failure.retries": "24",
+            "hive.merge.smallfiles.avgsize": "16000000",
+            "hive.tez.max.partition.factor": "2.0",
+            "hive.server2.transport.mode": "binary",
+            "hive.tez.container.size": "170",
+            "hive.optimize.bucketmapjoin.sortedmerge": "false",
+            "hive.compactor.worker.threads": "0",
+            "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+            "hive.server2.thrift.port": "10000",
+            "hive.map.aggr.hash.percentmemory": "0.5",
+            "hive.user.install.directory": "/user/",
+            "datanucleus.autoCreateSchema": "false",
+            "hive.compute.query.using.stats": "true",
+            "hive.merge.rcfile.block.level": "true",
+            "hive.map.aggr": "true",
+            "hive.metastore.client.connect.retry.delay": "5s",
+            "hive.security.authorization.enabled": "false",
+            "hive.map.aggr.hash.force.flush.memory.threshold": "0.9",
+            "hive.server2.tez.default.queues": "default",
+            "hive.prewarm.enabled": "false",
+            "hive.exec.reducers.max": "1009",
+            "hive.metastore.kerberos.keytab.file": "/etc/security/keytabs/hive.service.keytab",
+            "hive.stats.fetch.partition.stats": "true",
+            "hive.cli.print.header": "false",
+            "hive.server2.thrift.sasl.qop": "auth",
+            "hive.server2.support.dynamic.service.discovery": "true",
+            "hive.fetch.task.conversion": "more",
+            "hive.exec.reducers.bytes.per.reducer": "67108864",
+            "hive.compactor.abortedtxn.threshold": "1000",
+            "hive.tez.dynamic.partition.pruning.max.data.size": "104857600",
+            "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+            "hive.metastore.client.socket.timeout": "1800s",
+            "hive.server2.zookeeper.namespace": "hiveserver2",
+            "hive.prewarm.numcontainers": "3",
+            "hive.vectorized.groupby.flush.percent": "0.1",
+            "hive.server2.enable.doAs": "true",
+            "hive.security.metastore.authenticator.manager": "org.apache.hadoop.hive.ql.security.HadoopDefaultMetastoreAuthenticator",
+            "hive.server2.use.SSL": "false",
+            "hive.enforce.bucketing": "false",
+            "hive.server2.authentication.spnego.keytab": "HTTP/_HOST@EXAMPLE.COM",
+            "hive.mapred.reduce.tasks.speculative.execution": "false",
+            "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+            "hive.exec.dynamic.partition.mode": "strict",
+            "hive.auto.convert.sortmerge.join": "true",
+            "hive.zookeeper.quorum": "c6403.ambari.apache.org:2181,c6401.ambari.apache.org:2181,c6402.ambari.apache.org:2181",
+            "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.plugin.sqlstd.SQLStdConfOnlyAuthorizerFactory",
+            "hive.exec.parallel": "false",
+            "hive.stats.fetch.column.stats": "true",
+            "hive.enforce.sorting": "true",
+            "hive.txn.timeout": "300",
+            "hive.metastore.authorization.storage.checks": "false",
+            "hive.exec.orc.default.stripe.size": "67108864",
+            "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+            "hive.server2.logging.operation.enabled": "true",
+            "hive.merge.tezfiles": "false",
+            "hive.exec.parallel.thread.number": "8",
+            "hive.auto.convert.join.noconditionaltask": "true",
+            "hive.server2.authentication.spnego.principal": "/etc/security/keytabs/spnego.service.keytab",
+            "hive.compactor.worker.timeout": "86400L",
+            "hive.optimize.null.scan": "true",
+            "hive.server2.tez.initialize.default.sessions": "false",
+            "datanucleus.cache.level2.type": "none",
+            "hive.stats.autogather": "true",
+            "hive.auto.convert.join": "true",
+            "hive.exec.submit.local.task.via.child": "true",
+            "hive.merge.mapredfiles": "false",
+            "hive.vectorized.execution.enabled": "true",
+            "hive.cluster.delegation.token.store.zookeeper.connectString": "c6403.ambari.apache.org:2181,c6401.ambari.apache.org:2181,c6402.ambari.apache.org:2181",
+            "hive.vectorized.execution.reduce.enabled": "false",
+            "hive.optimize.reducededuplication": "true",
+            "hive.server2.tez.sessions.per.default.queue": "1",
+            "hive.exec.max.dynamic.partitions.pernode": "2000",
+            "hive.tez.dynamic.partition.pruning": "true",
+            "datanucleus.fixedDatastore": "true",
+            "hive.limit.pushdown.memory.usage": "0.04",
+            "hive.security.metastore.authorization.auth.reads": "true",
+            "ambari.hive.db.schema.name": "hive",
+            "hive.vectorized.groupby.checkinterval": "4096",
+            "hive.smbjoin.cache.rows": "10000",
+            "hive.metastore.execute.setugi": "true",
+            "hive.zookeeper.client.port": "2181",
+            "hive.vectorized.groupby.maxentries": "100000",
+            "hive.cluster.delegation.token.store.class": "org.apache.hadoop.hive.thrift.ZooKeeperTokenStore",
+            "hive.cluster.delegation.token.store.zookeeper.znode": "/hive/cluster/delegation",
+            "javax.jdo.option.ConnectionPassword": "password",
+            "hive.exec.max.created.files": "100000",
+            "hive.default.fileformat.managed": "TextFile",
+            "hive.map.aggr.hash.min.reduction": "0.5",
+            "hive.orc.splits.include.file.footer": "false",
+            "hive.exec.pre.hooks": "org.apache.hadoop.hive.ql.hooks.ATSHook",
+            "hive.merge.orcfile.stripe.level": "true",
+            "hive.exec.orc.default.compress": "ZLIB",
+            "hive.server2.allow.user.substitution": "true",
+            "hive.exec.orc.encoding.strategy": "SPEED",
+            "hive.metastore.connect.retries": "24",
+            "hive.metastore.server.max.threads": "100000",
+            "hive.exec.orc.compression.strategy": "SPEED",
+            "hive.optimize.reducededuplication.min.reducer": "4",
+            "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9083",
+            "hive.enforce.sortmergebucketmapjoin": "true",
+            "hive.auto.convert.join.noconditionaltask.size": "59419306",
+            "javax.jdo.option.ConnectionUserName": "hive",
+            "hive.tez.log.level": "INFO",
+            "hive.compactor.delta.num.threshold": "10",
+            "hive.exec.dynamic.partition": "true",
+            "hive.server2.authentication": "NONE",
+            "hive.exec.compress.intermediate": "false",
+            "hive.orc.compute.splits.num.threads": "10",
+            "hive.tez.smb.number.waves": "0.5",
+            "hive.convert.join.bucket.mapjoin.tez": "false",
+            "hive.metastore.schema.verification": "true",
+            "hive.server2.logging.operation.log.location": "/tmp/hive/operation_logs",
+            "hive.tez.input.format": "org.apache.hadoop.hive.ql.io.HiveInputFormat",
+            "hive.exec.failure.hooks": "org.apache.hadoop.hive.ql.hooks.ATSHook",
+            "hive.support.concurrency": "false",
+            "hive.compactor.check.interval": "300L",
+            "hive.compactor.delta.pct.threshold": "0.1f"
+        },
         "hive-exec-log4j": {
             "content": "\n# Licensed to the Apache Software Foundation (ASF) under one\n# or more contributor license agreements.  See the NOTICE file\n# distributed with this work for additional information\n# regarding copyright ownership.  The ASF licenses this file\n# to you under the Apache License, Version 2.0 (the\n# \"License\"); you may not use this file except in compliance\n# with the License.  You may obtain a copy of the License at\n#\n#     http://www.apache.org/licenses/LICENSE-2.0\n#\n# Unless required by applicable law or agreed to in writing, software\n# distributed under the License is distributed on an \"AS IS\" BASIS,\n# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.\n# See the License for the specific language governing permissions and\n# limitations under the License.\n\n# Define some default values that can be overridden by system properties\n\nhive.log.threshold=ALL\nhive.root.logger=INFO,FA\nhive.log.dir=${java.io.tmpdir}/${user.na
 me}\nhive.query.id=hadoop\nhive.log.file=${hive.query.id}.log\n\n# Define the root logger to the system property \"hadoop.root.logger\".\nlog4j.rootLogger=${hive.root.logger}, EventCounter\n\n# Logging Threshold\nlog4j.threshhold=${hive.log.threshold}\n\n#\n# File Appender\n#\n\nlog4j.appender.FA=org.apache.log4j.FileAppender\nlog4j.appender.FA.File=${hive.log.dir}/${hive.log.file}\nlog4j.appender.FA.layout=org.apache.log4j.PatternLayout\n\n# Pattern format: Date LogLevel LoggerName LogMessage\n#log4j.appender.DRFA.layout.ConversionPattern=%d{ISO8601} %p %c: %m%n\n# Debugging Pattern format\nlog4j.appender.FA.layout.ConversionPattern=%d{ISO8601} %-5p %c{2} (%F:%M(%L)) - %m%n\n\n\n#\n# console\n# Add \"console\" to rootlogger above if you want to use this\n#\n\nlog4j.appender.console=org.apache.log4j.ConsoleAppender\nlog4j.appender.console.target=System.err\nlog4j.appender.console.layout=org.apache.log4j.PatternLayout\nlog4j.appender.console.layout.ConversionPattern=%d{yy/MM/dd HH:mm
 :ss} %p %c{2}: %m%n\n\n#custom logging levels\n#log4j.logger.xxx=DEBUG\n\n#\n# Event Counter Appender\n# Sends counts of logging messages at different severity levels to Hadoop Metrics.\n#\nlog4j.appender.EventCounter=org.apache.hadoop.hive.shims.HiveEventCounter\n\n\nlog4j.category.DataNucleus=ERROR,FA\nlog4j.category.Datastore=ERROR,FA\nlog4j.category.Datastore.Schema=ERROR,FA\nlog4j.category.JPOX.Datastore=ERROR,FA\nlog4j.category.JPOX.Plugin=ERROR,FA\nlog4j.category.JPOX.MetaData=ERROR,FA\nlog4j.category.JPOX.Query=ERROR,FA\nlog4j.category.JPOX.General=ERROR,FA\nlog4j.category.JPOX.Enhancer=ERROR,FA\n\n\n# Silence useless ZK logs\nlog4j.logger.org.apache.zookeeper.server.NIOServerCnxn=WARN,FA\nlog4j.logger.org.apache.zookeeper.ClientCnxnSocketNIO=WARN,FA"
         }, 

http://git-wip-us.apache.org/repos/asf/ambari/blob/82ac281e/ambari-server/src/test/python/stacks/2.1/configs/secured.json
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/python/stacks/2.1/configs/secured.json b/ambari-server/src/test/python/stacks/2.1/configs/secured.json
index 6ddab70..80daddf 100644
--- a/ambari-server/src/test/python/stacks/2.1/configs/secured.json
+++ b/ambari-server/src/test/python/stacks/2.1/configs/secured.json
@@ -494,7 +494,50 @@
             "hive.optimize.mapjoin.mapreduce": "true",
             "hive.server2.transport.mode": "binary",
             "hive.server2.authentication.kerberos.keytab": "/etc/security/keytabs/hive.service.keytab"
-        }, 
+        },
+        "hive-interactive-site": {
+          "hive.enforce.sorting": "true",
+          "javax.jdo.option.ConnectionPassword": "asd",
+          "javax.jdo.option.ConnectionDriverName": "com.mysql.jdbc.Driver",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true",
+          "hive.security.metastore.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+          "fs.file.impl.disable.cache": "true",
+          "hive.auto.convert.join.noconditionaltask": "true",
+          "hive.server2.authentication.kerberos.principal": "hive/_HOST@EXAMPLE.COM",
+          "hive.optimize.bucketmapjoin": "true",
+          "hive.map.aggr": "true",
+          "hive.optimize.index.filter": "true",
+          "hive.security.authorization.enabled": "true",
+          "hive.optimize.reducededuplication": "true",
+          "hive.metastore.kerberos.keytab.file": "/etc/security/keytabs/hive.service.keytab",
+          "hive.metastore.uris": "thrift://c6402.ambari.apache.org:9084",
+          "hive.mapjoin.bucket.cache.size": "10000",
+          "hive.auto.convert.join.noconditionaltask.size": "1000000000",
+          "hive.vectorized.execution.enabled": "false",
+          "javax.jdo.option.ConnectionUserName": "hive",
+          "hive.metastore.cache.pinobjtypes": "Table,Database,Type,FieldSchema,Order",
+          "hive.server2.authentication": "KERBEROS",
+          "hive.metastore.sasl.enabled": "true",
+          "hive.metastore.warehouse.dir": "/apps/hive/warehouse",
+          "hive.metastore.client.socket.timeout": "60",
+          "hive.metastore.kerberos.principal": "hive/_HOST@EXAMPLE.COM",
+          "hive.optimize.reducededuplication.min.reducer": "1",
+          "hive.auto.convert.join": "true",
+          "hive.enforce.bucketing": "true",
+          "hive.mapred.reduce.tasks.speculative.execution": "false",
+          "hive.security.authenticator.manager": "org.apache.hadoop.hive.ql.security.ProxyUserAuthenticator",
+          "javax.jdo.option.ConnectionURL": "jdbc:mysql://c6402.ambari.apache.org/hive?createDatabaseIfNotExist=true",
+          "hive.auto.convert.sortmerge.join": "true",
+          "fs.hdfs.impl.disable.cache": "true",
+          "hive.security.authorization.manager": "org.apache.hadoop.hive.ql.security.authorization.StorageBasedAuthorizationProvider",
+          "ambari.hive.db.schema.name": "hive",
+          "hive.metastore.execute.setugi": "true",
+          "hive.auto.convert.sortmerge.join.noconditionaltask": "true",
+          "hive.server2.enable.doAs": "true",
+          "hive.optimize.mapjoin.mapreduce": "true",
+          "hive.server2.transport.mode": "binary",
+          "hive.server2.authentication.kerberos.keytab": "/etc/security/keytabs/hive.service.keytab"
+        },
         "yarn-site": {
             "yarn.nodemanager.disk-health-checker.min-healthy-disks": "0.25", 
             "yarn.nodemanager.container-executor.class": "org.apache.hadoop.yarn.server.nodemanager.LinuxContainerExecutor", 
@@ -801,6 +844,13 @@
           "javax.jdo.option.ConnectionDriverName": "true",
           "hive.optimize.bucketmapjoin.sortedmerge": "true"
         }
+      },
+      "hive-interactive-site": {
+        "final": {
+          "javax.jdo.option.ConnectionPassword": "true",
+          "javax.jdo.option.ConnectionDriverName": "true",
+          "hive.optimize.bucketmapjoin.sortedmerge": "true"
+        }
       }
     },
     "configurationTags": {
@@ -837,6 +887,9 @@
         "hive-site": {
             "tag": "version1389972945450"
         },
+        "hive-interactive-site": {
+          "tag": "version1389972945450"
+        },
         "hdfs-log4j": {
             "tag": "version1389972945450"
         },