You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@predictionio.apache.org by ta...@apache.org on 2018/08/11 00:14:21 UTC

predictionio git commit: Fix several minor typos detected by github.com/client9/misspell

Repository: predictionio
Updated Branches:
  refs/heads/develop f19d0154d -> da4c9d66e


Fix several minor typos detected by github.com/client9/misspell

Closes #456


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

Branch: refs/heads/develop
Commit: da4c9d66e81a64084c36f15f50eaa8c07665e5ca
Parents: f19d015
Author: Kazuhiro Sera <se...@gmail.com>
Authored: Sat Aug 11 09:12:11 2018 +0900
Committer: Naoki Takezoe <ta...@apache.org>
Committed: Sat Aug 11 09:13:38 2018 +0900

----------------------------------------------------------------------
 .../org/apache/predictionio/controller/Engine.scala     |  4 ++--
 .../org/apache/predictionio/core/AbstractDoer.scala     |  2 +-
 .../predictionio/core/SelfCleaningDataSource.scala      |  4 ++--
 .../org/apache/predictionio/workflow/FakeWorkflow.scala |  2 +-
 .../webhooks/mailchimp/MailChimpConnectorSpec.scala     | 12 ++++++------
 data/test.sh                                            |  2 +-
 .../predictionio/data/storage/hbase/HBEventsUtil.scala  |  2 +-
 tests/pio_tests/README.md                               |  4 ++--
 tests/pio_tests/utils.py                                |  2 +-
 .../org/apache/predictionio/tools/commands/App.scala    |  2 +-
 10 files changed, 18 insertions(+), 18 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/predictionio/blob/da4c9d66/core/src/main/scala/org/apache/predictionio/controller/Engine.scala
