org.apache.spark.h2o

H2OContext

class H2OContext extends Logging with H2OConf with Serializable

Simple H2O context motivated by SQLContext.

It provides implicit conversion from RDD -> H2OLikeRDD and back.

Linear Supertypes
Serializable, Serializable, H2OConf, Logging, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. H2OContext
  2. Serializable
  3. Serializable
  4. H2OConf
  5. Logging
  6. AnyRef
  7. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new H2OContext(sparkContext: JavaSparkContext)

    Supports call from java environments.

  2. new H2OContext(sparkContext: SparkContext)

Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. def asDataFrame(s: String)(implicit sqlContext: SQLContext): DataFrame

  7. def asDataFrame(fr: H2OFrame)(implicit sqlContext: SQLContext): DataFrame

  8. def asH2OFrame(s: String): H2OFrame

    Create a new H2OFrame based on existing Frame referenced by its key.

  9. implicit def asH2OFrame(fr: Frame): H2OFrame

    Implicit conversion from Frame to DataFrame

  10. def asH2OFrame(df: DataFrame, frameName: String): H2OFrame

  11. def asH2OFrame(df: DataFrame, frameName: Option[String]): H2OFrame

  12. implicit def asH2OFrame(df: DataFrame): H2OFrame

    Implicit conversion from Spark DataFrame to H2O's DataFrame

  13. def asH2OFrame(rdd: SupportedRDD, frameName: String): H2OFrame

  14. def asH2OFrame(rdd: SupportedRDD, frameName: Option[String]): H2OFrame

  15. def asH2OFrame(rdd: SupportedRDD): H2OFrame

    Transforms RDD[Supported type] to H2OFrame

  16. def asH2OFrameFromRDDBool(rdd: JavaRDD[Boolean], frameName: String): H2OFrame

    Conversion from RDD[Boolean] to H2O's DataFrame

  17. implicit def asH2OFrameFromRDDBool(rdd: RDD[Boolean]): H2OFrame

  18. def asH2OFrameFromRDDBoolKey(rdd: JavaRDD[Boolean], frameName: String): Key[Frame]

    Returns key of the H2O's DataFrame conversed from RDD[Boolean]

  19. implicit def asH2OFrameFromRDDByte(rdd: RDD[Byte]): H2OFrame

  20. def asH2OFrameFromRDDDouble(rdd: JavaRDD[Double], frameName: String): H2OFrame

    Conversion from RDD[Double] to H2O's DataFrame

  21. implicit def asH2OFrameFromRDDDouble(rdd: RDD[Double]): H2OFrame

  22. def asH2OFrameFromRDDDoubleKey(rdd: JavaRDD[Double], frameName: String): Key[Frame]

    Returns key of the H2O's DataFrame conversed from RDD[Double]

  23. implicit def asH2OFrameFromRDDLabeledPoint(rdd: RDD[LabeledPoint]): H2OFrame

  24. def asH2OFrameFromRDDLong(rdd: JavaRDD[Long], frameName: String): H2OFrame

    Conversion from RDD[Long] to H2O's DataFrame

  25. implicit def asH2OFrameFromRDDLong(rdd: RDD[Long]): H2OFrame

  26. def asH2OFrameFromRDDLongKey(rdd: JavaRDD[Long], frameName: String): Key[Frame]

    Returns key of the H2O's DataFrame conversed from RDD[Long]

  27. implicit def asH2OFrameFromRDDProduct[A <: Product](rdd: RDD[A])(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A]): H2OFrame

    Implicit conversion from RDD[Supported type] to H2OFrame

  28. implicit def asH2OFrameFromRDDShort(rdd: RDD[Short]): H2OFrame

  29. def asH2OFrameFromRDDString(rdd: JavaRDD[String], frameName: String): H2OFrame

    Conversion from RDD[String] to H2O's DataFrame

  30. implicit def asH2OFrameFromRDDString(rdd: RDD[String]): H2OFrame

  31. def asH2OFrameFromRDDStringKey(rdd: JavaRDD[String], frameName: String): Key[Frame]

    Returns key of the H2O's DataFrame conversed from RDD[String]

  32. implicit def asH2OFrameFromRDDTimeStamp(rdd: RDD[Timestamp]): H2OFrame

  33. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  34. def asRDD[A <: Product](fr: H2OFrame)(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A], arg1: ClassTag[A]): RDD[A]

    Convert given H2O frame into a Product RDD type

  35. def clientBasePort: Int

    Definition Classes
    H2OConf
  36. def clientIcedDir: Option[String]

    Definition Classes
    H2OConf
  37. def clientIp: Option[String]

    Definition Classes
    H2OConf
  38. def clientWebPort: Int

    Definition Classes
    H2OConf
  39. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  40. def cloudName: String

    Definition Classes
    H2OConf
  41. def cloudTimeout: Int

    Definition Classes
    H2OConf
  42. def createH2ORDD[A <: Product](fr: H2OFrame)(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A], arg1: ClassTag[A]): RDD[A]

  43. def createH2OSchemaRDD(fr: H2OFrame)(implicit sqlContext: SQLContext): DataFrame

  44. def defaultCloudSize: Int

    Definition Classes
    H2OConf
  45. def disableGA: Boolean

    Definition Classes
    H2OConf
  46. def drddMulFactor: Int

    Definition Classes
    H2OConf
  47. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  48. def equals(arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  49. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  50. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  51. def getH2OClientArgs: Array[String]

    Get arguments for H2O client.

    Get arguments for H2O client.

    returns

    array of H2O client arguments.

    Definition Classes
    H2OConf
  52. def getH2ONodeArgs: Array[String]

    Produce arguments for H2O node based on this config.

    Produce arguments for H2O node based on this config.

    returns

    array of H2O launcher command line arguments

    Definition Classes
    H2OConf
  53. def h2oClientLogDir: String

    Definition Classes
    H2OConf
  54. def h2oClientLogLevel: String

    Definition Classes
    H2OConf
  55. def h2oLocalClient: String

  56. def h2oLocalClientIp: String

  57. def h2oLocalClientPort: Int

  58. def h2oNodeLogDir: String

    Definition Classes
    H2OConf
  59. def h2oNodeLogLevel: String

    Definition Classes
    H2OConf
  60. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  61. def hashLogin: Boolean

    Definition Classes
    H2OConf
  62. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  63. def isTraceEnabled(): Boolean

    Attributes
    protected
    Definition Classes
    Logging
  64. def jks: Option[String]

    Definition Classes
    H2OConf
  65. def jksPass: Option[String]

    Definition Classes
    H2OConf
  66. def ldapLogin: Boolean

    Definition Classes
    H2OConf
  67. def log: Logger

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

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

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  74. def logName: String

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  79. def loginConf: Option[String]

    Definition Classes
    H2OConf
  80. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  81. def networkMask: Option[String]

    Definition Classes
    H2OConf
  82. def nodeBasePort: Int

    Definition Classes
    H2OConf
  83. def nodeIcedDir: Option[String]

    Definition Classes
    H2OConf
  84. final def notify(): Unit

    Definition Classes
    AnyRef
  85. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  86. def nthreads: Int

    Definition Classes
    H2OConf
  87. def numH2OWorkers: Option[Int]

    Definition Classes
    H2OConf
  88. def numRddRetries: Int

    Definition Classes
    H2OConf
  89. def openFlow(): Unit

    Open H2O Flow running in this client.

  90. def scalaIntDefaultNum: Int

    Definition Classes
    H2OConf
  91. val sparkConf: SparkConf

    Definition Classes
    H2OContextH2OConf
  92. val sparkContext: SparkContext

  93. def start(): H2OContext

    Initialize Sparkling H2O and start H2O cloud.

  94. def stop(stopSparkContext: Boolean = false): Unit

    Stops H2O context.

    Stops H2O context.

    Calls System.exit() which kills executor JVM.

  95. def subseqTries: Int

    Definition Classes
    H2OConf
  96. implicit def symbolToString(sy: Symbol): String

    Transform given Scala symbol to String

  97. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  98. implicit def toH2OFrameKey(fr: Frame): Key[Frame]

  99. def toH2OFrameKey(rdd: DataFrame, frameName: String): Key[Frame]

  100. def toH2OFrameKey(rdd: DataFrame, frameName: Option[String]): Key[Frame]

  101. implicit def toH2OFrameKey(rdd: DataFrame): Key[Frame]

    Implicit conversion from Spark DataFrame to H2O's DataFrame

  102. def toH2OFrameKey(rdd: SupportedRDD, frameName: String): Key[_]

  103. def toH2OFrameKey(rdd: SupportedRDD, frameName: Option[String]): Key[_]

  104. def toH2OFrameKey(rdd: SupportedRDD): Key[_]

    Transforms RDD[Supported type] to H2OFrame key

  105. implicit def toH2OFrameKeyFromRDDBool(rdd: RDD[Boolean]): Key[_]

  106. implicit def toH2OFrameKeyFromRDDByte(rdd: RDD[Byte]): Key[_]

  107. implicit def toH2OFrameKeyFromRDDDouble(rdd: RDD[Double]): Key[_]

  108. implicit def toH2OFrameKeyFromRDDLabeledPoint(rdd: RDD[LabeledPoint]): Key[_]

  109. implicit def toH2OFrameKeyFromRDDLong(rdd: RDD[Long]): Key[_]

  110. implicit def toH2OFrameKeyFromRDDProduct[A <: Product](rdd: RDD[A])(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A]): Key[_]

    Implicit conversion from RDD[Supported type] to H2OFrame key

  111. implicit def toH2OFrameKeyFromRDDShort(rdd: RDD[Short]): Key[_]

  112. implicit def toH2OFrameKeyFromRDDString(rdd: RDD[String]): Key[_]

  113. implicit def toH2OFrameKeyFromRDDTimeStamp(rdd: RDD[Timestamp]): Key[_]

  114. def toString(): String

    Definition Classes
    H2OContextH2OConf → AnyRef → Any
  115. def useFlatFile: Boolean

    Definition Classes
    H2OConf
  116. def userName: Option[String]

    Definition Classes
    H2OConf
  117. final def wait(): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  118. final def wait(arg0: Long, arg1: Int): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  119. final def wait(arg0: Long): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Deprecated Value Members

  1. def asSchemaRDD(fr: H2OFrame)(implicit sqlContext: SQLContext): DataFrame

    Convert given H2O frame into DataFrame type

    Convert given H2O frame into DataFrame type

    Annotations
    @deprecated
    Deprecated

    (Since version Use asDataFrame) 1.3

  2. def start(h2oWorkers: Int): H2OContext

    Initialize Sparkling H2O and start H2O cloud with specified number of workers.

    Initialize Sparkling H2O and start H2O cloud with specified number of workers.

    Annotations
    @deprecated
    Deprecated

    (Since version 1.5.11) Use start() method.

  3. def toRDD[A <: Product](fr: H2OFrame)(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A], arg1: ClassTag[A]): RDD[A]

    Convert given H2O frame into a RDD type

    Convert given H2O frame into a RDD type

    Annotations
    @deprecated
    Deprecated

    (Since version 0.2.3) Use asRDD instead

Inherited from Serializable

Inherited from Serializable

Inherited from H2OConf

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped