Skip to content

Commit

Permalink
minor
Browse files Browse the repository at this point in the history
  • Loading branch information
mengxr committed Oct 20, 2016
1 parent 2ec3206 commit e2ebd88
Show file tree
Hide file tree
Showing 4 changed files with 4 additions and 7 deletions.
1 change: 0 additions & 1 deletion core/src/main/scala/org/apache/spark/rdd/RDD.scala
Original file line number Diff line number Diff line change
Expand Up @@ -816,7 +816,6 @@ abstract class RDD[T: ClassTag](
preservesPartitioning)
}


/**
* Return a new RDD by applying a function to each partition of this RDD, while tracking the index
* of the original partition.
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,6 @@ import org.apache.spark.sql.types.{DataType, StructType}

/**
* A [[Projection]] that is calculated by calling the `eval` of each of the specified expressions.
*
* @param expressions a sequence of expressions that determine the value of each column of the
* output row.
*/
Expand Down Expand Up @@ -57,7 +56,6 @@ class InterpretedProjection(expressions: Seq[Expression]) extends Projection {
/**
* A [[MutableProjection]] that is calculated by calling `eval` on each of the specified
* expressions.
*
* @param expressions a sequence of expressions that determine the value of each column of the
* output row.
*/
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -22,10 +22,10 @@ import org.apache.spark.sql.catalyst.expressions.codegen.{CodegenContext, ExprCo
import org.apache.spark.sql.types.{DataType, IntegerType}

/**
* Expression that returns the current partition id of the Spark task.
* Expression that returns the current partition id.
*/
@ExpressionDescription(
usage = "_FUNC_() - Returns the current partition id of the Spark task",
usage = "_FUNC_() - Returns the current partition id",
extended = "> SELECT _FUNC_();\n 0")
case class SparkPartitionID() extends LeafExpression with Nondeterministic {

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -185,8 +185,8 @@ class CodegenContext {
}

/**
* Code statements to initialize states that depends on the partition index.
* An integer `partitionIndex` will be available within the scope.
* Code statements to initialize states that depend on the partition index.
* An integer `partitionIndex` will be made available within the scope.
*/
val partitionInitializationStatements: mutable.ArrayBuffer[String] = mutable.ArrayBuffer.empty

Expand Down

0 comments on commit e2ebd88

Please sign in to comment.