You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by ma...@apache.org on 2016/07/08 19:47:33 UTC

[02/11] incubator-geode git commit: GEODE-33 - Applying PR feedback items * Minor fixes (adding mavenLocal to list of repositories, fixed dependency versions and use of gradle.properties). * Locator port now is parameterized and uses env variable. If not

GEODE-33 - Applying PR feedback items
* Minor fixes (adding mavenLocal to list of repositories, fixed dependency versions and use of gradle.properties).
* Locator port now is parameterized and uses env variable. If not set will use default port 10334.
* Applied PR feedback on testing classes and shellUtil now is based on Apache commons-exec.
* Merged #173
* Moved ShellUtil to utils submodule.


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

Branch: refs/heads/develop
Commit: a4010b2043ee708b8c85c987d21169da69af6df6
Parents: 3eaa1cd
Author: William Markito <wm...@pivotal.io>
Authored: Thu Jul 7 14:07:24 2016 -0700
Committer: William Markito <wm...@pivotal.io>
Committed: Fri Jul 8 12:42:39 2016 -0700

----------------------------------------------------------------------
 geode-examples/build.gradle                     |   8 +-
 geode-examples/gradle.properties                |   4 +-
 geode-examples/replicated/.gitignore            |   2 +
 geode-examples/replicated/scripts/pidkiller.sh  |  36 +++++
 geode-examples/replicated/scripts/setEnv.sh     |   6 +
 geode-examples/replicated/scripts/startAll.sh   |  13 +-
 geode-examples/replicated/scripts/stopAll.sh    |   6 +-
 .../examples/replicated/ReplicatedTest.java     | 151 ++++++++++++++-----
 .../geode/examples/replicated/ShellUtil.java    |  42 ------
 geode-examples/settings.gradle                  |   4 +-
 .../apache/geode/example/utils/ShellUtil.java   | 106 +++++++++++++
 gradle/rat.gradle                               |   3 +-
 12 files changed, 289 insertions(+), 92 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/geode-examples/build.gradle
----------------------------------------------------------------------
diff --git a/geode-examples/build.gradle b/geode-examples/build.gradle
index fe0d93b..1eadc31 100644
--- a/geode-examples/build.gradle
+++ b/geode-examples/build.gradle
@@ -15,12 +15,12 @@
  * limitations under the License.
  */
 
-
 subprojects {
 
     apply plugin:'java'
 
     repositories {
+        mavenLocal()
         maven {
             url "https://repository.apache.org/content/repositories/snapshots/"
         }
@@ -28,11 +28,12 @@ subprojects {
     }
 
     dependencies {
+        testCompile project(":utils")
         compile "org.apache.geode:geode-core:$geodeVersion"
-//        testCompile "org.apache.geode:geode-junit:$geodeVersion"
         testCompile "junit:junit:$junitVersion"
         testCompile "org.mockito:mockito-core:$mockitocoreVersion"
-        compile "com.jayway.awaitility:awaitility:1.7.0"
+        compile "org.apache.commons:commons-exec:$commonsExecVersion"
+        compile "com.jayway.awaitility:awaitility:$awaitilityVersion"
     }
 
     task run(type: JavaExec) {
@@ -47,5 +48,6 @@ subprojects {
         }
     }
 
+
 }
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/geode-examples/gradle.properties
----------------------------------------------------------------------
diff --git a/geode-examples/gradle.properties b/geode-examples/gradle.properties
index 31e0ed5..9c7822a 100644
--- a/geode-examples/gradle.properties
+++ b/geode-examples/gradle.properties
@@ -16,4 +16,6 @@
 #
 geodeVersion = 1.0.0-incubating.M3-SNAPSHOT
 junitVersion = 4.12
-mockitocoreVersion = 1.10.19
\ No newline at end of file
+mockitocoreVersion = 1.10.19
+commonsExecVersion = 1.3
+awaitilityVersion = 1.7.0
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/geode-examples/replicated/.gitignore
----------------------------------------------------------------------
diff --git a/geode-examples/replicated/.gitignore b/geode-examples/replicated/.gitignore
new file mode 100644
index 0000000..b858ea8
--- /dev/null
+++ b/geode-examples/replicated/.gitignore
@@ -0,0 +1,2 @@
+server*/*
+locator*/*

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/geode-examples/replicated/scripts/pidkiller.sh
----------------------------------------------------------------------
diff --git a/geode-examples/replicated/scripts/pidkiller.sh b/geode-examples/replicated/scripts/pidkiller.sh
new file mode 100755
index 0000000..1a3eaf2
--- /dev/null
+++ b/geode-examples/replicated/scripts/pidkiller.sh
@@ -0,0 +1,36 @@
+#
+# 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.
+#
+#!/bin/bash
+#
+# @brief Script that look for .pid files on a directory and kill those processes. 
+#
+
+export DIR=$1
+
+if [ $# -eq 0 ]
+  then
+    echo "No arguments supplied. Script needs directory to look for pid files."
+    exit 1
+fi
+
+for pid in `find $DIR -name "*.pid"`
+do
+ echo "Found: $pid"
+ kill -9 `cat $pid`
+ echo "Killed."
+done
+

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/geode-examples/replicated/scripts/setEnv.sh
----------------------------------------------------------------------
diff --git a/geode-examples/replicated/scripts/setEnv.sh b/geode-examples/replicated/scripts/setEnv.sh
index 3cc1549..60befc6 100755
--- a/geode-examples/replicated/scripts/setEnv.sh
+++ b/geode-examples/replicated/scripts/setEnv.sh
@@ -16,6 +16,9 @@
 #
 #!/bin/bash
 
+## check if locator port has been set otherwise set to default
+export GEODE_LOCATOR_PORT="${GEODE_LOCATOR_PORT:-10334}"
+
 ## check if GEODE_HOME has been set
 : ${GEODE_HOME?"GEODE_HOME enviroment variable needs to be set"}
 
@@ -25,3 +28,6 @@ echo "Geode version: `$GEODE_HOME/bin/gfsh version`"
 
 ## prefer GEODE_HOME for finding gfsh
 export PATH=$GEODE_HOME/bin:$PATH
+
+
+: ${GEODE_LOCATOR_PORT?}

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/geode-examples/replicated/scripts/startAll.sh
----------------------------------------------------------------------
diff --git a/geode-examples/replicated/scripts/startAll.sh b/geode-examples/replicated/scripts/startAll.sh
index f543412..f4ce413 100755
--- a/geode-examples/replicated/scripts/startAll.sh
+++ b/geode-examples/replicated/scripts/startAll.sh
@@ -18,23 +18,28 @@
 
 set -e
 
+current=`pwd`
+
 cd `dirname $0`
 
 . ./setEnv.sh
 
+cd $current
+
+#export GEODE_LOCATOR_PORT="${GEODE_LOCATOR_PORT:-10334}"
 # start a locator
-gfsh start locator --name=locator1 --mcast-port=0
+gfsh start locator --name=locator1 --mcast-port=0 --port=${GEODE_LOCATOR_PORT}
 
 # start 2 servers on a random available port
 for N in {1..2}
 do
- gfsh start server --locators=localhost[10334] --name=server$N  --server-port=0 --mcast-port=0
+ gfsh start server --locators=localhost[${GEODE_LOCATOR_PORT}] --name=server$N  --server-port=0 --mcast-port=0
 done
 
 # create a region using GFSH
-gfsh -e "connect" -e "create region --name=myRegion --type=REPLICATE"
+gfsh -e "connect --locator=localhost[${GEODE_LOCATOR_PORT}]" -e "create region --name=myRegion --type=REPLICATE"
 
-gfsh -e "connect" -e "list members"
+gfsh -e "connect --locator=localhost[${GEODE_LOCATOR_PORT}]" -e "list members"
 
 exit 0
 

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/geode-examples/replicated/scripts/stopAll.sh
----------------------------------------------------------------------
diff --git a/geode-examples/replicated/scripts/stopAll.sh b/geode-examples/replicated/scripts/stopAll.sh
index d2fb2be..2a2c39b 100755
--- a/geode-examples/replicated/scripts/stopAll.sh
+++ b/geode-examples/replicated/scripts/stopAll.sh
@@ -17,8 +17,12 @@
 #!/bin/bash
 set -e
 
+current=`pwd`
+
 cd `dirname $0`
 
 . ./setEnv.sh
 
-gfsh -e "connect" -e "shutdown --include-locators=true"
+cd $current
+
+gfsh -e "connect --locator=localhost[${GEODE_LOCATOR_PORT}]" -e "shutdown --include-locators=true"

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/geode-examples/replicated/src/test/java/org/apache/geode/examples/replicated/ReplicatedTest.java
----------------------------------------------------------------------
diff --git a/geode-examples/replicated/src/test/java/org/apache/geode/examples/replicated/ReplicatedTest.java b/geode-examples/replicated/src/test/java/org/apache/geode/examples/replicated/ReplicatedTest.java
index 6d777d0..dc4e65f 100644
--- a/geode-examples/replicated/src/test/java/org/apache/geode/examples/replicated/ReplicatedTest.java
+++ b/geode-examples/replicated/src/test/java/org/apache/geode/examples/replicated/ReplicatedTest.java
@@ -16,76 +16,149 @@
  */
 package org.apache.geode.examples.replicated;
 
+import static org.hamcrest.core.Is.*;
 import static org.junit.Assert.*;
+import static org.junit.Assume.*;
 
-import java.io.File;
 import java.io.IOException;
+import java.net.ServerSocket;
+import java.util.Map;
 import java.util.concurrent.TimeUnit;
-
+import java.util.logging.Level;
+import java.util.logging.Logger;
+
+import org.apache.commons.exec.CommandLine;
+import org.apache.commons.exec.DefaultExecuteResultHandler;
+import org.apache.commons.exec.ExecuteException;
+import org.apache.commons.exec.environment.EnvironmentUtils;
+import org.apache.geode.example.utils.ShellUtil;
 import org.junit.After;
+import org.junit.Before;
+import org.junit.Rule;
 import org.junit.Test;
+import org.junit.rules.TemporaryFolder;
 
+/**
+ * Tests for the shell scripts of the replicated example
+ */
 public class ReplicatedTest {
 
   //TODO: parameterize
-  private String startScriptFileName = "startAll.sh";
-  private String stopScriptFileName = "stopAll.sh";
+  public static final String GEODE_LOCATOR_PORT = "GEODE_LOCATOR_PORT=";
+  private static final String startScriptFileName = "startAll.sh";
+  private static final String stopScriptFileName = "stopAll.sh";
+  private static final String pidkillerScriptFileName = "pidkiller.sh";
   private boolean processRunning = false;
   private ShellUtil shell = new ShellUtil();
-  private Process process;
+  private final long scriptTimeout = TimeUnit.SECONDS.toMillis(60);
+  private static final Logger logger = Logger.getAnonymousLogger();
 
-  private int waitTimeForScript=60;
+  @Rule
+  public TemporaryFolder testFolder = new TemporaryFolder();
 
-  @Test
-  public void checkIfScriptsExists() throws IOException {
-    ClassLoader classLoader = getClass().getClassLoader();
+  private int locatorPort;
+  private Map environment;
 
-    File file = new File(classLoader.getResource(startScriptFileName).getFile());
-    assertTrue(file.exists());
+  @Before
+  public void setup() throws IOException {
+    // ignores test if running on windows
+    assumeThat(System.getProperty("os.name").startsWith("Windows"), is(false));
 
-    file = new File(classLoader.getResource(stopScriptFileName).getFile());
-    assertTrue(file.exists());
+    locatorPort = getAvailablePort();
+    environment = EnvironmentUtils.getProcEnvironment();
+    EnvironmentUtils.addVariableToEnvironment(environment, GEODE_LOCATOR_PORT + locatorPort);
+    logger.fine("Locator port: " + locatorPort);
   }
 
-
-  private Process start() {
-    Process p = shell.executeFile(startScriptFileName).get();
-    processRunning = true;
-    return p;
+  @Test
+  public void checkIfScriptsExistsAndAreExecutable() throws IOException {
+    assertTrue(shell.getFileFromClassLoader(startScriptFileName).map(x -> x.isFile()).orElse(false));
+    assertTrue(shell.getFileFromClassLoader(startScriptFileName).map(x -> x.isFile()).orElse(false));
   }
 
-  private Process stop() {
-    Process p = shell.executeFile(stopScriptFileName).get();
-    processRunning = false;
-    return p;
+  @Test
+  public void executeStartThenStopScript() throws InterruptedException, IOException {
+    final int exitCodeStart = executeScript(startScriptFileName);
+    assertEquals(0, exitCodeStart);
+
+    final int exitCodeStop = executeScript(stopScriptFileName);
+    assertEquals(0, exitCodeStop);
   }
 
   @Test
-  public void testStartAndStop() throws InterruptedException {
-    boolean status = false;
-    int exitCode = -1;
-
-    process = start();
-    status =  process.waitFor(waitTimeForScript, TimeUnit.SECONDS);
-    exitCode = process.exitValue();
-    verify(status, exitCode);
-
-    process = stop();
-    status = process.waitFor(waitTimeForScript, TimeUnit.SECONDS);
-    exitCode = process.exitValue();
-    verify(status, exitCode);
+  public void failToStopWhenNoServersAreRunning() throws InterruptedException, IOException {
+    final int exitCode;
+
+    exitCode = executeScript(stopScriptFileName);
+    assertEquals(1, exitCode);
   }
 
-  private void verify(boolean status, int exitCode) {
-    assertEquals(exitCode, 0);
-    assertEquals(status, true);
+  /**
+   * Execute the kill script that looks for pid files
+   * @throws IOException
+   * @throws InterruptedException
+   */
+  private void runKillScript() throws IOException, InterruptedException {
+    CommandLine cmdLine = CommandLine.parse(shell.getFileFromClassLoader(pidkillerScriptFileName)
+                                                 .map(x -> x.getAbsolutePath())
+                                                 .orElseThrow(IllegalArgumentException::new));
+    cmdLine.addArgument(testFolder.getRoot().getAbsolutePath());
+
+    DefaultExecuteResultHandler resultHandler = shell.execute(cmdLine, scriptTimeout, environment, testFolder
+      .getRoot());
+    resultHandler.waitFor(scriptTimeout);
+  }
+
+  /**
+   * Given a script file name, runs the script and return the exit code.
+   * If exitCode != 0 extract and prints exception.
+   * @param scriptName
+   * @return <code>int</code> with exitCode
+   * @throws IOException
+   * @throws InterruptedException
+   */
+  private int executeScript(String scriptName) throws IOException, InterruptedException {
+    final int exitCode;
+    DefaultExecuteResultHandler resultHandler = shell.execute(scriptName, scriptTimeout, environment, testFolder
+      .getRoot());
+    processRunning = true;
+    resultHandler.waitFor();
+
+    logger.finest(String.format("Executing %s...", scriptName));
+    exitCode = resultHandler.getExitValue();
+
+    // extract and log exception if any happened
+    if (exitCode != 0) {
+      ExecuteException executeException = resultHandler.getException();
+      logger.log(Level.SEVERE, executeException.getMessage(), executeException);
+    }
+    return exitCode;
   }
 
   @After
   public void tearDown() {
     if (processRunning) {
-      stop();
+      try {
+        runKillScript();
+      } catch (IOException | InterruptedException e) {
+        e.printStackTrace();
+      }
+    }
+  }
+
+  /**
+   * Get a random available port
+   * @return <code>int</code>  port number
+   */
+  private static int getAvailablePort() {
+    try (ServerSocket socket = new ServerSocket(0)) {
+      int port = socket.getLocalPort();
+      socket.close();
+      return port;
+    } catch (IOException ioex) {
+      logger.log(Level.SEVERE, ioex.getMessage(), ioex);
     }
+    throw new IllegalStateException("No TCP/IP ports available.");
   }
 
 }

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/geode-examples/replicated/src/test/java/org/apache/geode/examples/replicated/ShellUtil.java
----------------------------------------------------------------------
diff --git a/geode-examples/replicated/src/test/java/org/apache/geode/examples/replicated/ShellUtil.java b/geode-examples/replicated/src/test/java/org/apache/geode/examples/replicated/ShellUtil.java
deleted file mode 100644
index b93f828..0000000
--- a/geode-examples/replicated/src/test/java/org/apache/geode/examples/replicated/ShellUtil.java
+++ /dev/null
@@ -1,42 +0,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.
- */
-
-package org.apache.geode.examples.replicated;
-
-import java.io.File;
-import java.io.IOException;
-import java.util.Optional;
-
-public class ShellUtil {
-
-  /**
-   * File name should available on the classpath
-   * @param fileName
-   * @return <Optional>Process</Optional>
-   */
-  public Optional<Process> executeFile(String fileName) {
-    try {
-      ClassLoader classLoader = getClass().getClassLoader();
-      File file = new File(classLoader.getResource(fileName).getFile());
-
-      return Optional.of(Runtime.getRuntime().exec(file.getAbsolutePath()));
-    } catch (IOException e) {
-      e.printStackTrace();
-    }
-    return Optional.empty();
-  }
-}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/geode-examples/settings.gradle
----------------------------------------------------------------------
diff --git a/geode-examples/settings.gradle b/geode-examples/settings.gradle
index cb71558..432a8eb 100644
--- a/geode-examples/settings.gradle
+++ b/geode-examples/settings.gradle
@@ -16,4 +16,6 @@
  */
 rootProject.name = 'geode-examples'
 
-include 'replicated'
\ No newline at end of file
+include 'replicated'
+include 'utils'
+

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/geode-examples/utils/src/main/java/org/apache/geode/example/utils/ShellUtil.java
----------------------------------------------------------------------
diff --git a/geode-examples/utils/src/main/java/org/apache/geode/example/utils/ShellUtil.java b/geode-examples/utils/src/main/java/org/apache/geode/example/utils/ShellUtil.java
new file mode 100644
index 0000000..c5290b8
--- /dev/null
+++ b/geode-examples/utils/src/main/java/org/apache/geode/example/utils/ShellUtil.java
@@ -0,0 +1,106 @@
+/*
+ * 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.geode.example.utils;
+
+import java.io.File;
+import java.io.IOException;
+import java.net.URL;
+import java.util.Map;
+import java.util.Optional;
+
+import org.apache.commons.exec.CommandLine;
+import org.apache.commons.exec.DefaultExecuteResultHandler;
+import org.apache.commons.exec.DefaultExecutor;
+import org.apache.commons.exec.ExecuteWatchdog;
+import org.apache.commons.exec.PumpStreamHandler;
+import org.apache.commons.exec.ShutdownHookProcessDestroyer;
+
+/**
+ * Utility class for executing shell commands using Apache commons-exec
+ */
+public class ShellUtil {
+
+  private final ClassLoader classLoader = getClass().getClassLoader();
+
+  public Optional<File> getFileFromClassLoader(String fileName) {
+    URL resourceURL = classLoader.getResource(fileName);
+    return (resourceURL == null) ? Optional.empty() : Optional.of(new File(resourceURL.getFile()));
+  }
+
+  public CommandLine parseCommandLine(String fileName) {
+    return getFileFromClassLoader(fileName).map(file -> CommandLine.parse(file.getAbsolutePath()))
+                                           .orElseThrow(IllegalArgumentException::new);
+  }
+
+  public DefaultExecuteResultHandler execute(CommandLine cmdLine, long timeout, Map environment, File dir) throws IOException {
+    ExecutorTemplate exampleTestExecutor = new ExecutorTemplate(timeout, dir).invoke();
+    DefaultExecutor executor = exampleTestExecutor.getExecutor();
+    DefaultExecuteResultHandler resultHandler = exampleTestExecutor.getResultHandler();
+    executor.execute(cmdLine, environment, resultHandler);
+
+    return resultHandler;
+
+  }
+
+  public DefaultExecuteResultHandler execute(String fileName, long timeout, Map environment, File dir) throws IOException {
+    ExecutorTemplate exampleTestExecutor = new ExecutorTemplate(timeout, dir).invoke();
+    DefaultExecutor executor = exampleTestExecutor.getExecutor();
+    DefaultExecuteResultHandler resultHandler = exampleTestExecutor.getResultHandler();
+    executor.execute(parseCommandLine(fileName), environment, resultHandler);
+
+    return resultHandler;
+  }
+
+  /**
+   * Executor template for common scenarios
+   */
+  private static class ExecutorTemplate {
+
+    private final long timeout;
+    private final File dir;
+    private DefaultExecutor executor;
+    private DefaultExecuteResultHandler resultHandler;
+
+    public ExecutorTemplate(final long timeout, final File dir) {
+      this.timeout = timeout;
+      this.dir = dir;
+    }
+
+    public DefaultExecutor getExecutor() {
+      return executor;
+    }
+
+    public DefaultExecuteResultHandler getResultHandler() {
+      return resultHandler;
+    }
+
+    public ExecutorTemplate invoke() {
+      executor = new DefaultExecutor();
+      ExecuteWatchdog watchdog = new ExecuteWatchdog(timeout);
+      executor.setWatchdog(watchdog);
+
+      PumpStreamHandler psh = new PumpStreamHandler(System.out, System.err);
+      executor.setProcessDestroyer(new ShutdownHookProcessDestroyer());
+      executor.setStreamHandler(psh);
+      executor.setWorkingDirectory(dir);
+
+      resultHandler = new DefaultExecuteResultHandler();
+      return this;
+    }
+  }
+}
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/incubator-geode/blob/a4010b20/gradle/rat.gradle
----------------------------------------------------------------------
diff --git a/gradle/rat.gradle b/gradle/rat.gradle
index dfbb52d..02bf85c 100644
--- a/gradle/rat.gradle
+++ b/gradle/rat.gradle
@@ -44,7 +44,8 @@ rat {
     'geode-spark-connector/sbt',
 
     // Geode examples
-    'geode-examples/*/scripts/**',
+    'geode-examples/*/scripts/server*/',
+    'geode-examples/*/scripts/locator*/',
     'geode-examples/.idea/**',
     'geode-examples/gradlew*/**',
     'geode-examples/gradle/wrapper/**',