Skip to content

Commit 345825d

Browse files
lianchengpwendell
authored andcommitted
Unified package definition format in Spark SQL
According to discussions in comments of PR #208, this PR unifies package definition format in Spark SQL. Some broken links in ScalaDoc and typos detected along the way are also fixed. Author: Cheng Lian <[email protected]> Closes #225 from liancheng/packageDefinition and squashes the following commits: 75c47b3 [Cheng Lian] Fixed file line length 4f87968 [Cheng Lian] Unified package definition format in Spark SQL
1 parent a0853a3 commit 345825d

File tree

103 files changed

+209
-333
lines changed

Some content is hidden

Large Commits have some content hidden by default. Use the searchbox below for content that may be hidden.

103 files changed

+209
-333
lines changed

core/src/main/scala/org/apache/spark/Dependency.scala

Lines changed: 3 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -44,8 +44,9 @@ abstract class NarrowDependency[T](rdd: RDD[T]) extends Dependency(rdd) {
4444
* Represents a dependency on the output of a shuffle stage.
4545
* @param rdd the parent RDD
4646
* @param partitioner partitioner used to partition the shuffle output
47-
* @param serializer [[Serializer]] to use. If set to null, the default serializer, as specified
48-
* by `spark.serializer` config option, will be used.
47+
* @param serializer [[org.apache.spark.serializer.Serializer Serializer]] to use. If set to null,
48+
* the default serializer, as specified by `spark.serializer` config option, will
49+
* be used.
4950
*/
5051
class ShuffleDependency[K, V](
5152
@transient rdd: RDD[_ <: Product2[K, V]],

core/src/main/scala/org/apache/spark/api/java/JavaRDDLike.scala

Lines changed: 2 additions & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -481,7 +481,7 @@ trait JavaRDDLike[T, This <: JavaRDDLike[T, This]] extends Serializable {
481481
/**
482482
* Returns the maximum element from this RDD as defined by the specified
483483
* Comparator[T].
484-
* @params comp the comparator that defines ordering
484+
* @param comp the comparator that defines ordering
485485
* @return the maximum of the RDD
486486
* */
487487
def max(comp: Comparator[T]): T = {
@@ -491,7 +491,7 @@ trait JavaRDDLike[T, This <: JavaRDDLike[T, This]] extends Serializable {
491491
/**
492492
* Returns the minimum element from this RDD as defined by the specified
493493
* Comparator[T].
494-
* @params comp the comparator that defines ordering
494+
* @param comp the comparator that defines ordering
495495
* @return the minimum of the RDD
496496
* */
497497
def min(comp: Comparator[T]): T = {

sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/ScalaReflection.scala

Lines changed: 1 addition & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -15,8 +15,7 @@
1515
* limitations under the License.
1616
*/
1717

18-
package org.apache.spark.sql
19-
package catalyst
18+
package org.apache.spark.sql.catalyst
2019

2120
import org.apache.spark.sql.catalyst.expressions.Attribute
2221
import org.apache.spark.sql.catalyst.expressions.AttributeReference

sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/analysis/Analyzer.scala

Lines changed: 4 additions & 5 deletions
Original file line numberDiff line numberDiff line change
@@ -15,9 +15,7 @@
1515
* limitations under the License.
1616
*/
1717

18-
package org.apache.spark.sql
19-
package catalyst
20-
package analysis
18+
package org.apache.spark.sql.catalyst.analysis
2119

2220
import org.apache.spark.sql.catalyst.expressions._
2321
import org.apache.spark.sql.catalyst.plans.logical._
@@ -89,7 +87,8 @@ class Analyzer(catalog: Catalog, registry: FunctionRegistry, caseSensitive: Bool
8987

9088
/**
9189
* Replaces [[UnresolvedAttribute]]s with concrete
92-
* [[expressions.AttributeReference AttributeReferences]] from a logical plan node's children.
90+
* [[catalyst.expressions.AttributeReference AttributeReferences]] from a logical plan node's
91+
* children.
9392
*/
9493
object ResolveReferences extends Rule[LogicalPlan] {
9594
def apply(plan: LogicalPlan): LogicalPlan = plan transformUp {
@@ -106,7 +105,7 @@ class Analyzer(catalog: Catalog, registry: FunctionRegistry, caseSensitive: Bool
106105
}
107106

108107
/**
109-
* Replaces [[UnresolvedFunction]]s with concrete [[expressions.Expression Expressions]].
108+
* Replaces [[UnresolvedFunction]]s with concrete [[catalyst.expressions.Expression Expressions]].
110109
*/
111110
object ResolveFunctions extends Rule[LogicalPlan] {
112111
def apply(plan: LogicalPlan): LogicalPlan = plan transform {

sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/analysis/Catalog.scala

Lines changed: 1 addition & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -15,9 +15,7 @@
1515
* limitations under the License.
1616
*/
1717

18-
package org.apache.spark.sql
19-
package catalyst
20-
package analysis
18+
package org.apache.spark.sql.catalyst.analysis
2119

2220
import scala.collection.mutable
2321

sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/analysis/FunctionRegistry.scala

Lines changed: 1 addition & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -15,9 +15,7 @@
1515
* limitations under the License.
1616
*/
1717

18-
package org.apache.spark.sql
19-
package catalyst
20-
package analysis
18+
package org.apache.spark.sql.catalyst.analysis
2119

2220
import org.apache.spark.sql.catalyst.expressions.Expression
2321

sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/analysis/HiveTypeCoercion.scala

Lines changed: 3 additions & 5 deletions
Original file line numberDiff line numberDiff line change
@@ -15,9 +15,7 @@
1515
* limitations under the License.
1616
*/
1717

18-
package org.apache.spark.sql
19-
package catalyst
20-
package analysis
18+
package org.apache.spark.sql.catalyst.analysis
2119

2220
import org.apache.spark.sql.catalyst.expressions._
2321
import org.apache.spark.sql.catalyst.plans.logical.{LogicalPlan, Project, Union}
@@ -37,8 +35,8 @@ trait HiveTypeCoercion {
3735
StringToIntegralCasts, FunctionArgumentConversion)
3836

3937
/**
40-
* Applies any changes to [[catalyst.expressions.AttributeReference AttributeReference]] dataTypes
41-
* that are made by other rules to instances higher in the query tree.
38+
* Applies any changes to [[catalyst.expressions.AttributeReference AttributeReference]] data
39+
* types that are made by other rules to instances higher in the query tree.
4240
*/
4341
object PropagateTypes extends Rule[LogicalPlan] {
4442
def apply(plan: LogicalPlan): LogicalPlan = plan transform {

sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/analysis/MultiInstanceRelation.scala

Lines changed: 1 addition & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -15,8 +15,7 @@
1515
* limitations under the License.
1616
*/
1717

18-
package org.apache.spark.sql.catalyst
19-
package analysis
18+
package org.apache.spark.sql.catalyst.analysis
2019

2120
import org.apache.spark.sql.catalyst.rules.Rule
2221
import org.apache.spark.sql.catalyst.plans.logical.LogicalPlan

sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/analysis/package.scala

Lines changed: 1 addition & 2 deletions
Original file line numberDiff line numberDiff line change
@@ -15,8 +15,7 @@
1515
* limitations under the License.
1616
*/
1717

18-
package org.apache.spark.sql
19-
package catalyst
18+
package org.apache.spark.sql.catalyst
2019

2120
/**
2221
* Provides a logical query plan [[Analyzer]] and supporting classes for performing analysis.

sql/catalyst/src/main/scala/org/apache/spark/sql/catalyst/analysis/unresolved.scala

Lines changed: 2 additions & 3 deletions
Original file line numberDiff line numberDiff line change
@@ -15,10 +15,9 @@
1515
* limitations under the License.
1616
*/
1717

18-
package org.apache.spark.sql
19-
package catalyst
20-
package analysis
18+
package org.apache.spark.sql.catalyst.analysis
2119

20+
import org.apache.spark.sql.catalyst.{errors, trees}
2221
import org.apache.spark.sql.catalyst.expressions.{Alias, Attribute, Expression, NamedExpression}
2322
import org.apache.spark.sql.catalyst.plans.logical.BaseRelation
2423
import org.apache.spark.sql.catalyst.trees.TreeNode

0 commit comments

Comments
 (0)