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

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

    Implicit conversion from Frame to DataFrame

  10. def asH2OFrame(primitiveType: PrimitiveType, frameName: String): H2OFrame

  11. def asH2OFrame(primitiveType: PrimitiveType, frameName: Option[String]): H2OFrame

  12. implicit def asH2OFrame(primitiveType: PrimitiveType): H2OFrame

    Implicit conversion from RDD[Primitive type] ( where primitive type can be String, Double, Float or Int) to appropriate H2OFrame

  13. def asH2OFrame[A <: Product](rdd: RDD[A], frameName: String)(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A]): H2OFrame

  14. def asH2OFrame[A <: Product](rdd: RDD[A], frameName: Option[String])(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A]): H2OFrame

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

    Implicit conversion from typed RDD to H2O's DataFrame

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

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

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

    Implicit conversion from Spark DataFrame to H2O's DataFrame

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

    Conversion from RDD[Boolean] to H2O's DataFrame

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

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

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

    Conversion from RDD[Double] to H2O's DataFrame

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

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

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

    Conversion from RDD[Long] to H2O's DataFrame

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

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

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

    Conversion from RDD[String] to H2O's DataFrame

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

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

  27. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  28. 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

  29. def basePort: Int

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

    Definition Classes
    H2OConf
  31. def clientWebPort: Int

    Definition Classes
    H2OConf
  32. def clone(): AnyRef

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

    Definition Classes
    H2OConf
  34. def cloudTimeout: Int

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

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

  37. def defaultCloudSize: Int

    Definition Classes
    H2OConf
  38. def disableGA: Boolean

    Definition Classes
    H2OConf
  39. def drddMulFactor: Int

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

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

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

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

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

    Get arguments for H2O client.

    Get arguments for H2O client.

    returns

    array of H2O client arguments.

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

    Definition Classes
    H2OConf
  47. def h2oClientLogLevel: String

    Definition Classes
    H2OConf
  48. def h2oLocalClient: String

  49. def h2oLocalClientIp: String

  50. def h2oLocalClientPort: Int

  51. def h2oNodeLogDir: String

    Definition Classes
    H2OConf
  52. def h2oNodeLogLevel: String

    Definition Classes
    H2OConf
  53. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  54. def hashLogin: Boolean

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

    Definition Classes
    Any
  56. def isTraceEnabled(): Boolean

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

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

    Definition Classes
    H2OConf
  59. def ldapLogin: Boolean

    Definition Classes
    H2OConf
  60. def log: Logger

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

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

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  67. def logName: String

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

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

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

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

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

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

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

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

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

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

    Definition Classes
    AnyRef
  78. def nthreads: Int

    Definition Classes
    H2OConf
  79. def numH2OWorkers: Int

    Definition Classes
    H2OConf
  80. def numRddRetries: Int

    Definition Classes
    H2OConf
  81. def openFlow(): Unit

    Open H2O Flow running in this client.

  82. val sparkConf: SparkConf

    Definition Classes
    H2OContextH2OConf
  83. val sparkContext: SparkContext

  84. def start(): H2OContext

    Initialize Sparkling H2O and start H2O cloud.

  85. def start(h2oWorkers: Int): H2OContext

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

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

    Stops H2O context.

    Stops H2O context.

    Calls System.exit() which kills executor JVM.

  87. implicit def symbolToString(sy: Symbol): String

    Transform given Scala symbol to String

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

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

    Returns a key of given frame

  90. def toH2OFrameKey(primitiveType: PrimitiveType, frameName: String): Key[_]

  91. def toH2OFrameKey(primitiveType: PrimitiveType, frameName: Option[String]): Key[_]

  92. implicit def toH2OFrameKey(primitiveType: PrimitiveType): Key[_]

    Implicit conversion from RDD[Primitive type] ( where primitive type can be String, Boolean, Double, Float, Int, Long, Short or Byte ) to appropriate H2O's DataFrame

  93. def toH2OFrameKey[A <: Product](rdd: RDD[A], frameName: String)(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A]): Key[_]

  94. def toH2OFrameKey[A <: Product](rdd: RDD[A], frameName: Option[String])(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A]): Key[_]

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

    Implicit conversion from typed RDD to H2O's DataFrame

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

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

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

    Implicit conversion from Spark DataFrame to H2O's DataFrame

  99. def toString(): String

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

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

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  104. 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 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