Class/Object

org.apache.spark.ml.classification

BoostingClassificationModel

Related Docs: object BoostingClassificationModel | package classification

Permalink

class BoostingClassificationModel extends ClassificationModel[Vector, BoostingClassificationModel] with BoostingClassifierParams with MLWritable

Linear Supertypes
MLWritable, BoostingClassifierParams, BoostingParams, HasLearningRate, HasBaseLearner, HasSeed, HasWeightCol, HasMaxIter, ClassificationModel[Vector, BoostingClassificationModel], ClassifierParams, HasRawPredictionCol, PredictionModel[Vector, BoostingClassificationModel], PredictorParams, HasPredictionCol, HasFeaturesCol, HasLabelCol, Model[BoostingClassificationModel], Transformer, PipelineStage, Logging, Params, Serializable, Serializable, Identifiable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. BoostingClassificationModel
  2. MLWritable
  3. BoostingClassifierParams
  4. BoostingParams
  5. HasLearningRate
  6. HasBaseLearner
  7. HasSeed
  8. HasWeightCol
  9. HasMaxIter
  10. ClassificationModel
  11. ClassifierParams
  12. HasRawPredictionCol
  13. PredictionModel
  14. PredictorParams
  15. HasPredictionCol
  16. HasFeaturesCol
  17. HasLabelCol
  18. Model
  19. Transformer
  20. PipelineStage
  21. Logging
  22. Params
  23. Serializable
  24. Serializable
  25. Identifiable
  26. AnyRef
  27. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new BoostingClassificationModel(numClasses: Int, tuples: Array[(Double, EnsemblePredictionModelType)])

    Permalink
  2. new BoostingClassificationModel(numClasses: Int, weights: Array[Double], models: Array[EnsemblePredictionModelType])

    Permalink
  3. new BoostingClassificationModel(uid: String, numClasses: Int, weights: Array[Double], models: Array[EnsemblePredictionModelType])

    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. val baseLearner: Param[EnsemblePredictorType]

    Permalink

    param for the estimator that will be used by the ensemble learner as a base learner

    param for the estimator that will be used by the ensemble learner as a base learner

    Definition Classes
    HasBaseLearner
  7. final def clear(param: Param[_]): BoostingClassificationModel.this.type

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

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  9. def copy(extra: ParamMap): BoostingClassificationModel

    Permalink
    Definition Classes
    BoostingClassificationModel → Model → Transformer → PipelineStage → Params
  10. def copyValues[T <: Params](to: T, extra: ParamMap): T

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

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  12. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  14. def explainParam(param: Param[_]): String

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

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

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

    Permalink
    Definition Classes
    Params
  18. final val featuresCol: Param[String]

    Permalink
    Definition Classes
    HasFeaturesCol
  19. def featuresDataType: DataType

    Permalink
    Attributes
    protected
    Definition Classes
    PredictionModel
  20. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  21. final def get[T](param: Param[T]): Option[T]

    Permalink
    Definition Classes
    Params
  22. def getBaseLearner: EnsemblePredictorType

    Permalink

    Definition Classes
    HasBaseLearner
  23. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  24. final def getDefault[T](param: Param[T]): Option[T]

    Permalink
    Definition Classes
    Params
  25. final def getFeaturesCol: String

    Permalink
    Definition Classes
    HasFeaturesCol
  26. final def getLabelCol: String

    Permalink
    Definition Classes
    HasLabelCol
  27. def getLearningRate: Double

    Permalink

    Definition Classes
    HasLearningRate
  28. def getLoss: String

    Permalink

    Definition Classes
    BoostingClassifierParams
  29. final def getMaxIter: Int

    Permalink
    Definition Classes
    HasMaxIter
  30. final def getOrDefault[T](param: Param[T]): T

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

    Permalink
    Definition Classes
    Params
  32. final def getPredictionCol: String

    Permalink
    Definition Classes
    HasPredictionCol
  33. final def getRawPredictionCol: String

    Permalink
    Definition Classes
    HasRawPredictionCol
  34. final def getSeed: Long

    Permalink
    Definition Classes
    HasSeed
  35. final def getWeightCol: String

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

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

    Permalink
    Definition Classes
    Params
  38. def hasParent: Boolean

    Permalink
    Definition Classes
    Model
  39. def hashCode(): Int

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  46. final val labelCol: Param[String]

    Permalink
    Definition Classes
    HasLabelCol
  47. val learningRate: Param[Double]

    Permalink

    param for the learning rate of the algorithm

    param for the learning rate of the algorithm

    Definition Classes
    HasLearningRate
  48. def log: Logger

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  55. def logName: String

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  60. val loss: Param[String]

    Permalink

    Loss function which Boosting tries to minimize.

    Loss function which Boosting tries to minimize. (case-insensitive) Supported: "exponential" (default = exponential)

    Definition Classes
    BoostingClassifierParams
  61. final val maxIter: IntParam

    Permalink
    Definition Classes
    HasMaxIter
  62. val models: Array[EnsemblePredictionModelType]

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

    Permalink
    Definition Classes
    AnyRef
  64. final def notify(): Unit

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

    Permalink
    Definition Classes
    AnyRef
  66. val numClasses: Int

    Permalink
    Definition Classes
    BoostingClassificationModel → ClassificationModel
  67. def numFeatures: Int

    Permalink
    Definition Classes
    PredictionModel
    Annotations
    @Since( "1.6.0" )
  68. lazy val params: Array[Param[_]]

    Permalink
    Definition Classes
    Params
  69. var parent: Estimator[BoostingClassificationModel]

    Permalink
    Definition Classes
    Model
  70. def predict(features: Vector): Double

    Permalink
    Definition Classes
    ClassificationModel → PredictionModel
  71. def predictRaw(features: Vector): Vector

    Permalink
    Attributes
    protected
    Definition Classes
    BoostingClassificationModel → ClassificationModel
  72. final val predictionCol: Param[String]

    Permalink
    Definition Classes
    HasPredictionCol
  73. def raw2prediction(rawPrediction: Vector): Double

    Permalink
    Attributes
    protected
    Definition Classes
    ClassificationModel
  74. final val rawPredictionCol: Param[String]

    Permalink
    Definition Classes
    HasRawPredictionCol
  75. def save(path: String): Unit

    Permalink
    Definition Classes
    MLWritable
    Annotations
    @Since( "1.6.0" ) @throws( ... )
  76. final val seed: LongParam

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

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

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

    Permalink
    Definition Classes
    Params
  80. final def setDefault(paramPairs: ParamPair[_]*): BoostingClassificationModel.this.type

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

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  82. def setFeaturesCol(value: String): BoostingClassificationModel

    Permalink
    Definition Classes
    PredictionModel
  83. def setParent(parent: Estimator[BoostingClassificationModel]): BoostingClassificationModel

    Permalink
    Definition Classes
    Model
  84. def setPredictionCol(value: String): BoostingClassificationModel

    Permalink
    Definition Classes
    PredictionModel
  85. def setRawPredictionCol(value: String): BoostingClassificationModel

    Permalink
    Definition Classes
    ClassificationModel
  86. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink
    Definition Classes
    Identifiable → AnyRef → Any
  88. def transform(dataset: Dataset[_]): DataFrame

    Permalink
    Definition Classes
    ClassificationModel → PredictionModel → Transformer
  89. def transform(dataset: Dataset[_], paramMap: ParamMap): DataFrame

    Permalink
    Definition Classes
    Transformer
    Annotations
    @Since( "2.0.0" )
  90. def transform(dataset: Dataset[_], firstParamPair: ParamPair[_], otherParamPairs: ParamPair[_]*): DataFrame

    Permalink
    Definition Classes
    Transformer
    Annotations
    @Since( "2.0.0" ) @varargs()
  91. def transformImpl(dataset: Dataset[_]): DataFrame

    Permalink
    Attributes
    protected
    Definition Classes
    PredictionModel
  92. def transformSchema(schema: StructType): StructType

    Permalink
    Definition Classes
    PredictionModel → PipelineStage
  93. def transformSchema(schema: StructType, logging: Boolean): StructType

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

    Permalink
    Definition Classes
    BoostingClassificationModel → Identifiable
  95. def validateAndTransformSchema(schema: StructType, fitting: Boolean, featuresDataType: DataType): StructType

    Permalink
    Attributes
    protected
    Definition Classes
    ClassifierParams → PredictorParams
  96. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  99. final val weightCol: Param[String]

    Permalink
    Definition Classes
    HasWeightCol
  100. val weights: Array[Double]

    Permalink
  101. def write: MLWriter

    Permalink
    Definition Classes
    BoostingClassificationModel → MLWritable

Inherited from MLWritable

Inherited from BoostingClassifierParams

Inherited from BoostingParams

Inherited from HasLearningRate

Inherited from HasBaseLearner

Inherited from HasSeed

Inherited from HasWeightCol

Inherited from HasMaxIter

Inherited from ClassificationModel[Vector, BoostingClassificationModel]

Inherited from ClassifierParams

Inherited from HasRawPredictionCol

Inherited from PredictionModel[Vector, BoostingClassificationModel]

Inherited from PredictorParams

Inherited from HasPredictionCol

Inherited from HasFeaturesCol

Inherited from HasLabelCol

Inherited from Model[BoostingClassificationModel]

Inherited from Transformer

Inherited from PipelineStage

Inherited from Logging

Inherited from Params

Inherited from Serializable

Inherited from Serializable

Inherited from Identifiable

Inherited from AnyRef

Inherited from Any

getParam

param

Ungrouped