----------------------------------------------------------------------
diff --git a/core/src/main/scala/org/apache/predictionio/controller/Engine.scala b/core/src/main/scala/org/apache/predictionio/controller/Engine.scala
index 1f9d0ab..3b5f363 100644
--- a/core/src/main/scala/org/apache/predictionio/controller/Engine.scala
+++ b/core/src/main/scala/org/apache/predictionio/controller/Engine.scala
@@ -268,7 +268,7 @@ class Engine[TD, EI, PD, Q, P, A](
 
   /** Extract model for persistent layer.
     *
-    * PredictionIO presist models for future use. It allows custom
+    * PredictionIO persists models for future use. It allows custom
     * implementation for persisting models. You need to implement the
     * [[org.apache.predictionio.controller.PersistentModel]] interface. This method
     * traverses all models in the workflow. If the model is a
@@ -642,7 +642,7 @@ object Engine {
       dataSource.readTrainingBase(sc)
     } catch {
       case e: StorageClientException =>
-        logger.error(s"Error occured reading from data source. (Reason: " +
+        logger.error(s"Error occurred reading from data source. (Reason: " +
           e.getMessage + ") Please see the log for debugging details.", e)
         sys.exit(1)
     }

http://git-wip-us.apache.org/repos/asf/predictionio/blob/da4c9d66/core/src/main/scala/org/apache/predictionio/core/AbstractDoer.scala
----------------------------------------------------------------------
diff --git a/core/src/main/scala/org/apache/predictionio/core/AbstractDoer.scala b/core/src/main/scala/org/apache/predictionio/core/AbstractDoer.scala
index 5da48ce..04d781f 100644
--- a/core/src/main/scala/org/apache/predictionio/core/AbstractDoer.scala
+++ b/core/src/main/scala/org/apache/predictionio/core/AbstractDoer.scala
@@ -48,7 +48,7 @@ object Doer extends Logging {
 
     // Subclasses only allows two kind of constructors.
     // 1. Constructor with P <: Params.
-    // 2. Emtpy constructor.
+    // 2. Empty constructor.
     // First try (1), if failed, try (2).
     try {
       val constr = cls.getConstructor(params.getClass)

http://git-wip-us.apache.org/repos/asf/predictionio/blob/da4c9d66/core/src/main/scala/org/apache/predictionio/core/SelfCleaningDataSource.scala
----------------------------------------------------------------------
diff --git a/core/src/main/scala/org/apache/predictionio/core/SelfCleaningDataSource.scala b/core/src/main/scala/org/apache/predictionio/core/SelfCleaningDataSource.scala
index cadf6b8..be3fe05 100644
--- a/core/src/main/scala/org/apache/predictionio/core/SelfCleaningDataSource.scala
+++ b/core/src/main/scala/org/apache/predictionio/core/SelfCleaningDataSource.scala
@@ -69,7 +69,7 @@ trait SelfCleaningDataSource {
 
   /** :: DeveloperApi ::
     *
-    * Returns RDD of events happend after duration in event window params.
+    * Returns RDD of events happened after duration in event window params.
     *
     * @return RDD[Event] most recent PEvents.
     */
@@ -87,7 +87,7 @@ trait SelfCleaningDataSource {
 
   /** :: DeveloperApi ::
     *
-    * Returns Iterator of events happend after duration in event window params.
+    * Returns Iterator of events happened after duration in event window params.
     *
     * @return Iterator[Event] most recent LEvents.
     */

http://git-wip-us.apache.org/repos/asf/predictionio/blob/da4c9d66/core/src/main/scala/org/apache/predictionio/workflow/FakeWorkflow.scala
----------------------------------------------------------------------
diff --git a/core/src/main/scala/org/apache/predictionio/workflow/FakeWorkflow.scala b/core/src/main/scala/org/apache/predictionio/workflow/FakeWorkflow.scala
index c9b1d23..8e4db51 100644
--- a/core/src/main/scala/org/apache/predictionio/workflow/FakeWorkflow.scala
+++ b/core/src/main/scala/org/apache/predictionio/workflow/FakeWorkflow.scala
@@ -72,7 +72,7 @@ private[predictionio] case class FakeEvalResult() extends BaseEvaluatorResult {
   override val noSave: Boolean = true
 }
 
-/** FakeRun allows user to implement custom function under the exact enviroment
+/** FakeRun allows user to implement custom function under the exact environment
   * as other PredictionIO workflow.
   *
   * Useful for developing new features. Only need to extend this trait and

http://git-wip-us.apache.org/repos/asf/predictionio/blob/da4c9d66/data/src/test/scala/org/apache/predictionio/data/webhooks/mailchimp/MailChimpConnectorSpec.scala
----------------------------------------------------------------------
diff --git a/data/src/test/scala/org/apache/predictionio/data/webhooks/mailchimp/MailChimpConnectorSpec.scala b/data/src/test/scala/org/apache/predictionio/data/webhooks/mailchimp/MailChimpConnectorSpec.scala
index add9c6f..9bb1847 100644
--- a/data/src/test/scala/org/apache/predictionio/data/webhooks/mailchimp/MailChimpConnectorSpec.scala
+++ b/data/src/test/scala/org/apache/predictionio/data/webhooks/mailchimp/MailChimpConnectorSpec.scala
@@ -24,7 +24,7 @@ import org.specs2.mutable._
 
 class MailChimpConnectorSpec extends Specification with ConnectorTestUtil {
 
-  // TOOD: test other events
+  // TODO: test other events
   // TODO: test different optional fields
 
   "MailChimpConnector" should {
@@ -87,7 +87,7 @@ class MailChimpConnectorSpec extends Specification with ConnectorTestUtil {
         "data[merges][EMAIL]" -> "api+unsub@mailchimp.com",
         "data[merges][FNAME]" -> "MailChimp",
         "data[merges][LNAME]" -> "API",
-        "data[merges][INTERESTS]" -> "Group1,Group2", //optional 
+        "data[merges][INTERESTS]" -> "Group1,Group2", //optional
         "data[ip_opt]" -> "10.20.10.30",
         "data[campaign_id]" -> "cb398d21d2"
       )
@@ -120,7 +120,7 @@ class MailChimpConnectorSpec extends Specification with ConnectorTestUtil {
       check(MailChimpConnector, unsubscribe, expected)
     }
 
-    //check profile update to event Json 
+    //check profile update to event Json
     "convert profile update to event JSON" in {
 
       val profileUpdate = Map(
@@ -162,7 +162,7 @@ class MailChimpConnectorSpec extends Specification with ConnectorTestUtil {
       check(MailChimpConnector, profileUpdate, expected)
     }
 
-    //check email update to event Json 
+    //check email update to event Json
     "convert email update to event JSON" in {
 
       val emailUpdate = Map(
@@ -192,7 +192,7 @@ class MailChimpConnectorSpec extends Specification with ConnectorTestUtil {
       check(MailChimpConnector, emailUpdate, expected)
     }
 
-    //check cleaned email to event Json 
+    //check cleaned email to event Json
     "convert cleaned email to event JSON" in {
 
       val cleanedEmail = Map(
@@ -221,7 +221,7 @@ class MailChimpConnectorSpec extends Specification with ConnectorTestUtil {
       check(MailChimpConnector, cleanedEmail, expected)
     }
 
-    //check campaign sending status to event Json 
+    //check campaign sending status to event Json
     "convert campaign sending status to event JSON" in {
 
       val campaign = Map(

http://git-wip-us.apache.org/repos/asf/predictionio/blob/da4c9d66/data/test.sh
----------------------------------------------------------------------
diff --git a/data/test.sh b/data/test.sh
index be0eb07..8481f47 100755
--- a/data/test.sh
+++ b/data/test.sh
@@ -481,7 +481,7 @@ testdata='[{
 checkPOST "/batch/events.json?accessKey=$accessKey" "$testdata" 200
 
 # request with a malformed event (2nd event)
-# the response code is succesful but the error for individual event is reflected in the response's body.
+# the response code is successful but the error for individual event is reflected in the response's body.
 testdata='[{
   "event" : "my_event_1",
   "entityType" : "user",

http://git-wip-us.apache.org/repos/asf/predictionio/blob/da4c9d66/storage/hbase/src/main/scala/org/apache/predictionio/data/storage/hbase/HBEventsUtil.scala
----------------------------------------------------------------------
diff --git a/storage/hbase/src/main/scala/org/apache/predictionio/data/storage/hbase/HBEventsUtil.scala b/storage/hbase/src/main/scala/org/apache/predictionio/data/storage/hbase/HBEventsUtil.scala
index 64487fb..4b0ad9a 100644
--- a/storage/hbase/src/main/scala/org/apache/predictionio/data/storage/hbase/HBEventsUtil.scala
+++ b/storage/hbase/src/main/scala/org/apache/predictionio/data/storage/hbase/HBEventsUtil.scala
@@ -148,7 +148,7 @@ object HBEventsUtil {
     val rowKey = event.eventId.map { id =>
       RowKey(id) // create rowKey from eventId
     }.getOrElse {
-      // TOOD: use real UUID. not pseudo random
+      // TODO: use real UUID. not pseudo random
       val uuidLow: Long = UUID.randomUUID().getLeastSignificantBits
       RowKey(
         entityType = event.entityType,

http://git-wip-us.apache.org/repos/asf/predictionio/blob/da4c9d66/tests/pio_tests/README.md
----------------------------------------------------------------------
diff --git a/tests/pio_tests/README.md b/tests/pio_tests/README.md
index 070ac8b..cb426da 100644
--- a/tests/pio_tests/README.md
+++ b/tests/pio_tests/README.md
@@ -33,14 +33,14 @@ has to download the following python-3 packages:
 You can pass it arguments to:
 * suppress the output of executed shell commands within the tests
 * enable logging
-* specify which tests should be exectued (by names)
+* specify which tests should be executed (by names)
 
 For more information run:
 ```shell
 python3 tests.py -h
 ```
 
-As soon as the tests are finishied an XML file with JUnit-like test reports 
+As soon as the tests are finished an XML file with JUnit-like test reports
 is created in the directory of execution.
 
 ### Adding new tests

http://git-wip-us.apache.org/repos/asf/predictionio/blob/da4c9d66/tests/pio_tests/utils.py
----------------------------------------------------------------------
diff --git a/tests/pio_tests/utils.py b/tests/pio_tests/utils.py
index 4659e54..6eecf89 100644
--- a/tests/pio_tests/utils.py
+++ b/tests/pio_tests/utils.py
@@ -55,7 +55,7 @@ def repository_dirname(template):
 
 def obtain_template(engine_dir, template):
   """Given a directory with engines and a template downloads an engine
-  if neccessary
+  if necessary
   Args:
     engine_dir (str): directory where engines are stored
     template (str): either the name of an engine from the engines directory

http://git-wip-us.apache.org/repos/asf/predictionio/blob/da4c9d66/tools/src/main/scala/org/apache/predictionio/tools/commands/App.scala
----------------------------------------------------------------------
diff --git a/tools/src/main/scala/org/apache/predictionio/tools/commands/App.scala b/tools/src/main/scala/org/apache/predictionio/tools/commands/App.scala
index 5884ebd..06c1641 100644
--- a/tools/src/main/scala/org/apache/predictionio/tools/commands/App.scala
+++ b/tools/src/main/scala/org/apache/predictionio/tools/commands/App.scala
@@ -298,7 +298,7 @@ object App extends EitherLogging {
               Right(channel.copy(id = chanId))
             } else {
               errStr = s"""Unable to create new channel.
-                          |Failed to initalize Event Store.""".stripMargin
+                          |Failed to initialize Event Store.""".stripMargin
               error(errStr)
               // reverted back the meta data
               try {