Package

org.apache.spark

h2o

Permalink

package h2o

Type shortcuts to simplify work in Sparkling REPL

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. h2o
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. case class ByteHolder(result: Option[Byte]) extends Holder[Byte] with Product with Serializable

    Permalink
  2. type Dataset[X] = sql.Dataset[X]

    Permalink
  3. class DefaultSource extends RelationProvider with SchemaRelationProvider with CreatableRelationProvider with DataSourceRegister

    Permalink

    Provides access to H2OFrame from pure SQL statements (i.e.

    Provides access to H2OFrame from pure SQL statements (i.e. for users of the JDBC server).

  4. case class DoubleHolder(result: Option[Double]) extends Holder[Double] with Product with Serializable

    Permalink
  5. type Frame = water.fvec.Frame

    Permalink
  6. type H2O = water.H2O

    Permalink
  7. class H2OConf extends Logging with InternalBackendConf

    Permalink

    Configuration holder which is representing properties passed from user to Sparkling Water.

  8. class H2OContext extends Logging with Serializable with SparkDataFrameConverter with SupportedRDDConverter with H2OContextUtils

    Permalink

    Create new H2OContext based on provided H2O configuration

  9. abstract class H2OContextImplicits extends AnyRef

    Permalink

    Implicit transformations available on org.apache.spark.h2o.H2OContext

  10. implicit class H2ODataFrameReader extends AnyRef

    Permalink

    Adds a method, h2o, to DataFrameReader that allows you to read h2o frames using the DataFileReader.

    Adds a method, h2o, to DataFrameReader that allows you to read h2o frames using the DataFileReader. It's alias for sqlContext.read.format("org.apache.spark.h2o").option("key",frame.key.toString).load()

  11. implicit class H2ODataFrameWriter[T] extends AnyRef

    Permalink

    Adds a method, h2o, to DataFrameWriter that allows you to write h2o frames using the DataFileWriter.

    Adds a method, h2o, to DataFrameWriter that allows you to write h2o frames using the DataFileWriter. It's alias for sqlContext.write.format("org.apache.spark.h2o").option("key","new_frame_key").save()

  12. type H2OFrame = water.fvec.H2OFrame

    Permalink
  13. trait Holder[T] extends AnyRef

    Permalink
  14. case class IntHolder(result: Option[Int]) extends Holder[Int] with Product with Serializable

    Permalink
  15. class JavaH2OContext extends AnyRef

    Permalink
  16. type RDD[X] = rdd.RDD[X]

    Permalink
  17. case class ShortHolder(result: Option[Short]) extends Holder[Short] with Product with Serializable

    Permalink
  18. case class StringHolder(result: Option[String]) extends Holder[String] with Product with Serializable

    Permalink
  19. class WrongSparkVersion extends Exception with NoStackTrace

    Permalink

Value Members

  1. object DataSourceUtils

    Permalink
  2. object H2OConf

    Permalink
  3. object H2OContext extends Logging with Serializable

    Permalink
  4. package backends

    Permalink
  5. package converters

    Permalink
  6. package utils

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped