You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by jo...@apache.org on 2016/12/03 03:43:13 UTC

[1/7] ambari git commit: AMBARI-19068. Logsearch has a 'required' property while adding Ranger which quickly goes off upon navigating to the tab. (jaimin)

Repository: ambari
Updated Branches:
  refs/heads/branch-feature-AMBARI-18456 a58c39c9c -> 3bbe75c3b


AMBARI-19068. Logsearch has a 'required' property while adding Ranger which quickly goes off upon navigating to the tab. (jaimin)


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

Branch: refs/heads/branch-feature-AMBARI-18456
Commit: 5901b95bc3c4d718b7e7723baf403f3d5522647a
Parents: 0c837a6
Author: Jaimin Jetly <ja...@hortonworks.com>
Authored: Fri Dec 2 14:02:25 2016 -0800
Committer: Jaimin Jetly <ja...@hortonworks.com>
Committed: Fri Dec 2 14:04:05 2016 -0800

----------------------------------------------------------------------
 .../LOGSEARCH/0.5.0/configuration/logsearch-properties.xml         | 2 +-
 1 file changed, 1 insertion(+), 1 deletion(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/5901b95b/ambari-server/src/main/resources/common-services/LOGSEARCH/0.5.0/configuration/logsearch-properties.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/common-services/LOGSEARCH/0.5.0/configuration/logsearch-properties.xml b/ambari-server/src/main/resources/common-services/LOGSEARCH/0.5.0/configuration/logsearch-properties.xml
index 10ca9ae..b474c5d 100644
--- a/ambari-server/src/main/resources/common-services/LOGSEARCH/0.5.0/configuration/logsearch-properties.xml
+++ b/ambari-server/src/main/resources/common-services/LOGSEARCH/0.5.0/configuration/logsearch-properties.xml
@@ -238,7 +238,7 @@
   </property>
   <property>
     <name>logsearch.spnego.kerberos.enabled</name>
-    <value/>
+    <value>false</value>
     <display-name>Http Spnego enabled</display-name>
     <description>Enable SPNEGO based authentication on the Log Search UI</description>
     <value-attributes>


[3/7] ambari git commit: Revert "Revert "AMBARI-18888: Ambari-agent: Create configuration files with JCEKS information""

Posted by jo...@apache.org.
Revert "Revert "AMBARI-18888: Ambari-agent: Create configuration files with JCEKS information""

Set the value of credential store enabled on the execution command in AmbariManagementController::createHostAction() where the cluster and service are available.

This reverts commit 60a6bd4575fb87fc26c4a277cbabf850ef2089e1.


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

Branch: refs/heads/branch-feature-AMBARI-18456
Commit: db46822fbf50c5e5222bdec094b3a011584f8ee8
Parents: e465c0e
Author: Nahappan Somasundaram <ns...@hortonworks.com>
Authored: Fri Dec 2 08:23:43 2016 -0800
Committer: Nahappan Somasundaram <ns...@hortonworks.com>
Committed: Fri Dec 2 15:39:25 2016 -0800

----------------------------------------------------------------------
 ambari-agent/conf/unix/ambari-agent.ini         |   3 +
 .../ambari_agent/CustomServiceOrchestrator.py   | 120 +++++++++++++++++++
 ambari-agent/src/packages/tarball/all.xml       |  30 +++++
 .../ambari/server/agent/ExecutionCommand.java   |  28 +++++
 .../ambari/server/agent/HeartBeatHandler.java   |   2 +-
 .../AmbariManagementControllerImpl.java         |   5 +
 .../server/agent/TestHeartbeatHandler.java      |  28 +++--
 7 files changed, 207 insertions(+), 9 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/db46822f/ambari-agent/conf/unix/ambari-agent.ini
----------------------------------------------------------------------
diff --git a/ambari-agent/conf/unix/ambari-agent.ini b/ambari-agent/conf/unix/ambari-agent.ini
index 61948d4..d6fcf5f 100644
--- a/ambari-agent/conf/unix/ambari-agent.ini
+++ b/ambari-agent/conf/unix/ambari-agent.ini
@@ -46,6 +46,9 @@ keysdir=/var/lib/ambari-agent/keys
 server_crt=ca.crt
 passphrase_env_var_name=AMBARI_PASSPHRASE
 ssl_verify_cert=0
+credential_lib_dir=/var/lib/ambari-agent/cred/lib
+credential_conf_dir=/var/lib/ambari-agent/cred/conf
+credential_shell_cmd=org.apache.hadoop.security.alias.CredentialShell
 
 [services]
 pidLookupPath=/var/run/

http://git-wip-us.apache.org/repos/asf/ambari/blob/db46822f/ambari-agent/src/main/python/ambari_agent/CustomServiceOrchestrator.py
----------------------------------------------------------------------
diff --git a/ambari-agent/src/main/python/ambari_agent/CustomServiceOrchestrator.py b/ambari-agent/src/main/python/ambari_agent/CustomServiceOrchestrator.py
index 11c8cbe..f9ed4cf 100644
--- a/ambari-agent/src/main/python/ambari_agent/CustomServiceOrchestrator.py
+++ b/ambari-agent/src/main/python/ambari_agent/CustomServiceOrchestrator.py
@@ -29,6 +29,8 @@ from FileCache import FileCache
 from AgentException import AgentException
 from PythonExecutor import PythonExecutor
 from PythonReflectiveExecutor import PythonReflectiveExecutor
+from resource_management.core.utils import PasswordString
+import subprocess
 import Constants
 import hostname
 
@@ -65,6 +67,11 @@ class CustomServiceOrchestrator():
   REFLECTIVELY_RUN_COMMANDS = FREQUENT_COMMANDS # -- commands which run a lot and often (this increases their speed)
   DONT_BACKUP_LOGS_FOR_COMMANDS = FREQUENT_COMMANDS
 
+  # Path where hadoop credential JARS will be available
+  DEFAULT_CREDENTIAL_SHELL_LIB_PATH = '/var/lib/ambari-agent/cred/lib'
+  DEFAULT_CREDENTIAL_CONF_DIR = '/var/lib/ambari-agent/cred/conf'
+  DEFAULT_CREDENTIAL_SHELL_CMD = 'org.apache.hadoop.security.alias.CredentialShell'
+
   def __init__(self, config, controller):
     self.config = config
     self.tmp_dir = config.get('agent', 'prefix')
@@ -78,6 +85,14 @@ class CustomServiceOrchestrator():
     # cache reset will be called on every agent registration
     controller.registration_listeners.append(self.file_cache.reset)
 
+    # Construct the hadoop credential lib JARs path
+    self.credential_shell_lib_path = os.path.join(config.get('security', 'credential_lib_dir',
+                                                             self.DEFAULT_CREDENTIAL_SHELL_LIB_PATH), '*')
+
+    self.credential_conf_dir = config.get('security', 'credential_conf_dir', self.DEFAULT_CREDENTIAL_CONF_DIR)
+
+    self.credential_shell_cmd = config.get('security', 'credential_shell_cmd', self.DEFAULT_CREDENTIAL_SHELL_CMD)
+
     # Clean up old status command files if any
     try:
       os.unlink(self.status_commands_stdout)
@@ -114,6 +129,102 @@ class CustomServiceOrchestrator():
     else:
       return PythonExecutor(self.tmp_dir, self.config)
 
+  def getProviderDirectory(self, service_name):
+    """
+    Gets the path to the service conf folder where the JCEKS file will be created.
+
+    :param service_name: Name of the service, for example, HIVE
+    :return: lower case path to the service conf folder
+    """
+
+    # The stack definition scripts of the service can move the
+    # JCEKS file around to where it wants, which is usually
+    # /etc/<service_name>/conf
+
+    conf_dir = os.path.join(self.credential_conf_dir, service_name.lower())
+    if not os.path.exists(conf_dir):
+      os.makedirs(conf_dir, 0644)
+
+    return conf_dir
+
+  def getAffectedConfigTypes(self, commandJson):
+    """
+    Gets the affected config types for the service in this command
+
+    :param commandJson:
+    :return:
+    """
+    return commandJson.get('configuration_attributes')
+
+  def getCredentialProviderPropertyName(self):
+    """
+    Gets the property name used by the hadoop credential provider
+    :return:
+    """
+    return 'hadoop.security.credential.provider.path'
+
+  def generateJceks(self, commandJson):
+    """
+    Generates the JCEKS file with passwords for the service specified in commandJson
+
+    :param commandJson: command JSON
+    :return: An exit value from the external process that generated the JCEKS file. None if
+    there are no passwords in the JSON.
+    """
+    cmd_result = None
+    roleCommand = None
+    if 'roleCommand' in commandJson:
+      roleCommand = commandJson['roleCommand']
+
+    logger.info('generateJceks: roleCommand={0}'.format(roleCommand))
+
+    # Password properties for a config type, if present,
+    # are under configuration_attributes:config_type:hidden:{prop1:attributes1, prop2, attributes2}
+    passwordProperties = {}
+    config_types = self.getAffectedConfigTypes(commandJson)
+    for config_type in config_types:
+      elem = config_types.get(config_type)
+      hidden = elem.get('hidden')
+      if hidden is not None:
+        passwordProperties[config_type] = hidden
+
+    # Set up the variables for the external command to generate a JCEKS file
+    java_home = commandJson['hostLevelParams']['java_home']
+    java_bin = '{java_home}/bin/java'.format(java_home=java_home)
+
+    cs_lib_path = self.credential_shell_lib_path
+    serviceName = commandJson['serviceName']
+
+    # Gather the password values and remove them from the configuration
+    configs = commandJson.get('configurations')
+    for key, value in passwordProperties.items():
+      config = configs.get(key)
+      if config is not None:
+        file_path = os.path.join(self.getProviderDirectory(serviceName), "{0}.jceks".format(key))
+        if os.path.exists(file_path):
+          os.remove(file_path)
+        provider_path = 'jceks://file{file_path}'.format(file_path=file_path)
+        logger.info('provider_path={0}'.format(provider_path))
+        for alias in value:
+          pwd = config.get(alias)
+          if pwd is not None:
+            # Remove the clear text password
+            config.pop(alias, None)
+            # Add JCEKS provider path instead
+            config[self.getCredentialProviderPropertyName()] = provider_path
+            logger.debug("config={0}".format(config))
+            protected_pwd = PasswordString(pwd)
+            # Generate the JCEKS file
+            cmd = (java_bin, '-cp', cs_lib_path, self.credential_shell_cmd, 'create',
+                   alias, '-value', protected_pwd, '-provider', provider_path)
+            logger.info(cmd)
+            cmd_result = subprocess.call(cmd)
+            logger.info('cmd_result = {0}'.format(cmd_result))
+            os.chmod(file_path, 0644) # group and others should have read access so that the service user can read
+
+    return cmd_result
+
+
   def runCommand(self, command, tmpoutfile, tmperrfile, forced_command_name=None,
                  override_output_files=True, retry=False):
     """
@@ -174,6 +285,15 @@ class CustomServiceOrchestrator():
         handle.on_background_command_started = self.map_task_to_process
         del command['__handle']
 
+      # If command contains credentialStoreEnabled, then
+      # generate the JCEKS file for the configurations.
+      credentialStoreEnabled = False
+      if 'credentialStoreEnabled' in command:
+        credentialStoreEnabled = (command['credentialStoreEnabled'] == "true")
+
+      if credentialStoreEnabled == True:
+        self.generateJceks(command)
+
       json_path = self.dump_command_to_json(command, retry)
       pre_hook_tuple = self.resolve_hook_script_path(hook_dir,
           self.PRE_HOOK_PREFIX, command_name, script_type)

http://git-wip-us.apache.org/repos/asf/ambari/blob/db46822f/ambari-agent/src/packages/tarball/all.xml
----------------------------------------------------------------------
diff --git a/ambari-agent/src/packages/tarball/all.xml b/ambari-agent/src/packages/tarball/all.xml
index c481208..f8a54e3 100644
--- a/ambari-agent/src/packages/tarball/all.xml
+++ b/ambari-agent/src/packages/tarball/all.xml
@@ -190,4 +190,34 @@
       <outputDirectory>/var/lib/${project.artifactId}/data</outputDirectory>
     </file>
   </files>
+  <moduleSets>
+    <moduleSet>
+      <binaries>
+        <includeDependencies>false</includeDependencies>
+        <outputDirectory>/var/lib/${project.artifactId}/cred/lib</outputDirectory>
+        <unpack>false</unpack>
+        <directoryMode>755</directoryMode>
+        <fileMode>644</fileMode>
+        <dependencySets>
+          <dependencySet>
+            <outputDirectory>/var/lib/${project.artifactId}/cred/lib</outputDirectory>
+            <unpack>false</unpack>
+            <includes>
+              <include>commons-cli:commons-cli</include>
+              <include>commons-collections:commons-collections</include>
+              <include>commons-configuration:commons-configuration</include>
+              <include>commons-io:commons-io:jar:${commons.io.version}</include>
+              <include>commons-lang:commons-lang</include>
+              <include>commons-logging:commons-logging</include>
+              <include>com.google.guava:guava</include>
+              <include>org.slf4j:slf4j-api</include>
+              <include>org.apache.hadoop:hadoop-common</include>
+              <include>org.apache.hadoop:hadoop-auth</include>
+              <include>org.apache.htrace:htrace-core</include>
+            </includes>
+          </dependencySet>
+        </dependencySets>
+      </binaries>
+    </moduleSet>
+  </moduleSets>
 </assembly>

http://git-wip-us.apache.org/repos/asf/ambari/blob/db46822f/ambari-server/src/main/java/org/apache/ambari/server/agent/ExecutionCommand.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/agent/ExecutionCommand.java b/ambari-server/src/main/java/org/apache/ambari/server/agent/ExecutionCommand.java
index ef1ee4f..e46167a 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/agent/ExecutionCommand.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/agent/ExecutionCommand.java
@@ -112,6 +112,13 @@ public class ExecutionCommand extends AgentCommand {
   @SerializedName("availableServices")
   private Map<String, String> availableServices = new HashMap<>();
 
+  /**
+   * "true" or "false" indicating whether this
+   * service is enabled for credential store use.
+   */
+  @SerializedName("credentialStoreEnabled")
+  private String credentialStoreEnabled;
+
   public String getCommandId() {
     return commandId;
   }
@@ -295,6 +302,27 @@ public class ExecutionCommand extends AgentCommand {
 	this.serviceType = serviceType;
   }
 
+  /**
+   * Get a value indicating whether this service is enabled
+   * for credential store use.
+   *
+   * @return "true" or "false", any other value is
+   * considered as "false"
+   */
+  public String getCredentialStoreEnabled() {
+    return credentialStoreEnabled;
+  }
+
+  /**
+   * Set a value indicating whether this service is enabled
+   * for credential store use.
+   *
+   * @param credentialStoreEnabled
+   */
+  public void setCredentialStoreEnabled(String credentialStoreEnabled) {
+    this.credentialStoreEnabled = credentialStoreEnabled;
+  }
+
   public String getComponentName() {
     return componentName;
   }

http://git-wip-us.apache.org/repos/asf/ambari/blob/db46822f/ambari-server/src/main/java/org/apache/ambari/server/agent/HeartBeatHandler.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/agent/HeartBeatHandler.java b/ambari-server/src/main/java/org/apache/ambari/server/agent/HeartBeatHandler.java
index 75bef30..a25b875 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/agent/HeartBeatHandler.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/agent/HeartBeatHandler.java
@@ -329,7 +329,7 @@ public class HeartBeatHandler {
           case BACKGROUND_EXECUTION_COMMAND:
           case EXECUTION_COMMAND: {
             ExecutionCommand ec = (ExecutionCommand)ac;
-            LOG.info("HeartBeatHandler.sendCommands: sending ExecutionCommand for host {}, role {}, roleCommand {}, and command ID {}, taskId {}",
+            LOG.info("HeartBeatHandler.sendCommands: sending ExecutionCommand for host {}, role {}, roleCommand {}, and command ID {}, task ID {}",
                      ec.getHostname(), ec.getRole(), ec.getRoleCommand(), ec.getCommandId(), ec.getTaskId());
             Map<String, String> hlp = ec.getHostLevelParams();
             if (hlp != null) {

http://git-wip-us.apache.org/repos/asf/ambari/blob/db46822f/ambari-server/src/main/java/org/apache/ambari/server/controller/AmbariManagementControllerImpl.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/controller/AmbariManagementControllerImpl.java b/ambari-server/src/main/java/org/apache/ambari/server/controller/AmbariManagementControllerImpl.java
index 0448b9f..aa35f09 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/controller/AmbariManagementControllerImpl.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/controller/AmbariManagementControllerImpl.java
@@ -2118,6 +2118,10 @@ public class AmbariManagementControllerImpl implements AmbariManagementControlle
     execCmd.setConfigurationAttributes(configurationAttributes);
     execCmd.setConfigurationTags(configTags);
 
+    // Get the value of credential store enabled from the DB
+    Service clusterService = cluster.getService(serviceName);
+    execCmd.setCredentialStoreEnabled(String.valueOf(clusterService.isCredentialStoreEnabled()));
+
     // Create a local copy for each command
     Map<String, String> commandParams = new TreeMap<String, String>();
     if (commandParamsInp != null) { // if not defined
@@ -2324,6 +2328,7 @@ public class AmbariManagementControllerImpl implements AmbariManagementControlle
 
     execCmd.setAvailableServicesFromServiceInfoMap(ambariMetaInfo.getServices(stackId.getStackName(), stackId.getStackVersion()));
 
+
     if ((execCmd != null) && (execCmd.getConfigurationTags().containsKey("cluster-env"))) {
       LOG.debug("AmbariManagementControllerImpl.createHostAction: created ExecutionCommand for host {}, role {}, roleCommand {}, and command ID {}, with cluster-env tags {}",
         execCmd.getHostname(), execCmd.getRole(), execCmd.getRoleCommand(), execCmd.getCommandId(), execCmd.getConfigurationTags().get("cluster-env").get("tag"));

http://git-wip-us.apache.org/repos/asf/ambari/blob/db46822f/ambari-server/src/test/java/org/apache/ambari/server/agent/TestHeartbeatHandler.java
----------------------------------------------------------------------
diff --git a/ambari-server/src/test/java/org/apache/ambari/server/agent/TestHeartbeatHandler.java b/ambari-server/src/test/java/org/apache/ambari/server/agent/TestHeartbeatHandler.java
index a50a116..ac58f64 100644
--- a/ambari-server/src/test/java/org/apache/ambari/server/agent/TestHeartbeatHandler.java
+++ b/ambari-server/src/test/java/org/apache/ambari/server/agent/TestHeartbeatHandler.java
@@ -48,6 +48,7 @@ import java.io.File;
 import java.io.FileWriter;
 import java.io.IOException;
 import java.util.ArrayList;
+import java.util.Collection;
 import java.util.Collections;
 import java.util.Date;
 import java.util.HashMap;
@@ -171,22 +172,31 @@ public class TestHeartbeatHandler {
     ActionManager am = actionManagerTestHelper.getMockActionManager();
     expect(am.getTasks(anyObject(List.class))).andReturn(new ArrayList<HostRoleCommand>());
     replay(am);
+
+    Cluster cluster = heartbeatTestHelper.getDummyCluster();
+    Service hdfs = cluster.addService(HDFS);
+    hdfs.addServiceComponent(DATANODE);
+    hdfs.addServiceComponent(NAMENODE);
+    hdfs.addServiceComponent(SECONDARY_NAMENODE);
+    Collection<Host> hosts = cluster.getHosts();
+    assertEquals(hosts.size(), 1);
+
     Clusters fsm = clusters;
-    fsm.addHost(DummyHostname1);
-    Host hostObject = clusters.getHost(DummyHostname1);
+    Host hostObject = hosts.iterator().next();
     hostObject.setIPv4("ipv4");
     hostObject.setIPv6("ipv6");
     hostObject.setOsType(DummyOsType);
 
+    String hostname = hostObject.getHostName();
     ActionQueue aq = new ActionQueue();
 
     HeartBeatHandler handler = new HeartBeatHandler(fsm, aq, am, injector);
     Register reg = new Register();
     HostInfo hi = new HostInfo();
-    hi.setHostName(DummyHostname1);
+    hi.setHostName(hostname);
     hi.setOS(DummyOs);
     hi.setOSRelease(DummyOSRelease);
-    reg.setHostname(DummyHostname1);
+    reg.setHostname(hostname);
     reg.setHardwareProfile(hi);
     reg.setAgentVersion(metaInfo.getServerVersion());
     handler.handleRegistration(reg);
@@ -195,19 +205,21 @@ public class TestHeartbeatHandler {
 
     ExecutionCommand execCmd = new ExecutionCommand();
     execCmd.setRequestAndStage(2, 34);
-    execCmd.setHostname(DummyHostname1);
-    aq.enqueue(DummyHostname1, new ExecutionCommand());
+    execCmd.setHostname(hostname);
+    execCmd.setClusterName(cluster.getClusterName());
+    execCmd.setServiceName(HDFS);
+    aq.enqueue(hostname, execCmd);
     HeartBeat hb = new HeartBeat();
     hb.setResponseId(0);
     HostStatus hs = new HostStatus(Status.HEALTHY, DummyHostStatus);
     List<Alert> al = new ArrayList<Alert>();
     al.add(new Alert());
     hb.setNodeStatus(hs);
-    hb.setHostname(DummyHostname1);
+    hb.setHostname(hostname);
 
     handler.handleHeartBeat(hb);
     assertEquals(HostState.HEALTHY, hostObject.getState());
-    assertEquals(0, aq.dequeueAll(DummyHostname1).size());
+    assertEquals(0, aq.dequeueAll(hostname).size());
   }
 
 


[4/7] ambari git commit: AMBARI-19071. Ambari Server Unit Test failure on branch-2.5 and trunk: org.apache.ambari.server.state.ServicePropertiesTest.validatePropertySchemaOfServiceXMLs.(vbrodetskyi)

Posted by jo...@apache.org.
AMBARI-19071. Ambari Server Unit Test failure on branch-2.5 and trunk: org.apache.ambari.server.state.ServicePropertiesTest.validatePropertySchemaOfServiceXMLs.(vbrodetskyi)


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

Branch: refs/heads/branch-feature-AMBARI-18456
Commit: 6c411baa2f3d9bae5ba7e781ac3b4cddbf18ae82
Parents: db46822
Author: Vitaly Brodetskyi <vb...@hortonworks.com>
Authored: Sat Dec 3 01:53:32 2016 +0200
Committer: Vitaly Brodetskyi <vb...@hortonworks.com>
Committed: Sat Dec 3 01:53:32 2016 +0200

----------------------------------------------------------------------
 .../1.0/services/HAPPY/configuration/happy-alert-config.xml     | 5 +++++
 .../1.0/services/HBASE/configuration/hbase-alert-config.xml     | 5 +++++
 .../PERF/1.0/services/HDFS/configuration/hdfs-alert-config.xml  | 5 +++++
 .../1.0/services/SLEEPY/configuration/sleepy-alert-config.xml   | 5 +++++
 .../PERF/1.0/services/SNOW/configuration/snow-alert-config.xml  | 5 +++++
 .../PERF/1.0/services/YARN/configuration/yarn-alert-config.xml  | 5 +++++
 .../1.0/services/ZOOKEEPER/configuration/zk-alert-config.xml    | 5 +++++
 7 files changed, 35 insertions(+)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/6c411baa/ambari-server/src/main/resources/stacks/PERF/1.0/services/HAPPY/configuration/happy-alert-config.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/PERF/1.0/services/HAPPY/configuration/happy-alert-config.xml b/ambari-server/src/main/resources/stacks/PERF/1.0/services/HAPPY/configuration/happy-alert-config.xml
index 760e706..392eea7 100644
--- a/ambari-server/src/main/resources/stacks/PERF/1.0/services/HAPPY/configuration/happy-alert-config.xml
+++ b/ambari-server/src/main/resources/stacks/PERF/1.0/services/HAPPY/configuration/happy-alert-config.xml
@@ -26,6 +26,7 @@
             This property describes type of alert behaviour.
             There are three types percentage, timeout, flip.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -37,6 +38,7 @@
             set to "percentage". Here you should set percent of successful
             alert checks.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -48,6 +50,7 @@
             set to "timeout". Here you should set result which alert will
             return after timeout, false|true|none.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
     <property>
@@ -58,6 +61,7 @@
             set to "timeout". Here you should set number of seconds for
             alert to sleep.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -69,6 +73,7 @@
             set to "flip". Here you should set number of minutes at which
             the alert should flip from true|false.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/6c411baa/ambari-server/src/main/resources/stacks/PERF/1.0/services/HBASE/configuration/hbase-alert-config.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/PERF/1.0/services/HBASE/configuration/hbase-alert-config.xml b/ambari-server/src/main/resources/stacks/PERF/1.0/services/HBASE/configuration/hbase-alert-config.xml
index 760e706..392eea7 100644
--- a/ambari-server/src/main/resources/stacks/PERF/1.0/services/HBASE/configuration/hbase-alert-config.xml
+++ b/ambari-server/src/main/resources/stacks/PERF/1.0/services/HBASE/configuration/hbase-alert-config.xml
@@ -26,6 +26,7 @@
             This property describes type of alert behaviour.
             There are three types percentage, timeout, flip.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -37,6 +38,7 @@
             set to "percentage". Here you should set percent of successful
             alert checks.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -48,6 +50,7 @@
             set to "timeout". Here you should set result which alert will
             return after timeout, false|true|none.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
     <property>
@@ -58,6 +61,7 @@
             set to "timeout". Here you should set number of seconds for
             alert to sleep.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -69,6 +73,7 @@
             set to "flip". Here you should set number of minutes at which
             the alert should flip from true|false.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/6c411baa/ambari-server/src/main/resources/stacks/PERF/1.0/services/HDFS/configuration/hdfs-alert-config.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/PERF/1.0/services/HDFS/configuration/hdfs-alert-config.xml b/ambari-server/src/main/resources/stacks/PERF/1.0/services/HDFS/configuration/hdfs-alert-config.xml
index 760e706..392eea7 100644
--- a/ambari-server/src/main/resources/stacks/PERF/1.0/services/HDFS/configuration/hdfs-alert-config.xml
+++ b/ambari-server/src/main/resources/stacks/PERF/1.0/services/HDFS/configuration/hdfs-alert-config.xml
@@ -26,6 +26,7 @@
             This property describes type of alert behaviour.
             There are three types percentage, timeout, flip.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -37,6 +38,7 @@
             set to "percentage". Here you should set percent of successful
             alert checks.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -48,6 +50,7 @@
             set to "timeout". Here you should set result which alert will
             return after timeout, false|true|none.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
     <property>
@@ -58,6 +61,7 @@
             set to "timeout". Here you should set number of seconds for
             alert to sleep.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -69,6 +73,7 @@
             set to "flip". Here you should set number of minutes at which
             the alert should flip from true|false.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/6c411baa/ambari-server/src/main/resources/stacks/PERF/1.0/services/SLEEPY/configuration/sleepy-alert-config.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/PERF/1.0/services/SLEEPY/configuration/sleepy-alert-config.xml b/ambari-server/src/main/resources/stacks/PERF/1.0/services/SLEEPY/configuration/sleepy-alert-config.xml
index 760e706..392eea7 100644
--- a/ambari-server/src/main/resources/stacks/PERF/1.0/services/SLEEPY/configuration/sleepy-alert-config.xml
+++ b/ambari-server/src/main/resources/stacks/PERF/1.0/services/SLEEPY/configuration/sleepy-alert-config.xml
@@ -26,6 +26,7 @@
             This property describes type of alert behaviour.
             There are three types percentage, timeout, flip.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -37,6 +38,7 @@
             set to "percentage". Here you should set percent of successful
             alert checks.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -48,6 +50,7 @@
             set to "timeout". Here you should set result which alert will
             return after timeout, false|true|none.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
     <property>
@@ -58,6 +61,7 @@
             set to "timeout". Here you should set number of seconds for
             alert to sleep.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -69,6 +73,7 @@
             set to "flip". Here you should set number of minutes at which
             the alert should flip from true|false.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/6c411baa/ambari-server/src/main/resources/stacks/PERF/1.0/services/SNOW/configuration/snow-alert-config.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/PERF/1.0/services/SNOW/configuration/snow-alert-config.xml b/ambari-server/src/main/resources/stacks/PERF/1.0/services/SNOW/configuration/snow-alert-config.xml
index 760e706..392eea7 100644
--- a/ambari-server/src/main/resources/stacks/PERF/1.0/services/SNOW/configuration/snow-alert-config.xml
+++ b/ambari-server/src/main/resources/stacks/PERF/1.0/services/SNOW/configuration/snow-alert-config.xml
@@ -26,6 +26,7 @@
             This property describes type of alert behaviour.
             There are three types percentage, timeout, flip.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -37,6 +38,7 @@
             set to "percentage". Here you should set percent of successful
             alert checks.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -48,6 +50,7 @@
             set to "timeout". Here you should set result which alert will
             return after timeout, false|true|none.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
     <property>
@@ -58,6 +61,7 @@
             set to "timeout". Here you should set number of seconds for
             alert to sleep.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -69,6 +73,7 @@
             set to "flip". Here you should set number of minutes at which
             the alert should flip from true|false.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/6c411baa/ambari-server/src/main/resources/stacks/PERF/1.0/services/YARN/configuration/yarn-alert-config.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/PERF/1.0/services/YARN/configuration/yarn-alert-config.xml b/ambari-server/src/main/resources/stacks/PERF/1.0/services/YARN/configuration/yarn-alert-config.xml
index 760e706..392eea7 100644
--- a/ambari-server/src/main/resources/stacks/PERF/1.0/services/YARN/configuration/yarn-alert-config.xml
+++ b/ambari-server/src/main/resources/stacks/PERF/1.0/services/YARN/configuration/yarn-alert-config.xml
@@ -26,6 +26,7 @@
             This property describes type of alert behaviour.
             There are three types percentage, timeout, flip.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -37,6 +38,7 @@
             set to "percentage". Here you should set percent of successful
             alert checks.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -48,6 +50,7 @@
             set to "timeout". Here you should set result which alert will
             return after timeout, false|true|none.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
     <property>
@@ -58,6 +61,7 @@
             set to "timeout". Here you should set number of seconds for
             alert to sleep.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -69,6 +73,7 @@
             set to "flip". Here you should set number of minutes at which
             the alert should flip from true|false.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 

http://git-wip-us.apache.org/repos/asf/ambari/blob/6c411baa/ambari-server/src/main/resources/stacks/PERF/1.0/services/ZOOKEEPER/configuration/zk-alert-config.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/PERF/1.0/services/ZOOKEEPER/configuration/zk-alert-config.xml b/ambari-server/src/main/resources/stacks/PERF/1.0/services/ZOOKEEPER/configuration/zk-alert-config.xml
index 760e706..392eea7 100644
--- a/ambari-server/src/main/resources/stacks/PERF/1.0/services/ZOOKEEPER/configuration/zk-alert-config.xml
+++ b/ambari-server/src/main/resources/stacks/PERF/1.0/services/ZOOKEEPER/configuration/zk-alert-config.xml
@@ -26,6 +26,7 @@
             This property describes type of alert behaviour.
             There are three types percentage, timeout, flip.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -37,6 +38,7 @@
             set to "percentage". Here you should set percent of successful
             alert checks.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -48,6 +50,7 @@
             set to "timeout". Here you should set result which alert will
             return after timeout, false|true|none.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
     <property>
@@ -58,6 +61,7 @@
             set to "timeout". Here you should set number of seconds for
             alert to sleep.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 
@@ -69,6 +73,7 @@
             set to "flip". Here you should set number of minutes at which
             the alert should flip from true|false.
         </description>
+        <on-ambari-upgrade add="false"/>
     </property>
 
 


[6/7] ambari git commit: AMBARI-19073 - Ambari Contrib View Has Inconsistent Version in pom.xml (jonathanhurley)

Posted by jo...@apache.org.
AMBARI-19073 - Ambari Contrib View Has Inconsistent Version in pom.xml (jonathanhurley)


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

Branch: refs/heads/branch-feature-AMBARI-18456
Commit: 3096c79dfa666341154d70a7b5a0b61eb7696d52
Parents: 2f6942f
Author: Jonathan Hurley <jh...@hortonworks.com>
Authored: Fri Dec 2 21:23:23 2016 -0500
Committer: Jonathan Hurley <jh...@hortonworks.com>
Committed: Fri Dec 2 22:34:13 2016 -0500

----------------------------------------------------------------------
 contrib/views/ambari-views-package/pom.xml | 4 ++--
 1 file changed, 2 insertions(+), 2 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/3096c79d/contrib/views/ambari-views-package/pom.xml
----------------------------------------------------------------------
diff --git a/contrib/views/ambari-views-package/pom.xml b/contrib/views/ambari-views-package/pom.xml
index cb070e6..16c9985 100644
--- a/contrib/views/ambari-views-package/pom.xml
+++ b/contrib/views/ambari-views-package/pom.xml
@@ -26,7 +26,7 @@
   <parent>
     <groupId>org.apache.ambari.contrib.views</groupId>
     <artifactId>ambari-contrib-views</artifactId>
-    <version>2.5.0.0.0</version>
+    <version>2.0.0.0-SNAPSHOT</version>
   </parent>
 
   <description>
@@ -120,4 +120,4 @@
 
     </plugins>
   </build>
-</project>
\ No newline at end of file
+</project>


[7/7] ambari git commit: Merge branch 'trunk' into branch-feature-AMBARI-18456

Posted by jo...@apache.org.
Merge branch 'trunk' into branch-feature-AMBARI-18456


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

Branch: refs/heads/branch-feature-AMBARI-18456
Commit: 3bbe75c3bd7b1a913905137465c19b2c7f7c9ba9
Parents: a58c39c 3096c79
Author: Jonathan Hurley <jh...@hortonworks.com>
Authored: Fri Dec 2 22:40:18 2016 -0500
Committer: Jonathan Hurley <jh...@hortonworks.com>
Committed: Fri Dec 2 22:40:18 2016 -0500

----------------------------------------------------------------------
 ambari-agent/conf/unix/ambari-agent.ini         |   3 +
 .../ambari_agent/CustomServiceOrchestrator.py   | 120 +++++++++++++++++++
 ambari-agent/src/packages/tarball/all.xml       |  30 +++++
 .../ambari/server/agent/ExecutionCommand.java   |  28 +++++
 .../ambari/server/agent/HeartBeatHandler.java   |   2 +-
 .../AmbariManagementControllerImpl.java         |   5 +
 .../configuration/logsearch-properties.xml      |   2 +-
 .../HDP/2.6/services/ACCUMULO/metainfo.xml      |   2 +-
 .../stacks/HDP/2.6/services/FALCON/metainfo.xml |   2 +-
 .../stacks/HDP/2.6/services/FLUME/metainfo.xml  |   2 +-
 .../stacks/HDP/2.6/services/HBASE/metainfo.xml  |   2 +-
 .../stacks/HDP/2.6/services/HDFS/metainfo.xml   |   2 +-
 .../stacks/HDP/2.6/services/HIVE/metainfo.xml   |   2 +-
 .../stacks/HDP/2.6/services/KAFKA/metainfo.xml  |   2 +-
 .../stacks/HDP/2.6/services/KNOX/metainfo.xml   |   2 +-
 .../stacks/HDP/2.6/services/MAHOUT/metainfo.xml |   2 +-
 .../stacks/HDP/2.6/services/OOZIE/metainfo.xml  |   1 +
 .../stacks/HDP/2.6/services/PIG/metainfo.xml    |   2 +-
 .../stacks/HDP/2.6/services/RANGER/metainfo.xml |   2 +-
 .../HDP/2.6/services/RANGER_KMS/metainfo.xml    |   2 +-
 .../stacks/HDP/2.6/services/SLIDER/metainfo.xml |   2 +-
 .../stacks/HDP/2.6/services/SPARK/metainfo.xml  |   2 +-
 .../stacks/HDP/2.6/services/SPARK2/metainfo.xml |   2 +-
 .../stacks/HDP/2.6/services/SQOOP/metainfo.xml  |   2 +-
 .../stacks/HDP/2.6/services/STORM/metainfo.xml  |   2 +-
 .../stacks/HDP/2.6/services/TEZ/metainfo.xml    |   2 +-
 .../stacks/HDP/2.6/services/YARN/metainfo.xml   |   4 +-
 .../HDP/2.6/services/ZOOKEEPER/metainfo.xml     |   2 +-
 .../HAPPY/configuration/happy-alert-config.xml  |   5 +
 .../HBASE/configuration/hbase-alert-config.xml  |   5 +
 .../HDFS/configuration/hdfs-alert-config.xml    |   5 +
 .../configuration/sleepy-alert-config.xml       |   5 +
 .../SNOW/configuration/snow-alert-config.xml    |   5 +
 .../YARN/configuration/yarn-alert-config.xml    |   5 +
 .../ZOOKEEPER/configuration/zk-alert-config.xml |   5 +
 .../server/agent/TestHeartbeatHandler.java      |  28 +++--
 ambari-web/app/messages.js                      |   1 -
 .../configs/objects/service_config_property.js  |   7 --
 .../widgets/slider_config_widget_view.js        |   7 +-
 contrib/views/ambari-views-package/pom.xml      |   4 +-
 40 files changed, 269 insertions(+), 46 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/3bbe75c3/ambari-server/src/main/java/org/apache/ambari/server/controller/AmbariManagementControllerImpl.java
----------------------------------------------------------------------


[5/7] ambari git commit: AMBARI-19070. Incorrect version metadata for HDP 2.6 (smohanty)

Posted by jo...@apache.org.
AMBARI-19070. Incorrect version metadata for HDP 2.6 (smohanty)


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

Branch: refs/heads/branch-feature-AMBARI-18456
Commit: 2f6942f5b6d09e07ed31e28ed70a741db899fbc7
Parents: 6c411ba
Author: Sumit Mohanty <sm...@hortonworks.com>
Authored: Fri Dec 2 18:48:09 2016 -0800
Committer: Sumit Mohanty <sm...@hortonworks.com>
Committed: Fri Dec 2 18:48:51 2016 -0800

----------------------------------------------------------------------
 .../main/resources/stacks/HDP/2.6/services/ACCUMULO/metainfo.xml | 2 +-
 .../main/resources/stacks/HDP/2.6/services/FALCON/metainfo.xml   | 2 +-
 .../main/resources/stacks/HDP/2.6/services/FLUME/metainfo.xml    | 2 +-
 .../main/resources/stacks/HDP/2.6/services/HBASE/metainfo.xml    | 2 +-
 .../src/main/resources/stacks/HDP/2.6/services/HDFS/metainfo.xml | 2 +-
 .../src/main/resources/stacks/HDP/2.6/services/HIVE/metainfo.xml | 2 +-
 .../main/resources/stacks/HDP/2.6/services/KAFKA/metainfo.xml    | 2 +-
 .../src/main/resources/stacks/HDP/2.6/services/KNOX/metainfo.xml | 2 +-
 .../main/resources/stacks/HDP/2.6/services/MAHOUT/metainfo.xml   | 2 +-
 .../main/resources/stacks/HDP/2.6/services/OOZIE/metainfo.xml    | 1 +
 .../src/main/resources/stacks/HDP/2.6/services/PIG/metainfo.xml  | 2 +-
 .../main/resources/stacks/HDP/2.6/services/RANGER/metainfo.xml   | 2 +-
 .../resources/stacks/HDP/2.6/services/RANGER_KMS/metainfo.xml    | 2 +-
 .../main/resources/stacks/HDP/2.6/services/SLIDER/metainfo.xml   | 2 +-
 .../main/resources/stacks/HDP/2.6/services/SPARK/metainfo.xml    | 2 +-
 .../main/resources/stacks/HDP/2.6/services/SPARK2/metainfo.xml   | 2 +-
 .../main/resources/stacks/HDP/2.6/services/SQOOP/metainfo.xml    | 2 +-
 .../main/resources/stacks/HDP/2.6/services/STORM/metainfo.xml    | 2 +-
 .../src/main/resources/stacks/HDP/2.6/services/TEZ/metainfo.xml  | 2 +-
 .../src/main/resources/stacks/HDP/2.6/services/YARN/metainfo.xml | 4 ++--
 .../resources/stacks/HDP/2.6/services/ZOOKEEPER/metainfo.xml     | 2 +-
 21 files changed, 22 insertions(+), 21 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/ACCUMULO/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/ACCUMULO/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/ACCUMULO/metainfo.xml
index ec81f3e..3f619af 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/ACCUMULO/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/ACCUMULO/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>ACCUMULO</name>
-      <version>1.7.0.2.5</version>
+      <version>1.7.0.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/FALCON/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/FALCON/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/FALCON/metainfo.xml
index 0b54385..b449388 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/FALCON/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/FALCON/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>FALCON</name>
-      <version>0.10.0.2.5</version>
+      <version>0.10.0.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/FLUME/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/FLUME/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/FLUME/metainfo.xml
index 33ceb43..0d7cd1f 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/FLUME/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/FLUME/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>FLUME</name>
-      <version>1.5.2.2.5</version>
+      <version>1.5.2.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/HBASE/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/HBASE/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/HBASE/metainfo.xml
index 0feaa5e..9bc3ee2 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/HBASE/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/HBASE/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>HBASE</name>
-      <version>1.1.2.2.5</version>
+      <version>1.1.2.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/HDFS/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/HDFS/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/HDFS/metainfo.xml
index a3e4a64..1fc7f51 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/HDFS/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/HDFS/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>HDFS</name>
-      <version>2.7.1.2.5</version>
+      <version>2.7.3.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/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 3b43cc0..54c92d8 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
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>HIVE</name>
-      <version>1.2.1.2.5</version>
+      <version>1.2.1.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/KAFKA/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/KAFKA/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/KAFKA/metainfo.xml
index 12f6c45..047bbd2 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/KAFKA/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/KAFKA/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>KAFKA</name>
-      <version>0.10.0.2.5</version>
+      <version>0.10.0.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/KNOX/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/KNOX/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/KNOX/metainfo.xml
index 8f303a5..cd7b92c 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/KNOX/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/KNOX/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>KNOX</name>
-      <version>0.9.0.2.5</version>
+      <version>0.11.0.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/MAHOUT/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/MAHOUT/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/MAHOUT/metainfo.xml
index 9ed6957..3fe4d57 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/MAHOUT/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/MAHOUT/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>MAHOUT</name>
-      <version>0.9.0.2.5</version>
+      <version>0.9.0.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/OOZIE/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/OOZIE/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/OOZIE/metainfo.xml
index 9e845c3..6392ed4 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/OOZIE/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/OOZIE/metainfo.xml
@@ -20,6 +20,7 @@
   <services>
     <service>
       <name>OOZIE</name>
+      <version>4.2.0.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/PIG/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/PIG/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/PIG/metainfo.xml
index 0dbf74c..266aa5e 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/PIG/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/PIG/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>PIG</name>
-      <version>0.16.0.2.5</version>
+      <version>0.16.0.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/RANGER/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/RANGER/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/RANGER/metainfo.xml
index 6287e00..a115134 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/RANGER/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/RANGER/metainfo.xml
@@ -23,7 +23,7 @@
   <services>
     <service>
       <name>RANGER</name>
-      <version>0.6.0.2.5</version>
+      <version>0.7.0.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/RANGER_KMS/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/RANGER_KMS/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/RANGER_KMS/metainfo.xml
index ab065d9..1c0a2db 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/RANGER_KMS/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/RANGER_KMS/metainfo.xml
@@ -23,7 +23,7 @@
   <services>
     <service>
       <name>RANGER_KMS</name>
-      <version>0.6.0.2.5</version>
+      <version>0.7.0.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/SLIDER/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/SLIDER/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/SLIDER/metainfo.xml
index 6502bfe..0447906 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/SLIDER/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/SLIDER/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>SLIDER</name>
-      <version>0.80.0.2.5</version>
+      <version>0.91.0.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/SPARK/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/SPARK/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/SPARK/metainfo.xml
index d1129cd..21cbd0e 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/SPARK/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/SPARK/metainfo.xml
@@ -23,7 +23,7 @@
   <services>
     <service>
       <name>SPARK</name>
-      <version>1.6.x.2.5</version>
+      <version>1.6.x.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/SPARK2/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/SPARK2/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/SPARK2/metainfo.xml
index 2f83cf4..6440a3a 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/SPARK2/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/SPARK2/metainfo.xml
@@ -23,7 +23,7 @@
   <services>
     <service>
       <name>SPARK2</name>
-      <version>2.0.x.2.5</version>
+      <version>2.0.x.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/SQOOP/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/SQOOP/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/SQOOP/metainfo.xml
index eb67d63..2d1fe85 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/SQOOP/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/SQOOP/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>SQOOP</name>
-      <version>1.4.6.2.5</version>
+      <version>1.4.6.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/STORM/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/STORM/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/STORM/metainfo.xml
index c1e9490..e5eb1c0 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/STORM/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/STORM/metainfo.xml
@@ -21,7 +21,7 @@
   <services>
     <service>
       <name>STORM</name>
-      <version>1.0.1.2.5</version>
+      <version>1.0.1.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/TEZ/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/TEZ/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/TEZ/metainfo.xml
index 30f0c25..457342a 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/TEZ/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/TEZ/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>TEZ</name>
-      <version>0.7.0.2.5</version>
+      <version>0.7.0.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/YARN/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/YARN/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/YARN/metainfo.xml
index 48b30a9..35b883e 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/YARN/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/YARN/metainfo.xml
@@ -21,11 +21,11 @@
   <services>
     <service>
       <name>YARN</name>
-      <version>2.7.1.2.5</version>
+      <version>2.7.3.2.6</version>
     </service>
     <service>
       <name>MAPREDUCE2</name>
-      <version>2.7.1.2.5</version>
+      <version>2.7.3.2.6</version>
     </service>
   </services>
 </metainfo>

http://git-wip-us.apache.org/repos/asf/ambari/blob/2f6942f5/ambari-server/src/main/resources/stacks/HDP/2.6/services/ZOOKEEPER/metainfo.xml
----------------------------------------------------------------------
diff --git a/ambari-server/src/main/resources/stacks/HDP/2.6/services/ZOOKEEPER/metainfo.xml b/ambari-server/src/main/resources/stacks/HDP/2.6/services/ZOOKEEPER/metainfo.xml
index de8ebd9..e5f33f9 100644
--- a/ambari-server/src/main/resources/stacks/HDP/2.6/services/ZOOKEEPER/metainfo.xml
+++ b/ambari-server/src/main/resources/stacks/HDP/2.6/services/ZOOKEEPER/metainfo.xml
@@ -20,7 +20,7 @@
   <services>
     <service>
       <name>ZOOKEEPER</name>
-      <version>3.4.6.2.5</version>
+      <version>3.4.6.2.6</version>
     </service>
   </services>
 </metainfo>


[2/7] ambari git commit: AMBARI-19069. Remove 'llap_queue_capacity' references from UI code. (jaimin)

Posted by jo...@apache.org.
AMBARI-19069. Remove 'llap_queue_capacity' references from UI code. (jaimin)


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

Branch: refs/heads/branch-feature-AMBARI-18456
Commit: e465c0e7a667e8c411a1ff38480bddd49e01427c
Parents: 5901b95
Author: Jaimin Jetly <ja...@hortonworks.com>
Authored: Fri Dec 2 14:39:39 2016 -0800
Committer: Jaimin Jetly <ja...@hortonworks.com>
Committed: Fri Dec 2 14:39:39 2016 -0800

----------------------------------------------------------------------
 ambari-web/app/messages.js                                    | 1 -
 .../app/models/configs/objects/service_config_property.js     | 7 -------
 .../views/common/configs/widgets/slider_config_widget_view.js | 7 ++-----
 3 files changed, 2 insertions(+), 13 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/ambari/blob/e465c0e7/ambari-web/app/messages.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/messages.js b/ambari-web/app/messages.js
index 90ad70f..090244c 100644
--- a/ambari-web/app/messages.js
+++ b/ambari-web/app/messages.js
@@ -3200,7 +3200,6 @@ Em.I18n.translations = {
   'config.infoMessage.wrong.value.for.combobox.widget': '"{0}" is not available in the list of valid values',
   'config.warnMessage.outOfBoundaries.greater': 'Values greater than {0} are not recommended',
   'config.warnMessage.outOfBoundaries.less': 'Values smaller than {0} are not recommended',
-  'config.warnMessage.llap_queue_capacity.max': 'LLAP will consume entire Yarn queue',
 
   'errorMessage.config.required': 'This is required',
   'errorMessage.config.number.integer': 'Must contain digits only',

http://git-wip-us.apache.org/repos/asf/ambari/blob/e465c0e7/ambari-web/app/models/configs/objects/service_config_property.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/models/configs/objects/service_config_property.js b/ambari-web/app/models/configs/objects/service_config_property.js
index 5d85ae0..4459946 100644
--- a/ambari-web/app/models/configs/objects/service_config_property.js
+++ b/ambari-web/app/models/configs/objects/service_config_property.js
@@ -358,13 +358,6 @@ App.ServiceConfigProperty = Em.Object.extend({
     } else if ((typeof this.get('value') != 'object') && ((this.get('value') + '').length === 0)) {
       var widgetType = this.get('widgetType');
       this.set('errorMessage', (this.get('isRequired') && (!['test-db-connection','label'].contains(widgetType))) ? Em.I18n.t('errorMessage.config.required') : '');
-    } else if (this.get('name') === 'llap_queue_capacity') {
-      if (!isNaN(parseInt(this.get('value'), 10)) && parseInt(this.get('value'), 10) === 100) {
-        this.set('warnMessage', Em.I18n.t('config.warnMessage.llap_queue_capacity.max'));
-      } else {
-        this.set('warnMessage', '');
-        this.set('errorMessage', this.validateErrors(this.get('value'), this.get('name'), this.get('retypedPassword')));
-      }
     } else {
       this.set('errorMessage', this.validateErrors(this.get('value'), this.get('name'), this.get('retypedPassword')));
     }

http://git-wip-us.apache.org/repos/asf/ambari/blob/e465c0e7/ambari-web/app/views/common/configs/widgets/slider_config_widget_view.js
----------------------------------------------------------------------
diff --git a/ambari-web/app/views/common/configs/widgets/slider_config_widget_view.js b/ambari-web/app/views/common/configs/widgets/slider_config_widget_view.js
index 71156f4..c7e810b 100644
--- a/ambari-web/app/views/common/configs/widgets/slider_config_widget_view.js
+++ b/ambari-web/app/views/common/configs/widgets/slider_config_widget_view.js
@@ -645,11 +645,8 @@ App.SliderConfigWidgetView = App.ConfigWidgetView.extend({
           return false;
         }
       }
-      if (this.get('config.name') === 'llap_queue_capacity') {
-        this.get('config').validate();
-      } else {
-        this.updateWarningsForCompatibilityWithWidget('');
-      }
+
+      this.updateWarningsForCompatibilityWithWidget('');
       return true;
     }
     return false;