Package

org.apache.spark

h2o

Permalink

package h2o

Type shortcuts to simplify work in Sparkling REPL

Linear Supertypes
Logging, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. h2o
  2. Logging
  3. AnyRef
  4. 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 with Serializable

    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. implicit class WithSQLContext extends AnyRef

    Permalink
  27. 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 extends Serializable

    Permalink
  5. object H2OContext extends Logging

    Permalink
  6. package backends

    Permalink
  7. package converters

    Permalink
  8. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  9. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  10. def log: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  11. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  12. def logDebug(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  13. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  14. def logError(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  15. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  16. def logInfo(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  17. def logName: String

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  18. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  19. def logTrace(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  20. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  21. def logWarning(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  22. package ui

    Permalink
  23. package utils

    Permalink

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped