package h2o
Type shortcuts to simplify work in Sparkling REPL
- Alphabetic
- By Inheritance
- h2o
- Logging
- Serializable
- Serializable
- Logging
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
Type Members
-  trait CrossSparkUtils extends AnyRef
-  type Dataset[X] = sql.Dataset[X]
- 
      
      
      
        
      
    
      
        
        class
      
      
        DefaultSource extends RelationProvider with SchemaRelationProvider with CreatableRelationProvider with DataSourceRegister
      
      
      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). 
-  type Frame = water.fvec.Frame
-  type H2O = water.H2O
- 
      
      
      
        
      
    
      
        
        class
      
      
        H2OConf extends Logging with InternalBackendConf with ExternalBackendConf with Serializable
      
      
      Configuration holder which is representing properties passed from user to Sparkling Water. 
- 
      
      
      
        
      
    
      
        
        class
      
      
        H2OContext extends H2OContextExtensions
      
      
      Create new H2OContext based on provided H2O configuration 
- 
      
      
      
        
      
    
      
        implicit 
        class
      
      
        H2ODataFrameReader extends AnyRef
      
      
      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()
- 
      
      
      
        
      
    
      
        implicit 
        class
      
      
        H2ODataFrameWriter[T] extends AnyRef
      
      
      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()
-  type H2OFrame = water.fvec.H2OFrame
- 
      
      
      
        
      
    
      
        
        class
      
      
        JavaH2OContext extends AnyRef
      
      
      A Java-friendly version of org.apache.spark.h2o.H2OContext A Java-friendly version of org.apache.spark.h2o.H2OContext Sparkling Water can run in two modes. External cluster mode and internal cluster mode. When using external cluster mode, it tries to connect to existing H2O cluster using the provided spark configuration properties. In the case of internal cluster mode,it creates H2O cluster living in Spark - that means that each Spark executor will have one h2o instance running in it. This mode is not recommended for big clusters and clusters where Spark executors are not stable. Cluster mode can be set using the spark configuration property spark.ext.h2o.mode which can be set in script starting sparkling-water or can be set in H2O configuration class H2OConf 
-  type RDD[X] = rdd.RDD[X]
-  class WrongSparkVersion extends Exception with NoStackTrace
Abstract Value Members
- 
      
      
      
        
      
    
      
        abstract 
        def
      
      
        getClass(): Class[_]
      
      
      - Definition Classes
- Any
 
Concrete Value Members
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        !=(arg0: Any): Boolean
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        ##(): Int
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        ==(arg0: Any): Boolean
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        asInstanceOf[T0]: T0
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        equals(arg0: Any): Boolean
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        hashCode(): Int
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        initializeLogIfNecessary(isInterpreter: Boolean): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        isInstanceOf[T0]: Boolean
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        isTraceEnabled(): Boolean
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        log: Logger
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logDebug(msg: ⇒ String, throwable: Throwable): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logDebug(msg: ⇒ String): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logError(msg: ⇒ String, throwable: Throwable): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logError(msg: ⇒ String): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logInfo(msg: ⇒ String, throwable: Throwable): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logInfo(msg: ⇒ String): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logName: String
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logTrace(msg: ⇒ String, throwable: Throwable): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logTrace(msg: ⇒ String): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logWarning(msg: ⇒ String, throwable: Throwable): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        logWarning(msg: ⇒ String): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        toString(): String
      
      
      - Definition Classes
- Any
 
-  object H2OConf extends Logging with Serializable
-  object H2OContext extends Logging with Serializable
-  object SparkSpecificUtils extends CrossSparkUtils