Skip to content

Commit

Permalink
Move import and add (Scala-specific) to scala APIs.
Browse files Browse the repository at this point in the history
  • Loading branch information
yhuai committed Feb 9, 2015
1 parent cf5703d commit e04d908
Show file tree
Hide file tree
Showing 2 changed files with 7 additions and 4 deletions.
6 changes: 3 additions & 3 deletions sql/core/src/main/scala/org/apache/spark/sql/DataFrame.scala
Original file line number Diff line number Diff line change
Expand Up @@ -17,19 +17,17 @@

package org.apache.spark.sql

import org.apache.spark.sql.sources.SaveMode

import scala.reflect.ClassTag

import org.apache.spark.annotation.{DeveloperApi, Experimental}
import org.apache.spark.api.java.JavaRDD
import org.apache.spark.rdd.RDD
import org.apache.spark.storage.StorageLevel
import org.apache.spark.sql.catalyst.plans.logical._
import org.apache.spark.sql.sources.SaveMode
import org.apache.spark.sql.types.StructType
import org.apache.spark.util.Utils


private[sql] object DataFrame {
def apply(sqlContext: SQLContext, logicalPlan: LogicalPlan): DataFrame = {
new DataFrameImpl(sqlContext, logicalPlan)
Expand Down Expand Up @@ -627,6 +625,7 @@ trait DataFrame extends RDDApi[Row] {

/**
* :: Experimental ::
* (Scala-specific)
* Creates a table from the the contents of this DataFrame based on a given data source
* and a set of options.
* If appendIfExists is true and the table already exists,
Expand Down Expand Up @@ -688,6 +687,7 @@ trait DataFrame extends RDDApi[Row] {

/**
* :: Experimental ::
* (Scala-specific)
* Saves the contents of this DataFrame based on the given data source and a set of options.
*/
@Experimental
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -412,7 +412,6 @@ class SQLContext(@transient val sparkContext: SparkContext)
/**
* :: Experimental ::
* Loads a dataset from the given path as a DataFrame based on a given data source.
* It will use the default data source configured in spark.sql.sources.default.
*/
@Experimental
def load(
Expand All @@ -434,6 +433,7 @@ class SQLContext(@transient val sparkContext: SparkContext)

/**
* :: Experimental ::
* (Scala-specific)
* Loads a dataset based on a given data source and a set of options.
*/
@Experimental
Expand All @@ -458,6 +458,7 @@ class SQLContext(@transient val sparkContext: SparkContext)

/**
* :: Experimental ::
* (Scala-specific)
* Loads a dataset based on a given data source, a schema and a set of options.
*/
@Experimental
Expand Down Expand Up @@ -508,6 +509,7 @@ class SQLContext(@transient val sparkContext: SparkContext)

/**
* :: Experimental ::
* (Scala-specific)
* Creates an external table from the given path based on a data source and a set of options.
* Then, returns the corresponding DataFrame.
*/
Expand Down Expand Up @@ -545,6 +547,7 @@ class SQLContext(@transient val sparkContext: SparkContext)

/**
* :: Experimental ::
* (Scala-specific)
* Create an external table from the given path based on a data source, a schema and
* a set of options. Then, returns the corresponding DataFrame.
*/
Expand Down

0 comments on commit e04d908

Please sign in to comment.