class H2OContext extends AnyRef
- Self Type
- H2OContext
Linear Supertypes
Ordering
- Alphabetic
- By Inheritance
Inherited
- H2OContext
- AnyRef
- Any
- Hide All
- Show All
Visibility
- Public
- All
Value Members
-
final
def
!=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
final
def
##(): Int
- Definition Classes
- AnyRef → Any
-
final
def
==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- def asH2OFrame(fr: Frame): H2OFrame
- def asH2OFrame(s: String): H2OFrame
- def asH2OFrame(ds: SupportedDataset, frameName: Option[String]): H2OFrame
- def asH2OFrame(ds: SupportedDataset, frameName: String): H2OFrame
- def asH2OFrame(ds: SupportedDataset): H2OFrame
- def asH2OFrame(df: DataFrame, frameName: Option[String]): H2OFrame
- def asH2OFrame(df: DataFrame, frameName: String): H2OFrame
- def asH2OFrame(df: DataFrame): H2OFrame
- def asH2OFrame(rdd: SupportedRDD, frameName: Option[String]): H2OFrame
- def asH2OFrame(rdd: SupportedRDD, frameName: String): H2OFrame
- def asH2OFrame(rdd: SupportedRDD): H2OFrame
- def asH2OFrameKeyString(ds: SupportedDataset, frameName: Option[String]): String
- def asH2OFrameKeyString(ds: SupportedDataset, frameName: String): String
- def asH2OFrameKeyString(ds: SupportedDataset): String
- def asH2OFrameKeyString(df: DataFrame, frameName: Option[String]): String
- def asH2OFrameKeyString(df: DataFrame, frameName: String): String
- def asH2OFrameKeyString(df: DataFrame): String
- def asH2OFrameKeyString(rdd: SupportedRDD, frameName: Option[String]): String
- def asH2OFrameKeyString(rdd: SupportedRDD, frameName: String): String
- def asH2OFrameKeyString(rdd: SupportedRDD): String
-
final
def
asInstanceOf[T0]: T0
- Definition Classes
- Any
- def asRDD[A <: Product](fr: ai.h2o.sparkling.H2OFrame)(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A], arg1: ClassTag[A]): rdd.RDD[A]
- 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] }
- def asRDD[A <: Product](fr: H2OFrame)(implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[A], arg1: ClassTag[A]): RDD[A]
- def asSparkFrame(s: String): DataFrame
- def asSparkFrame(s: String, copyMetadata: Boolean): DataFrame
- def asSparkFrame(fr: ai.h2o.sparkling.H2OFrame): DataFrame
- def asSparkFrame[T <: Frame](fr: T, copyMetadata: Boolean = true): DataFrame
-
def
clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()
- def downloadH2OLogs(destinationDir: String, logContainer: String): String
-
final
def
eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
def
equals(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
-
def
finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( classOf[java.lang.Throwable] )
- def flowURL(): String
-
final
def
getClass(): Class[_]
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
- def getConf: H2OConf
- def getH2OLogLevel(): String
- def getH2ONodes(): Array[NodeDesc]
- def h2oLocalClient: String
- def h2oLocalClientIp: String
- def h2oLocalClientPort: Int
-
def
hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
- val hc: ai.h2o.sparkling.H2OContext
- def importHiveTable(database: String = HiveTableImporter.DEFAULT_DATABASE, table: String, partitions: Array[Array[String]] = null, allowMultiFormat: Boolean = false): H2OFrame
-
final
def
isInstanceOf[T0]: Boolean
- Definition Classes
- Any
-
final
def
ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
-
final
def
notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
-
final
def
notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
- def openFlow(): Unit
- def setH2OLogLevel(level: String): Unit
- val sparkContext: SparkContext
- val sparkSession: SparkSession
- def stop(stopSparkContext: Boolean = false): Unit
-
final
def
synchronized[T0](arg0: ⇒ T0): T0
- Definition Classes
- AnyRef
- def toH2OFrameKey(ds: SupportedDataset, frameName: String): Key[Frame]
- def toH2OFrameKey(ds: SupportedDataset, frameName: Option[String]): Key[Frame]
- def toH2OFrameKey(ds: SupportedDataset): Key[Frame]
- def toH2OFrameKey(df: DataFrame, frameName: Option[String]): Key[Frame]
- def toH2OFrameKey(df: DataFrame, frameName: String): Key[Frame]
- def toH2OFrameKey(df: DataFrame): Key[Frame]
- def toH2OFrameKey(rdd: SupportedRDD, frameName: Option[String]): Key[_]
- def toH2OFrameKey(rdd: SupportedRDD, frameName: String): Key[_]
- def toH2OFrameKey(rdd: SupportedRDD): Key[_]
-
def
toString(): String
- Definition Classes
- H2OContext → AnyRef → Any
-
final
def
wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... )
-
final
def
wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()
- object implicits extends H2OContextImplicits with Serializable