You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@geode.apache.org by km...@apache.org on 2016/12/23 21:06:05 UTC

[1/2] geode git commit: GEODE-2231 package path component rename for consistency

Repository: geode
Updated Branches:
  refs/heads/feature/GEODE-2231 786b79c00 -> b440f4de2


GEODE-2231 package path component rename for consistency


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

Branch: refs/heads/feature/GEODE-2231
Commit: fd82ea1650a9692d3a8101f84369e799036d704f
Parents: 786b79c
Author: Karen Miller <km...@pivotal.io>
Authored: Thu Dec 22 16:10:53 2016 -0800
Committer: Karen Miller <km...@pivotal.io>
Committed: Thu Dec 22 16:10:53 2016 -0800

----------------------------------------------------------------------
 .../examples/partitioned/PartitionedTest.java   |   2 +-
 .../examples/partitioned/ProducerTest.java      |   2 +-
 .../examples/replicated/ReplicatedTest.java     |   2 +-
 .../apache/geode/example/utils/ShellUtil.java   | 106 -------------------
 .../apache/geode/examples/utils/ShellUtil.java  | 106 +++++++++++++++++++
 5 files changed, 109 insertions(+), 109 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/geode/blob/fd82ea16/geode-examples/partitioned/src/test/java/org/apache/geode/examples/partitioned/PartitionedTest.java
----------------------------------------------------------------------
diff --git a/geode-examples/partitioned/src/test/java/org/apache/geode/examples/partitioned/PartitionedTest.java b/geode-examples/partitioned/src/test/java/org/apache/geode/examples/partitioned/PartitionedTest.java
index fd4fed4..aa746a4 100644
--- a/geode-examples/partitioned/src/test/java/org/apache/geode/examples/partitioned/PartitionedTest.java
+++ b/geode-examples/partitioned/src/test/java/org/apache/geode/examples/partitioned/PartitionedTest.java
@@ -31,7 +31,7 @@ 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.apache.geode.examples.utils.ShellUtil;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.Rule;

http://git-wip-us.apache.org/repos/asf/geode/blob/fd82ea16/geode-examples/partitioned/src/test/java/org/apache/geode/examples/partitioned/ProducerTest.java
----------------------------------------------------------------------
diff --git a/geode-examples/partitioned/src/test/java/org/apache/geode/examples/partitioned/ProducerTest.java b/geode-examples/partitioned/src/test/java/org/apache/geode/examples/partitioned/ProducerTest.java
index ff8f6cf..f654b2f 100644
--- a/geode-examples/partitioned/src/test/java/org/apache/geode/examples/partitioned/ProducerTest.java
+++ b/geode-examples/partitioned/src/test/java/org/apache/geode/examples/partitioned/ProducerTest.java
@@ -14,7 +14,7 @@
  * See the License for the specific language governing permissions and
  * limitations under the License.
  */
-package org.apache.geode.example.partitioned;
+package org.apache.geode.examples.partitioned;
 
 import static org.mockito.Matchers.any;
 import static org.mockito.Mockito.*;

http://git-wip-us.apache.org/repos/asf/geode/blob/fd82ea16/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 ab84485..5a3db17 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
@@ -31,7 +31,7 @@ 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.apache.geode.examples.utils.ShellUtil;
 import org.junit.After;
 import org.junit.Before;
 import org.junit.Rule;

http://git-wip-us.apache.org/repos/asf/geode/blob/fd82ea16/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
deleted file mode 100644
index c5290b8..0000000
--- a/geode-examples/utils/src/main/java/org/apache/geode/example/utils/ShellUtil.java
+++ /dev/null
@@ -1,106 +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.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/geode/blob/fd82ea16/geode-examples/utils/src/main/java/org/apache/geode/examples/utils/ShellUtil.java
----------------------------------------------------------------------
diff --git a/geode-examples/utils/src/main/java/org/apache/geode/examples/utils/ShellUtil.java b/geode-examples/utils/src/main/java/org/apache/geode/examples/utils/ShellUtil.java
new file mode 100644
index 0000000..58d59f9
--- /dev/null
+++ b/geode-examples/utils/src/main/java/org/apache/geode/examples/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.examples.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


[2/2] geode git commit: GEODE-2231 spelling fix and better specification of a path

Posted by km...@apache.org.
GEODE-2231 spelling fix and better specification of a path


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

Branch: refs/heads/feature/GEODE-2231
Commit: b440f4de2f51eda5369df4542003ab1237740f1e
Parents: fd82ea1
Author: Karen Miller <km...@pivotal.io>
Authored: Fri Dec 23 13:05:30 2016 -0800
Committer: Karen Miller <km...@pivotal.io>
Committed: Fri Dec 23 13:05:30 2016 -0800

----------------------------------------------------------------------
 geode-examples/README.md             | 2 +-
 geode-examples/partitioned/README.md | 2 +-
 geode-examples/replicated/README.md  | 2 +-
 3 files changed, 3 insertions(+), 3 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/geode/blob/b440f4de/geode-examples/README.md
----------------------------------------------------------------------
diff --git a/geode-examples/README.md b/geode-examples/README.md
index 04283cf..d7d9d53 100644
--- a/geode-examples/README.md
+++ b/geode-examples/README.md
@@ -17,7 +17,7 @@ All examples:
 ### Installation and a Tutorial for Beginners
 
 *  [How to Install](http://geode.apache.org/docs/guide/getting_started/installation/install_standalone.html)
-*  Set a `GEODE_HOME` environment variable to point to the root directory of the installation; this directory contains `bin/`. For those that have built from source, it will be the `geode-assembly/build/install/apache-geode` directory.
+*  Set a `GEODE_HOME` environment variable to point to the root directory of the installation; this directory contains `bin/`. For those that have built from source, it will be the `/path/to/geode/geode-assembly/build/install/apache-geode` directory.
 *  If desired run the tutorial: [Apache Geode in 15 minutes or Less](http://geode.apache.org/docs/guide/getting_started/15_minute_quickstart_gfsh.html)
 
 ### Basics

http://git-wip-us.apache.org/repos/asf/geode/blob/b440f4de/geode-examples/partitioned/README.md
----------------------------------------------------------------------
diff --git a/geode-examples/partitioned/README.md b/geode-examples/partitioned/README.md
index afbd0f3..30bdf90 100644
--- a/geode-examples/partitioned/README.md
+++ b/geode-examples/partitioned/README.md
@@ -92,7 +92,7 @@ the entries are still available:
 
         gfsh>quit
 
-6. Shutdown the system:
+6. Shut down the system:
 
         $ scripts/stopAll.sh
 

http://git-wip-us.apache.org/repos/asf/geode/blob/b440f4de/geode-examples/replicated/README.md
----------------------------------------------------------------------
diff --git a/geode-examples/replicated/README.md b/geode-examples/replicated/README.md
index ea923dd..2e58ea6 100644
--- a/geode-examples/replicated/README.md
+++ b/geode-examples/replicated/README.md
@@ -38,7 +38,7 @@ The producer puts 50 entries into the replicated region. The consumer prints the
         ...
         INFO: Done. 50 entries available on the server(s).
 
-6. Shutdown the system:
+6. Shut down the system:
 
         $ scripts/stopAll.sh