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.

Self Type
H2OContext
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[T <: Frame](fr: T)(implicit sqlContext: SQLContext): DataFrame

  8. def asH2OFrame(fr: Frame): H2OFrame

    Create a new H2OFrame based on existing Frame

  9. def asH2OFrame(s: String): H2OFrame

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

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

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

  12. def asH2OFrame(df: DataFrame): H2OFrame

    Transform DataFrame to H2OFrame

  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. def asH2OFrameFromRDDBoolKey(rdd: JavaRDD[Boolean], frameName: String): Key[Frame]

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

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

    Conversion from RDD[Double] to H2O's DataFrame

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

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

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

    Conversion from RDD[Long] to H2O's DataFrame

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

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

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

    Conversion from RDD[String] to H2O's DataFrame

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

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

  24. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  25. def asRDD[A <: Product](implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A], arg1: ClassTag[A]): AnyRef { def apply[T <: org.apache.spark.h2o.Frame](fr: T): org.apache.spark.h2o.RDD[A] }

    A generic convert of Frame into Product RDD type

    A generic convert of Frame into Product RDD type

    This code: hc.asRDD[PUBDEV458Type](rdd) will need to be call as hc.asRDD[PUBDEV458Type].apply(rdd)

  26. 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

  27. def buildSparkMajorVersion: String

    Returns Major Spark version for which is this version of Sparkling Water designated.

    Returns Major Spark version for which is this version of Sparkling Water designated.

    For example, for 1.6.1 returns 1.6

    Definition Classes
    H2OConf
  28. def clientBasePort: Int

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

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

    Definition Classes
    H2OConf
  31. def clientNetworkMask: Option[String]

    Definition Classes
    H2OConf
  32. def clientVerboseOutput: Boolean

    Definition Classes
    H2OConf
  33. def clientWebPort: Int

    Definition Classes
    H2OConf
  34. def clone(): AnyRef

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

    Definition Classes
    H2OConf
  36. def cloudTimeout: Int

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

  38. def createH2OSchemaRDD[T <: Frame](fr: T)(implicit sqlContext: SQLContext): DataFrame

  39. def defaultCloudSize: Int

    Definition Classes
    H2OConf
  40. def disableGA: Boolean

    Definition Classes
    H2OConf
  41. def drddMulFactor: Int

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

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

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

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

    Definition Classes
    AnyRef → Any
  46. def getH2OClientArgs(ip: String): Array[String]

    Get arguments for H2O client.

    Get arguments for H2O client.

    returns

    array of H2O client arguments.

    Definition Classes
    H2OConf
  47. 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
  48. def h2oClientLogDir: String

    Definition Classes
    H2OConf
  49. def h2oClientLogLevel: String

    Definition Classes
    H2OConf
  50. def h2oLocalClient: String

  51. def h2oLocalClientIp: String

  52. def h2oLocalClientPort: Int

  53. def h2oNodeLogDir: String

    Definition Classes
    H2OConf
  54. def h2oNodeLogLevel: String

    Definition Classes
    H2OConf
  55. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  56. def hashLogin: Boolean

    Definition Classes
    H2OConf
  57. object implicits extends H2OContextImplicits with Serializable

    Define implicits available via h2oContext.

  58. def isClusterTopologyListenerEnabled: Boolean

    Definition Classes
    H2OConf
  59. def isFailOnUnsupportedSparkParamEnabled: Boolean

    Definition Classes
    H2OConf
  60. def isH2OReplEnabled: Boolean

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

    Definition Classes
    Any
  62. def isSparkVersionCheckEnabled: Boolean

    Definition Classes
    H2OConf
  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 kerberosLogin: Boolean

    Definition Classes
    H2OConf
  67. def ldapLogin: Boolean

    Definition Classes
    H2OConf
  68. def log: Logger

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

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

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  75. def logName: String

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

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

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

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

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

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

    Definition Classes
    AnyRef
  82. def nodeBasePort: Int

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

    Definition Classes
    H2OConf
  84. def nodeNetworkMask: Option[String]

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

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

    Definition Classes
    AnyRef
  87. def nthreads: Int

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

    Definition Classes
    H2OConf
  89. def numRddRetries: Int

    Definition Classes
    H2OConf
  90. def openFlow(): Unit

    Open H2O Flow running in this client.

  91. def scalaIntDefaultNum: Int

    Definition Classes
    H2OConf
  92. val sparkConf: SparkConf

    Definition Classes
    H2OContextH2OConf
  93. val sparkContext: SparkContext

  94. def start(): H2OContext

    Initialize Sparkling H2O and start H2O cloud.

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

    Stops H2O context.

    Stops H2O context.

    Calls System.exit() which kills executor JVM.

  96. def subseqTries: Int

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

    Definition Classes
    AnyRef
  98. def toH2OFrameKey(df: DataFrame, frameName: String): Key[Frame]

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

  100. def toH2OFrameKey(df: DataFrame): Key[Frame]

    Transform DataFrame to H2OFrame key

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

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

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

    Transforms RDD[Supported type] to H2OFrame key

  104. def toString(): String

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

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

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

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Deprecated Value Members

  1. def asSchemaRDD[T <: Frame](fr: T)(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