You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@toree.apache.org by cs...@apache.org on 2016/03/24 19:32:19 UTC

incubator-toree git commit: Fix typos in docs/comments/testnames.

Repository: incubator-toree
Updated Branches:
  refs/heads/master be91c0353 -> 429c74c67


Fix typos in docs/comments/testnames.


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

Branch: refs/heads/master
Commit: 429c74c67f4307d0f8236a2efcf6938621bf5b50
Parents: be91c03
Author: Dongjoon Hyun <do...@apache.org>
Authored: Wed Mar 23 15:41:03 2016 -0700
Committer: Dongjoon Hyun <do...@apache.org>
Committed: Thu Mar 24 11:19:17 2016 -0700

----------------------------------------------------------------------
 .../org/apache/toree/kernel/protocol/v5/client/Utilities.scala | 2 +-
 etc/examples/notebooks/meetup-streaming-toree.ipynb            | 6 +++---
 etc/pip_install/toree/_version.py                              | 2 +-
 kernel/src/test/scala/system/TruncationTests.scala             | 2 +-
 .../apache/toree/plugins/dependencies/DependencyManager.scala  | 2 +-
 .../src/main/scala/org/apache/toree/comm/CommManager.scala     | 2 +-
 .../apache/toree/kernel/protocol/v5/content/ClearOutput.scala  | 2 +-
 sparkr-interpreter/src/main/resources/R/pkg/R/DataFrame.R      | 2 +-
 sparkr-interpreter/src/main/resources/R/pkg/R/RDD.R            | 2 +-
 sparkr-interpreter/src/main/resources/R/pkg/R/SQLContext.R     | 4 ++--
 sparkr-interpreter/src/main/resources/R/pkg/R/context.R        | 4 ++--
 sparkr-interpreter/src/main/resources/R/pkg/R/deserialize.R    | 2 +-
 sparkr-interpreter/src/main/resources/R/pkg/R/pairRDD.R        | 2 +-
 .../src/main/resources/R/pkg/inst/tests/test_utils.R           | 2 +-
 14 files changed, 18 insertions(+), 18 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/client/src/main/scala/org/apache/toree/kernel/protocol/v5/client/Utilities.scala
----------------------------------------------------------------------
diff --git a/client/src/main/scala/org/apache/toree/kernel/protocol/v5/client/Utilities.scala b/client/src/main/scala/org/apache/toree/kernel/protocol/v5/client/Utilities.scala
index b8e5fa8..274057b 100644
--- a/client/src/main/scala/org/apache/toree/kernel/protocol/v5/client/Utilities.scala
+++ b/client/src/main/scala/org/apache/toree/kernel/protocol/v5/client/Utilities.scala
@@ -57,7 +57,7 @@ object Utilities extends LogLike {
   implicit def ZMQMessageToKernelMessage(message: ZMQMessage): KernelMessage = {
     val delimiterIndex: Int =
       message.frames.indexOf(ByteString("<IDS|MSG>".getBytes))
-    //  TODO Handle the case where there is no delimeter
+    //  TODO Handle the case where there is no delimiter
     val ids: Seq[String] =
       message.frames.take(delimiterIndex).map(
         (byteString : ByteString) =>  { new String(byteString.toArray) }

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/etc/examples/notebooks/meetup-streaming-toree.ipynb
----------------------------------------------------------------------
diff --git a/etc/examples/notebooks/meetup-streaming-toree.ipynb b/etc/examples/notebooks/meetup-streaming-toree.ipynb
index 51898bb..0537f4a 100644
--- a/etc/examples/notebooks/meetup-streaming-toree.ipynb
+++ b/etc/examples/notebooks/meetup-streaming-toree.ipynb
@@ -18,7 +18,7 @@
    "cell_type": "markdown",
    "metadata": {},
    "source": [
-    "This example is a Scala adapatation of [this](https://github.com/jupyter-incubator/dashboards/blob/master/etc/notebooks/stream_demo/meetup-streaming.ipynb) notebook from [jupyter_dashboards](https://github.com/jupyter-incubator/dashboards).\n",
+    "This example is a Scala adaptation of [this](https://github.com/jupyter-incubator/dashboards/blob/master/etc/notebooks/stream_demo/meetup-streaming.ipynb) notebook from [jupyter_dashboards](https://github.com/jupyter-incubator/dashboards).\n",
     "\n",
     "On your first visit to this notebook, we recommend that you execute one cell at a time as you read along. Later, if you  just want to see the demo, select *Cell > Run All* from the menu bar. Once you've run all of the cells, select *View > View Dashboard* and then click on the **Stream** toggle to start the data stream.\n",
     "\n",
@@ -47,7 +47,7 @@
    "source": [
     "## Initialize DeclarativeWidgets<span style=\"float: right; font-size: 0.5em\"><a href=\"#Initialize-DeclarativeWidgets\">Top</a></span>\n",
     "\n",
-    "In Toree, declarativewidgets need to be initialized by adding the JAR with the scala implamentation and calling `initWidgets`. This is must take place very close to the top of the notebook."
+    "In Toree, declarativewidgets need to be initialized by adding the JAR with the scala implementation and calling `initWidgets`. This is must take place very close to the top of the notebook."
    ]
   },
   {
@@ -187,7 +187,7 @@
     "\n",
     "We then put all our functionality into an `object` that is marked as `Serializable`. This is a great technique to avoid serialization problems when interacting with Spark. Also not that anything that we do not want to serialize, such as the `StreamingContext` and the `SQLContext` should be marked `@transient`.\n",
     "\n",
-    "The rest of the call are methos for starting and stopping the streaming application as well as functions that define the streaming flow."
+    "The rest of the call are methods for starting and stopping the streaming application as well as functions that define the streaming flow."
    ]
   },
   {

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/etc/pip_install/toree/_version.py
----------------------------------------------------------------------
diff --git a/etc/pip_install/toree/_version.py b/etc/pip_install/toree/_version.py
index d2565b1..6d53da5 100644
--- a/etc/pip_install/toree/_version.py
+++ b/etc/pip_install/toree/_version.py
@@ -15,4 +15,4 @@
 # limitations under the License.
 #
 
-# This file is populated when doing a make release. It should be empty by defaut.
+# This file is populated when doing a make release. It should be empty by default.

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/kernel/src/test/scala/system/TruncationTests.scala
----------------------------------------------------------------------
diff --git a/kernel/src/test/scala/system/TruncationTests.scala b/kernel/src/test/scala/system/TruncationTests.scala
index f413cda..2fe107f 100644
--- a/kernel/src/test/scala/system/TruncationTests.scala
+++ b/kernel/src/test/scala/system/TruncationTests.scala
@@ -214,7 +214,7 @@ class TruncationTests
           """.stripMargin,actorLoader,ioPub) should be ("1")
       }
     }
-    it("should truncate or not turncate based on %truncate") {
+    it("should truncate or not truncate based on %truncate") {
       withNoArgSparkKernel { (actorLoader, heartbeat, shell, ioPub) =>
 
         executeCode("for ( a <-  1 to 300 ) yield a",actorLoader,ioPub) should endWith("...")

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/plugins/src/main/scala/org/apache/toree/plugins/dependencies/DependencyManager.scala
----------------------------------------------------------------------
diff --git a/plugins/src/main/scala/org/apache/toree/plugins/dependencies/DependencyManager.scala b/plugins/src/main/scala/org/apache/toree/plugins/dependencies/DependencyManager.scala
index ab6adfb..6348cd2 100644
--- a/plugins/src/main/scala/org/apache/toree/plugins/dependencies/DependencyManager.scala
+++ b/plugins/src/main/scala/org/apache/toree/plugins/dependencies/DependencyManager.scala
@@ -22,7 +22,7 @@ import scala.reflect.runtime.universe.{Type, TypeTag}
 import scala.util.Try
 
 /**
- * Contains helpers and contants associated with the dependency manager.
+ * Contains helpers and constants associated with the dependency manager.
  */
 object DependencyManager {
   /** Represents an empty dependency manager. */

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/protocol/src/main/scala/org/apache/toree/comm/CommManager.scala
----------------------------------------------------------------------
diff --git a/protocol/src/main/scala/org/apache/toree/comm/CommManager.scala b/protocol/src/main/scala/org/apache/toree/comm/CommManager.scala
index b6ba9c1..be8d2ff 100644
--- a/protocol/src/main/scala/org/apache/toree/comm/CommManager.scala
+++ b/protocol/src/main/scala/org/apache/toree/comm/CommManager.scala
@@ -74,7 +74,7 @@ abstract class CommManager(private val commRegistrar: CommRegistrar) {
       commWriter.close()
     }
 
-    // Overriden to link before sending open message
+    // Overridden to link before sending open message
     override def writeOpen(targetName: String, data: MsgData): Unit = {
       linkFunc(this, this.commId, targetName, data)
       commWriter.writeOpen(targetName, data)

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/protocol/src/main/scala/org/apache/toree/kernel/protocol/v5/content/ClearOutput.scala
----------------------------------------------------------------------
diff --git a/protocol/src/main/scala/org/apache/toree/kernel/protocol/v5/content/ClearOutput.scala b/protocol/src/main/scala/org/apache/toree/kernel/protocol/v5/content/ClearOutput.scala
index 4053b43..d82131b 100644
--- a/protocol/src/main/scala/org/apache/toree/kernel/protocol/v5/content/ClearOutput.scala
+++ b/protocol/src/main/scala/org/apache/toree/kernel/protocol/v5/content/ClearOutput.scala
@@ -29,7 +29,7 @@ case class ClearOutput (
     Json.toJson(this)(ClearOutput.clearOutputWrites).toString
 }
 
-//  Single property fields are not well supported by play, this is a little funky workaround founde here:
+//  Single property fields are not well supported by play, this is a little funky workaround found here:
 //  https://groups.google.com/forum/?fromgroups=#!starred/play-framework/hGrveOkbJ6U
 object ClearOutput extends TypeString {
   implicit val clearOutputReads: Reads[ClearOutput] = (

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/sparkr-interpreter/src/main/resources/R/pkg/R/DataFrame.R
----------------------------------------------------------------------
diff --git a/sparkr-interpreter/src/main/resources/R/pkg/R/DataFrame.R b/sparkr-interpreter/src/main/resources/R/pkg/R/DataFrame.R
index f833e70..5605124 100644
--- a/sparkr-interpreter/src/main/resources/R/pkg/R/DataFrame.R
+++ b/sparkr-interpreter/src/main/resources/R/pkg/R/DataFrame.R
@@ -612,7 +612,7 @@ setMethod("ncol",
             length(columns(x))
           })
 
-#' Returns the dimentions (number of rows and columns) of a DataFrame
+#' Returns the dimensions (number of rows and columns) of a DataFrame
 #' @param x a SparkSQL DataFrame
 #'
 #' @rdname dim

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/sparkr-interpreter/src/main/resources/R/pkg/R/RDD.R
----------------------------------------------------------------------
diff --git a/sparkr-interpreter/src/main/resources/R/pkg/R/RDD.R b/sparkr-interpreter/src/main/resources/R/pkg/R/RDD.R
index 051e441..6442797 100644
--- a/sparkr-interpreter/src/main/resources/R/pkg/R/RDD.R
+++ b/sparkr-interpreter/src/main/resources/R/pkg/R/RDD.R
@@ -1438,7 +1438,7 @@ setMethod("glom",
 #
 # @param x An RDD.
 # @param y An RDD.
-# @return a new RDD created by performing the simple union (witout removing
+# @return a new RDD created by performing the simple union (without removing
 # duplicates) of two input RDDs.
 # @examples
 #\dontrun{

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/sparkr-interpreter/src/main/resources/R/pkg/R/SQLContext.R
----------------------------------------------------------------------
diff --git a/sparkr-interpreter/src/main/resources/R/pkg/R/SQLContext.R b/sparkr-interpreter/src/main/resources/R/pkg/R/SQLContext.R
index 1bc6445..91459b7 100644
--- a/sparkr-interpreter/src/main/resources/R/pkg/R/SQLContext.R
+++ b/sparkr-interpreter/src/main/resources/R/pkg/R/SQLContext.R
@@ -200,7 +200,7 @@ setMethod("toDF", signature(x = "RDD"),
 #' }
 
 jsonFile <- function(sqlContext, path) {
-  # Allow the user to have a more flexible definiton of the text file path
+  # Allow the user to have a more flexible definition of the text file path
   path <- suppressWarnings(normalizePath(path))
   # Convert a string vector of paths to a string containing comma separated paths
   path <- paste(path, collapse = ",")
@@ -250,7 +250,7 @@ jsonRDD <- function(sqlContext, rdd, schema = NULL, samplingRatio = 1.0) {
 
 # TODO: Implement saveasParquetFile and write examples for both
 parquetFile <- function(sqlContext, ...) {
-  # Allow the user to have a more flexible definiton of the text file path
+  # Allow the user to have a more flexible definition of the text file path
   paths <- lapply(list(...), function(x) suppressWarnings(normalizePath(x)))
   sdf <- callJMethod(sqlContext, "parquetFile", paths)
   dataFrame(sdf)

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/sparkr-interpreter/src/main/resources/R/pkg/R/context.R
----------------------------------------------------------------------
diff --git a/sparkr-interpreter/src/main/resources/R/pkg/R/context.R b/sparkr-interpreter/src/main/resources/R/pkg/R/context.R
index 720990e..4c026a5 100644
--- a/sparkr-interpreter/src/main/resources/R/pkg/R/context.R
+++ b/sparkr-interpreter/src/main/resources/R/pkg/R/context.R
@@ -43,7 +43,7 @@ getMinPartitions <- function(sc, minPartitions) {
 #  lines <- textFile(sc, "myfile.txt")
 #}
 textFile <- function(sc, path, minPartitions = NULL) {
-  # Allow the user to have a more flexible definiton of the text file path
+  # Allow the user to have a more flexible definition of the text file path
   path <- suppressWarnings(normalizePath(path))
   # Convert a string vector of paths to a string containing comma separated paths
   path <- paste(path, collapse = ",")
@@ -71,7 +71,7 @@ textFile <- function(sc, path, minPartitions = NULL) {
 #  rdd <- objectFile(sc, "myfile")
 #}
 objectFile <- function(sc, path, minPartitions = NULL) {
-  # Allow the user to have a more flexible definiton of the text file path
+  # Allow the user to have a more flexible definition of the text file path
   path <- suppressWarnings(normalizePath(path))
   # Convert a string vector of paths to a string containing comma separated paths
   path <- paste(path, collapse = ",")

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/sparkr-interpreter/src/main/resources/R/pkg/R/deserialize.R
----------------------------------------------------------------------
diff --git a/sparkr-interpreter/src/main/resources/R/pkg/R/deserialize.R b/sparkr-interpreter/src/main/resources/R/pkg/R/deserialize.R
index 33bf13e..c5bbd61 100644
--- a/sparkr-interpreter/src/main/resources/R/pkg/R/deserialize.R
+++ b/sparkr-interpreter/src/main/resources/R/pkg/R/deserialize.R
@@ -136,7 +136,7 @@ readDeserializeRows <- function(inputCon) {
   # readDeserializeRows will deserialize a DataOutputStream composed of
   # a list of lists. Since the DOS is one continuous stream and
   # the number of rows varies, we put the readRow function in a while loop
-  # that termintates when the next row is empty.
+  # that terminates when the next row is empty.
   data <- list()
   while(TRUE) {
     row <- readRow(inputCon)

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/sparkr-interpreter/src/main/resources/R/pkg/R/pairRDD.R
----------------------------------------------------------------------
diff --git a/sparkr-interpreter/src/main/resources/R/pkg/R/pairRDD.R b/sparkr-interpreter/src/main/resources/R/pkg/R/pairRDD.R
index 199c3fd..3680adc 100644
--- a/sparkr-interpreter/src/main/resources/R/pkg/R/pairRDD.R
+++ b/sparkr-interpreter/src/main/resources/R/pkg/R/pairRDD.R
@@ -395,7 +395,7 @@ setMethod("reduceByKeyLocally",
 # \itemize{
 #   \item createCombiner, which turns a V into a C (e.g., creates a one-element list)
 #   \item mergeValue, to merge a V into a C (e.g., adds it to the end of a list) -
-#   \item mergeCombiners, to combine two C's into a single one (e.g., concatentates
+#   \item mergeCombiners, to combine two C's into a single one (e.g., concatenates
 #    two lists).
 # }
 #

http://git-wip-us.apache.org/repos/asf/incubator-toree/blob/429c74c6/sparkr-interpreter/src/main/resources/R/pkg/inst/tests/test_utils.R
----------------------------------------------------------------------
diff --git a/sparkr-interpreter/src/main/resources/R/pkg/inst/tests/test_utils.R b/sparkr-interpreter/src/main/resources/R/pkg/inst/tests/test_utils.R
index 12df4cf..9325c86 100644
--- a/sparkr-interpreter/src/main/resources/R/pkg/inst/tests/test_utils.R
+++ b/sparkr-interpreter/src/main/resources/R/pkg/inst/tests/test_utils.R
@@ -100,7 +100,7 @@ test_that("cleanClosure on R functions", {
   expect_true("l" %in% ls(env))
   expect_true("f" %in% ls(env))
   expect_equal(get("l", envir = env, inherits = FALSE), l)
-  # "y" should be in the environemnt of g.
+  # "y" should be in the environment of g.
   newG <- get("g", envir = env, inherits = FALSE)
   env <- environment(newG)
   expect_equal(length(ls(env)), 1)