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. trait Announcement extends AnyRef

    Permalink
  2. trait AnnouncementProvider extends AnnouncementService with Logging

    Permalink

    Target announcement service implemented for different technologies - REST/Redis

  3. trait AnnouncementService extends AnyRef

    Permalink

    A top-level announcement service.

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

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

    Permalink
  6. 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).

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

    Permalink
  8. case class FlowLocationAnnouncement(clusterId: String, proto: String, ip: String, port: Int) extends Announcement with Product with Serializable

    Permalink
  9. type Frame = water.fvec.Frame

    Permalink
  10. type H2O = water.H2O

    Permalink
  11. class H2OConf extends Logging with InternalBackendConf with ExternalBackendConf

    Permalink

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

  12. class H2OContext extends Logging with H2OContextUtils

    Permalink

    Create new H2OContext based on provided H2O configuration

  13. abstract class H2OContextImplicits extends AnyRef

    Permalink

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

  14. 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()

  15. 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()

  16. type H2OFrame = water.fvec.H2OFrame

    Permalink
  17. trait Holder[T] extends AnyRef

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

    Permalink
  19. class JavaH2OContext extends AnyRef

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

    Permalink
  21. class RDDDoubleConversionFunc extends Function[Number, Double]

    Permalink
  22. class RDDLongConversionFunc extends Function[Number, Long]

    Permalink
  23. class RestAnnouncementProvider extends AnnouncementProvider

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

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

    Permalink
  26. class WrongSparkVersion extends Exception with NoStackTrace

    Permalink

Value Members

  1. object AnnouncementServiceFactory

    Permalink

    Factory to create announcement service.

  2. object BuildInfo

    Permalink

    Store information about H2O & Sparkling Water versions so they are available at run-time

  3. object DataSourceUtils

    Permalink
  4. object H2OConf

    Permalink
  5. object H2OContext extends Logging

    Permalink
  6. package backends

    Permalink
  7. package converters

    Permalink
  8. package ui

    Permalink
  9. package utils

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped