Class

org.apache.spark.ml.odkl.hyperopt

StochasticHyperopt

Related Doc: package hyperopt

Permalink

class StochasticHyperopt[ModelIn <: ModelWithSummary[ModelIn]] extends ForkedEstimator[ModelIn, ConfigNumber, ModelIn] with HyperparametersOptimizer[ModelIn] with HasMaxIter with HasTol with HasSeed

Searches for optimal parameters using Bayesian approach. Important difference of this searcher compared to other forked estimators is the need to get previous evaluation to know where to sample next params.

Linear Supertypes
HasSeed, HasTol, HasMaxIter, HyperparametersOptimizer[ModelIn], HasConfigurations, MetricsExtractor, ForkedEstimator[ModelIn, ConfigNumber, ModelIn], HasNumThreads, ForkedModelParams, SummarizableEstimator[ModelIn], Estimator[ModelIn], PipelineStage, Logging, Params, Serializable, Serializable, Identifiable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. StochasticHyperopt
  2. HasSeed
  3. HasTol
  4. HasMaxIter
  5. HyperparametersOptimizer
  6. HasConfigurations
  7. MetricsExtractor
  8. ForkedEstimator
  9. HasNumThreads
  10. ForkedModelParams
  11. SummarizableEstimator
  12. Estimator
  13. PipelineStage
  14. Logging
  15. Params
  16. Serializable
  17. Serializable
  18. Identifiable
  19. AnyRef
  20. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new StochasticHyperopt(nested: SummarizableEstimator[ModelIn])

    Permalink
  2. new StochasticHyperopt(nested: SummarizableEstimator[ModelIn], uid: String)

    Permalink

Value Members

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

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def $[T](param: Param[T]): T

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  4. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. final def clear(param: Param[_]): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    Params
  7. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  8. val configurationIndexColumn: Param[String]

    Permalink
    Definition Classes
    HasConfigurations
  9. val configurations: Block

    Permalink
    Definition Classes
    HasConfigurations
  10. def copy(extra: ParamMap): StochasticHyperopt[ModelIn]

    Permalink
    Definition Classes
    StochasticHyperoptHyperparametersOptimizerSummarizableEstimator → Estimator → PipelineStage → Params
  11. def copyValues[T <: Params](to: T, extra: ParamMap): T

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  12. def createConfigDF(config: ParamMap): DataFrame

    Permalink
  13. def createConfigurationsBlock(sqlContext: SQLContext, failedModels: Seq[(ParamMap, Try[ModelIn])], rankedModels: Seq[(ParamMap, ModelIn, Double)]): DataFrame

    Permalink

    Create summary block with investigated configurations.

    Create summary block with investigated configurations.

    Attributes
    protected
    Definition Classes
    HyperparametersOptimizer
  14. def createForkSource(dataset: Dataset[_]): ForkSource[ModelIn, ConfigNumber, ModelIn]

    Permalink
    Attributes
    protected
    Definition Classes
    StochasticHyperoptForkedEstimator
  15. def createForks(dataset: Dataset[_]): Seq[(ConfigNumber, DataFrame)]

    Permalink

    Not used due to custom forks source

    Not used due to custom forks source

    Attributes
    protected
    Definition Classes
    StochasticHyperoptForkedEstimator
  16. final def defaultCopy[T <: Params](extra: ParamMap): T

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  17. def diveToReproContext(partialData: (ConfigNumber, DataFrame), estimator: SummarizableEstimator[ModelIn]): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    StochasticHyperoptForkedEstimator
  18. final val enableDive: BooleanParam

    Permalink
    Definition Classes
    ForkedEstimator
  19. val epsilonGreedy: DoubleParam

    Permalink
  20. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  22. val errorColumn: Param[String]

    Permalink
    Definition Classes
    HasConfigurations
  23. def explainParam(param: Param[_]): String

    Permalink
    Definition Classes
    Params
  24. def explainParams(): String

    Permalink
    Definition Classes
    Params
  25. final def extract(model: ModelWithSummary[_]): Option[DataFrame]

    Permalink
    Definition Classes
    MetricsExtractor
  26. def extractBestModel(sqlContext: SQLContext, failedModels: Seq[(ParamMap, Try[ModelIn])], rankedModels: Seq[(ParamMap, ModelIn, Double)]): ModelIn

    Permalink

    Given all the history of the optimization create the resulting model with the configurations summary block.

    Given all the history of the optimization create the resulting model with the configurations summary block.

    Attributes
    protected
    Definition Classes
    HyperparametersOptimizer
  27. def extractConfig(row: Row): (Double, ParamMap)

    Permalink

    Extract model configuration from the configurations data frame row.

    Extract model configuration from the configurations data frame row.

    Attributes
    protected
    Definition Classes
    StochasticHyperoptHyperparametersOptimizer
  28. def extractConfig(model: ModelIn): (Double, ParamMap)

    Permalink
    Definition Classes
    HyperparametersOptimizer
  29. val extractExpression: Param[String]

    Permalink
    Definition Classes
    MetricsExtractor
  30. def extractImpl(model: ModelWithSummary[_]): Option[DataFrame]

    Permalink
    Attributes
    protected
    Definition Classes
    HasConfigurationsMetricsExtractor
  31. final def extractParamMap(): ParamMap

    Permalink
    Definition Classes
    Params
  32. final def extractParamMap(extra: ParamMap): ParamMap

    Permalink
    Definition Classes
    Params
  33. def extractParamsAndQuality(params: ParamMap, model: ModelIn): (ParamMap, ModelIn, Double)

    Permalink

    Extracts information of the resulting metrics from the trained model.

    Extracts information of the resulting metrics from the trained model.

    Attributes
    protected
    Definition Classes
    HyperparametersOptimizer
  34. def failFast(key: ConfigNumber, triedIn: Try[ModelIn]): Try[ModelIn]

    Permalink
    Attributes
    protected
    Definition Classes
    StochasticHyperoptForkedEstimator
  35. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  36. def finilizeReproContext: ReproContext

    Permalink
    Attributes
    protected
    Definition Classes
    ForkedEstimator
  37. def fit(dataset: Dataset[_]): ModelIn

    Permalink
    Definition Classes
    StochasticHyperoptForkedEstimator → Estimator
  38. def fit(dataset: Dataset[_], paramMaps: Array[ParamMap]): Seq[ModelIn]

    Permalink
    Definition Classes
    Estimator
    Annotations
    @Since( "2.0.0" )
  39. def fit(dataset: Dataset[_], paramMap: ParamMap): ModelIn

    Permalink
    Definition Classes
    Estimator
    Annotations
    @Since( "2.0.0" )
  40. def fit(dataset: Dataset[_], firstParamPair: ParamPair[_], otherParamPairs: ParamPair[_]*): ModelIn

    Permalink
    Definition Classes
    Estimator
    Annotations
    @Since( "2.0.0" ) @varargs()
  41. def fitFork(estimator: SummarizableEstimator[ModelIn], wholeData: Dataset[_], partialData: (ConfigNumber, DataFrame)): (ConfigNumber, Try[ModelIn])

    Permalink
    Definition Classes
    StochasticHyperoptForkedEstimator
  42. final def get[T](param: Param[T]): Option[T]

    Permalink
    Definition Classes
    Params
  43. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  44. def getConfigurationIndexColumn: String

    Permalink
    Definition Classes
    HasConfigurations
  45. def getCurrentContext: Seq[String]

    Permalink
    Attributes
    protected
    Definition Classes
    ForkedEstimator
  46. final def getDefault[T](param: Param[T]): Option[T]

    Permalink
    Definition Classes
    Params
  47. def getErrorColumn: String

    Permalink
    Definition Classes
    HasConfigurations
  48. def getForkTags(partialData: (ConfigNumber, DataFrame)): Seq[(String, String)]

    Permalink
    Attributes
    protected
    Definition Classes
    StochasticHyperoptForkedEstimator
  49. final def getMaxIter: Int

    Permalink
    Definition Classes
    HasMaxIter
  50. def getMetricsBlock: String

    Permalink
    Definition Classes
    HyperparametersOptimizer
  51. def getMetricsExpression: String

    Permalink
    Definition Classes
    HyperparametersOptimizer
  52. final def getOrDefault[T](param: Param[T]): T

    Permalink
    Definition Classes
    Params
  53. def getParam(paramName: String): Param[Any]

    Permalink
    Definition Classes
    Params
  54. def getResultingMetricColumn: String

    Permalink
    Definition Classes
    HasConfigurations
  55. final def getSeed: Long

    Permalink
    Definition Classes
    HasSeed
  56. final def getTol: Double

    Permalink
    Definition Classes
    HasTol
  57. final def hasDefault[T](param: Param[T]): Boolean

    Permalink
    Definition Classes
    Params
  58. def hasParam(paramName: String): Boolean

    Permalink
    Definition Classes
    Params
  59. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  60. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  61. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  62. final def isDefined(param: Param[_]): Boolean

    Permalink
    Definition Classes
    Params
  63. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  64. final def isSet(param: Param[_]): Boolean

    Permalink
    Definition Classes
    Params
  65. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  66. def log: Logger

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  73. def logMetricsToReproContext(model: ModelIn): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    ForkedEstimator
  74. def logName: String

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  79. final val maxIter: IntParam

    Permalink
    Definition Classes
    HasMaxIter
  80. val maxNoImproveIters: IntParam

    Permalink
  81. def mayBePropagateKey(data: DataFrame, key: Any): DataFrame

    Permalink
    Attributes
    protected
    Definition Classes
    ForkedModelParams
  82. def mergeModels(sqlContext: SQLContext, models: Seq[(ConfigNumber, Try[ModelIn])]): ModelIn

    Permalink

    Not used due to custom forks source

    Not used due to custom forks source

    Attributes
    protected
    Definition Classes
    StochasticHyperoptForkedEstimator
  83. val metricsBlock: Param[String]

    Permalink
    Definition Classes
    HyperparametersOptimizer
  84. val metricsExpression: Param[String]

    Permalink
    Definition Classes
    HyperparametersOptimizer
  85. val nanReplacement: DoubleParam

    Permalink
  86. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  87. val nested: SummarizableEstimator[ModelIn]

    Permalink

    Nested estimator to call for each fork.

    Nested estimator to call for each fork.

    Definition Classes
    ForkedEstimator
  88. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  89. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  90. final val numThreads: IntParam

    Permalink
    Definition Classes
    HasNumThreads
  91. final val overwriteModels: BooleanParam

    Permalink
    Definition Classes
    ForkedEstimator
  92. val paramDomains: Param[Array[ParamDomainPair[_]]]

    Permalink
  93. val paramNames: Param[Map[Param[_], String]]

    Permalink
    Definition Classes
    HyperparametersOptimizer
  94. lazy val params: Array[Param[_]]

    Permalink
    Definition Classes
    Params
  95. final val pathForTempModels: Param[String]

    Permalink
    Definition Classes
    ForkedEstimator
  96. final val persistingKeyColumns: StringArrayParam

    Permalink
    Definition Classes
    ForkedEstimator
  97. val priorsContextFilter: Param[String]

    Permalink
  98. val priorsPath: Param[String]

    Permalink
  99. val priorsToSample: IntParam

    Permalink
  100. final val propagatedKeyColumn: Param[String]

    Permalink
    Definition Classes
    ForkedModelParams
  101. def resolveParamName(param: Param[_]): String

    Permalink
    Definition Classes
    HyperparametersOptimizer
  102. val resultingMetricColumn: Param[String]

    Permalink
    Definition Classes
    HasConfigurations
  103. val searchMode: Param[BayesianParamOptimizerFactory]

    Permalink
  104. final val seed: LongParam

    Permalink
    Definition Classes
    HasSeed
  105. final def set(paramPair: ParamPair[_]): StochasticHyperopt.this.type

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  106. final def set(param: String, value: Any): StochasticHyperopt.this.type

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  107. final def set[T](param: Param[T], value: T): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    Params
  108. def setConfigurationIndexColumn(value: String): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    HasConfigurations
  109. final def setDefault(paramPairs: ParamPair[_]*): StochasticHyperopt.this.type

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  110. final def setDefault[T](param: Param[T], value: T): StochasticHyperopt.this.type

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  111. def setEnableDive(value: Boolean): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    ForkedEstimator
  112. def setEpsilonGreedy(value: Double): StochasticHyperopt.this.type

    Permalink
  113. def setErrorColumn(value: String): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    HasConfigurations
  114. def setExtractExpression(value: String): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    MetricsExtractor
  115. def setMaxIter(iters: Int): StochasticHyperopt.this.type

    Permalink
  116. def setMaxNoImproveIters(value: Int): StochasticHyperopt.this.type

    Permalink
  117. def setMetricsBlock(value: String): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    HyperparametersOptimizer
  118. def setMetricsExpression(value: String): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    HyperparametersOptimizer
  119. def setNanReplacement(value: Double): StochasticHyperopt.this.type

    Permalink
  120. def setNumThreads(value: Int): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    HasNumThreads
  121. def setOverwriteModels(value: Boolean): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    ForkedEstimator
  122. def setParamDomains(pairs: ParamDomainPair[_]*): StochasticHyperopt.this.type

    Permalink
  123. def setParamNames(value: (Param[_], String)*): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    HyperparametersOptimizer
  124. def setPathForTempModels(value: String): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    ForkedEstimator
  125. def setPriorsContextFilter(value: String): StochasticHyperopt.this.type

    Permalink
  126. def setPriorsPath(value: String): StochasticHyperopt.this.type

    Permalink
  127. def setPriorsToSample(value: Int): StochasticHyperopt.this.type

    Permalink
  128. def setPropagatedKeyColumn(value: String): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    ForkedModelParams
  129. def setResultingMetricColumn(value: String): StochasticHyperopt.this.type

    Permalink
    Definition Classes
    HasConfigurations
  130. def setSearchMode(value: BayesianParamOptimizerFactory): StochasticHyperopt.this.type

    Permalink
  131. def setSeed(value: Long): StochasticHyperopt.this.type

    Permalink
  132. def setTol(value: Double): StochasticHyperopt.this.type

    Permalink
  133. def setTopKForTolerance(value: Int): StochasticHyperopt.this.type

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

    Permalink
    Definition Classes
    AnyRef
  135. def toString(): String

    Permalink
    Definition Classes
    Identifiable → AnyRef → Any
  136. final val tol: DoubleParam

    Permalink
    Definition Classes
    HasTol
  137. val topKForTolerance: IntParam

    Permalink
  138. def transformSchema(schema: StructType): StructType

    Permalink
    Definition Classes
    ForkedEstimator → PipelineStage
    Annotations
    @DeveloperApi()
  139. def transformSchema(schema: StructType, logging: Boolean): StructType

    Permalink
    Attributes
    protected
    Definition Classes
    PipelineStage
    Annotations
    @DeveloperApi()
  140. val uid: String

    Permalink
    Definition Classes
    StochasticHyperoptForkedEstimator → Identifiable
  141. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from HasSeed

Inherited from HasTol

Inherited from HasMaxIter

Inherited from HyperparametersOptimizer[ModelIn]

Inherited from HasConfigurations

Inherited from MetricsExtractor

Inherited from ForkedEstimator[ModelIn, ConfigNumber, ModelIn]

Inherited from HasNumThreads

Inherited from ForkedModelParams

Inherited from SummarizableEstimator[ModelIn]

Inherited from Estimator[ModelIn]

Inherited from PipelineStage

Inherited from Logging

Inherited from Params

Inherited from Serializable

Inherited from Serializable

Inherited from Identifiable

Inherited from AnyRef

Inherited from Any

Ungrouped