You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@gearpump.apache.org by ma...@apache.org on 2017/08/17 14:46:14 UTC

incubator-gearpump git commit: [GEARPUMP-343] Fix typo of EmbeddedRuntimeEnvironment

Repository: incubator-gearpump
Updated Branches:
  refs/heads/master 38fe7ec00 -> f75fb19c7


[GEARPUMP-343] Fix typo of EmbeddedRuntimeEnvironment

Author: huafengw <fv...@gmail.com>

Closes #215 from huafengw/minor.


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

Branch: refs/heads/master
Commit: f75fb19c78ff7e04bfdb9727bd8bf6e08bc4d1e8
Parents: 38fe7ec
Author: huafengw <fv...@gmail.com>
Authored: Thu Aug 17 22:45:39 2017 +0800
Committer: manuzhang <ow...@gmail.com>
Committed: Thu Aug 17 22:45:49 2017 +0800

----------------------------------------------------------------------
 .../cluster/client/RuntimeEnvironment.scala     |  4 +-
 .../embedded/EmbeddedRuntimeEnvironemnt.scala   | 48 --------------------
 .../embedded/EmbeddedRuntimeEnvironment.scala   | 48 ++++++++++++++++++++
 3 files changed, 50 insertions(+), 50 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-gearpump/blob/f75fb19c/core/src/main/scala/org/apache/gearpump/cluster/client/RuntimeEnvironment.scala
----------------------------------------------------------------------
diff --git a/core/src/main/scala/org/apache/gearpump/cluster/client/RuntimeEnvironment.scala b/core/src/main/scala/org/apache/gearpump/cluster/client/RuntimeEnvironment.scala
index cf5842f..c78e06c 100644
--- a/core/src/main/scala/org/apache/gearpump/cluster/client/RuntimeEnvironment.scala
+++ b/core/src/main/scala/org/apache/gearpump/cluster/client/RuntimeEnvironment.scala
@@ -20,7 +20,7 @@ package org.apache.gearpump.cluster.client
 
 import com.typesafe.config.Config
 import org.apache.gearpump.cluster.client.RuntimeEnvironment.RemoteClientContext
-import org.apache.gearpump.cluster.embedded.EmbeddedRuntimeEnvironemnt
+import org.apache.gearpump.cluster.embedded.EmbeddedRuntimeEnvironment
 
 /**
  * The RuntimeEnvironment is the context decides where an application is submitted to.
@@ -45,7 +45,7 @@ object RuntimeEnvironment {
   class RemoteClientContext(akkaConf: Config) extends ClientContext(akkaConf, null, null)
 
   def get() : RuntimeEnvironment = {
-    Option(envInstance).getOrElse(new EmbeddedRuntimeEnvironemnt)
+    Option(envInstance).getOrElse(new EmbeddedRuntimeEnvironment)
   }
 
   def newClientContext(akkaConf: Config): ClientContext = {

http://git-wip-us.apache.org/repos/asf/incubator-gearpump/blob/f75fb19c/core/src/main/scala/org/apache/gearpump/cluster/embedded/EmbeddedRuntimeEnvironemnt.scala
----------------------------------------------------------------------
diff --git a/core/src/main/scala/org/apache/gearpump/cluster/embedded/EmbeddedRuntimeEnvironemnt.scala b/core/src/main/scala/org/apache/gearpump/cluster/embedded/EmbeddedRuntimeEnvironemnt.scala
deleted file mode 100644
index fbea53f..0000000
--- a/core/src/main/scala/org/apache/gearpump/cluster/embedded/EmbeddedRuntimeEnvironemnt.scala
+++ /dev/null
@@ -1,48 +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.gearpump.cluster.embedded
-
-import com.typesafe.config.Config
-import org.apache.gearpump.cluster.client.{ClientContext, RuntimeEnvironment}
-import org.apache.gearpump.cluster.embedded.EmbeddedRuntimeEnvironemnt.EmbeddedClientContext
-
-/**
- * The EmbeddedRuntimeEnvironemnt is initiated when user trying to launch their application
- * from IDE. It will create an embedded cluster and user's applcaition will run in a single
- * local process.
- */
-class EmbeddedRuntimeEnvironemnt extends RuntimeEnvironment {
-  override def newClientContext(akkaConf: Config): ClientContext = {
-    new EmbeddedClientContext(akkaConf)
-  }
-}
-
-object EmbeddedRuntimeEnvironemnt {
-  class EmbeddedClientContext private(cluster: EmbeddedCluster)
-    extends ClientContext(cluster.config, cluster.system, cluster.master) {
-
-    def this(akkaConf: Config) {
-      this(new EmbeddedCluster(akkaConf))
-    }
-
-    override def close(): Unit = {
-      super.close()
-      cluster.stop()
-    }
-  }
-}

http://git-wip-us.apache.org/repos/asf/incubator-gearpump/blob/f75fb19c/core/src/main/scala/org/apache/gearpump/cluster/embedded/EmbeddedRuntimeEnvironment.scala
----------------------------------------------------------------------
diff --git a/core/src/main/scala/org/apache/gearpump/cluster/embedded/EmbeddedRuntimeEnvironment.scala b/core/src/main/scala/org/apache/gearpump/cluster/embedded/EmbeddedRuntimeEnvironment.scala
new file mode 100644
index 0000000..bf3b5a7
--- /dev/null
+++ b/core/src/main/scala/org/apache/gearpump/cluster/embedded/EmbeddedRuntimeEnvironment.scala
@@ -0,0 +1,48 @@
+/*
+ * 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.gearpump.cluster.embedded
+
+import com.typesafe.config.Config
+import org.apache.gearpump.cluster.client.{ClientContext, RuntimeEnvironment}
+import org.apache.gearpump.cluster.embedded.EmbeddedRuntimeEnvironment.EmbeddedClientContext
+
+/**
+ * The EmbeddedRuntimeEnvironment is initiated when user trying to launch their application
+ * from IDE. It will create an embedded cluster and user's application will run in a single
+ * local process.
+ */
+class EmbeddedRuntimeEnvironment extends RuntimeEnvironment {
+  override def newClientContext(akkaConf: Config): ClientContext = {
+    new EmbeddedClientContext(akkaConf)
+  }
+}
+
+object EmbeddedRuntimeEnvironment {
+  class EmbeddedClientContext private(cluster: EmbeddedCluster)
+    extends ClientContext(cluster.config, cluster.system, cluster.master) {
+
+    def this(akkaConf: Config) {
+      this(new EmbeddedCluster(akkaConf))
+    }
+
+    override def close(): Unit = {
+      super.close()
+      cluster.stop()
+    }
+  }
+}