You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@ambari.apache.org by dm...@apache.org on 2020/09/25 12:25:10 UTC

[ambari] branch branch-2.7 updated: AMBARI-25551. NodeManager doesn't work after adding a new host to a patch upgraded cluster. (dvitiuk) (#3231)

This is an automated email from the ASF dual-hosted git repository.

dmitriusan pushed a commit to branch branch-2.7
in repository https://gitbox.apache.org/repos/asf/ambari.git


The following commit(s) were added to refs/heads/branch-2.7 by this push:
     new dc2da3f  AMBARI-25551. NodeManager doesn't work after adding a new host to a patch upgraded cluster. (dvitiuk) (#3231)
dc2da3f is described below

commit dc2da3f569e45c3d74f7d7ac5f31ad886e1bf700
Author: dvitiiuk <dm...@gmail.com>
AuthorDate: Fri Sep 25 15:24:59 2020 +0300

    AMBARI-25551. NodeManager doesn't work after adding a new host to a patch upgraded cluster. (dvitiuk) (#3231)
    
    Co-authored-by: Dmytro Vitiuk <dm...@cloudera.com>
---
 .../ambari/server/upgrade/SchemaUpgradeHelper.java |   1 +
 .../ambari/server/upgrade/UpgradeCatalog276.java   | 145 +++++++++++++++++++++
 2 files changed, 146 insertions(+)

diff --git a/ambari-server/src/main/java/org/apache/ambari/server/upgrade/SchemaUpgradeHelper.java b/ambari-server/src/main/java/org/apache/ambari/server/upgrade/SchemaUpgradeHelper.java
index 29fbdc2..feed420 100644
--- a/ambari-server/src/main/java/org/apache/ambari/server/upgrade/SchemaUpgradeHelper.java
+++ b/ambari-server/src/main/java/org/apache/ambari/server/upgrade/SchemaUpgradeHelper.java
@@ -194,6 +194,7 @@ public class SchemaUpgradeHelper {
       catalogBinder.addBinding().to(UpgradeCatalog273.class);
       catalogBinder.addBinding().to(UpgradeCatalog274.class);
       catalogBinder.addBinding().to(UpgradeCatalog275.class);
+      catalogBinder.addBinding().to(UpgradeCatalog276.class);
       catalogBinder.addBinding().to(UpdateAlertScriptPaths.class);
       catalogBinder.addBinding().to(FinalUpgradeCatalog.class);
 
diff --git a/ambari-server/src/main/java/org/apache/ambari/server/upgrade/UpgradeCatalog276.java b/ambari-server/src/main/java/org/apache/ambari/server/upgrade/UpgradeCatalog276.java
new file mode 100644
index 0000000..578b69a
--- /dev/null
+++ b/ambari-server/src/main/java/org/apache/ambari/server/upgrade/UpgradeCatalog276.java
@@ -0,0 +1,145 @@
+/*
+ * 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.
+ */
+package org.apache.ambari.server.upgrade;
+
+import java.sql.SQLException;
+import java.util.Arrays;
+import java.util.HashMap;
+import java.util.HashSet;
+import java.util.Map;
+import java.util.Set;
+
+import org.apache.ambari.server.AmbariException;
+import org.apache.ambari.server.controller.AmbariManagementController;
+import org.apache.ambari.server.state.Cluster;
+import org.apache.ambari.server.state.Clusters;
+import org.apache.ambari.server.state.Config;
+import org.slf4j.Logger;
+import org.slf4j.LoggerFactory;
+
+import com.google.inject.Inject;
+import com.google.inject.Injector;
+
+
+/**
+ * The {@link UpgradeCatalog276} upgrades Ambari from 2.7.5 to 2.7.6.
+ */
+public class UpgradeCatalog276 extends AbstractUpgradeCatalog {
+
+  private static final Logger LOG = LoggerFactory.getLogger(UpgradeCatalog276.class);
+
+  @Inject
+  public UpgradeCatalog276(Injector injector) {
+    super(injector);
+  }
+
+  @Override
+  public String getSourceVersion() {
+    return "2.7.5";
+  }
+
+  @Override
+  public String getTargetVersion() {
+    return "2.7.6";
+  }
+
+  /**
+   * Perform database schema transformation. Can work only before persist service start
+   *
+   * @throws AmbariException
+   * @throws SQLException
+   */
+  @Override
+  protected void executeDDLUpdates() throws AmbariException, SQLException {
+    // no actions needed
+  }
+
+  /**
+   * Perform data insertion before running normal upgrade of data, requires started persist service
+   *
+   * @throws AmbariException
+   * @throws SQLException
+   */
+  @Override
+  protected void executePreDMLUpdates() throws AmbariException, SQLException {
+    // no actions needed
+  }
+
+  /**
+   * Performs normal data upgrade
+   *
+   * @throws AmbariException
+   * @throws SQLException
+   */
+  @Override
+  protected void executeDMLUpdates() throws AmbariException, SQLException {
+    LOG.debug("UpgradeCatalog276 executing DML Updates.");
+    fixNativeLibrariesPathsForMR2AndTez();
+  }
+
+  protected void fixNativeLibrariesPathsForMR2AndTez() throws AmbariException {
+    AmbariManagementController ambariManagementController = injector.getInstance(AmbariManagementController.class);
+    Clusters clusters = ambariManagementController.getClusters();
+    if (clusters != null) {
+      String oldNativePath = "/usr/hdp/${hdp.version}/hadoop/lib/native:" +
+          "/usr/hdp/${hdp.version}/hadoop/lib/native/Linux-{{architecture}}-64";
+      String fixedNativePath = "/usr/hdp/current/hadoop-client/lib/native:" +
+          "/usr/hdp/current/hadoop-client/lib/native/Linux-{{architecture}}-64";
+
+      Map<String, Cluster> clusterMap = clusters.getClusters();
+      if (clusterMap != null && !clusterMap.isEmpty()) {
+        for (final Cluster cluster : clusterMap.values()) {
+          Set<String> installedServices = cluster.getServices().keySet();
+          if (installedServices.contains("TEZ")) {
+            updateConfigGroupNativePaths("tez-site",
+                new HashSet<>(Arrays.asList("tez.am.launch.env", "tez.task.launch.env")),
+                oldNativePath, fixedNativePath, cluster);
+          }
+          if (installedServices.contains("MAPREDUCE2")) {
+            updateConfigGroupNativePaths("mapred-site",
+                new HashSet<>(Arrays.asList("mapreduce.admin.user.env")),
+                oldNativePath, fixedNativePath, cluster);
+          }
+        }
+      }
+    }
+  }
+
+  private void updateConfigGroupNativePaths(String configGroupName, Set<String> configsToChange,
+                                            String replaceFrom, String replaceTo, Cluster cluster) throws AmbariException {
+    Config targetConfig = cluster.getDesiredConfigByType(configGroupName);
+
+    if (targetConfig != null) {
+      Map<String, String> newProperty = new HashMap<>();
+
+      for (String configName : configsToChange) {
+        String configValue = targetConfig.getProperties().get(configName);
+        if (configValue != null && configValue.contains(replaceFrom)) {
+          String newConfigValue = configValue.replace(replaceFrom, replaceTo);
+          LOG.info("Native path will be updated for '{}' property of '{}' config type, from '{}' to '{}'",
+              configName, configGroupName, configValue, newConfigValue);
+          newProperty.put(configName, newConfigValue);
+        }
+      }
+
+      if (!newProperty.isEmpty()) {
+        updateConfigurationPropertiesForCluster(cluster, configGroupName, newProperty, true, false);
+      }
+    }
+  }
+}