org.apache.spark.ml.odkl

MatrixLBFGS

class MatrixLBFGS extends Estimator[LinearCombinationModel[LogisticRegressionModel]] with SummarizableEstimator[LinearCombinationModel[LogisticRegressionModel]] with PredictorParams with HasTol with HasMaxIter with HasRegParam with HasRegularizeLast with HasBatchSize with HasNetlibBlas

Created by dmitriybugaichenko on 24.03.16.

Implementation for multi-class logistic regression training. In contrast to traditional notion of multi-class logistic regression this trainer produces one regression per each class. Internally treats all classes simultaneously using matrix-matrix multplication. Allows for L1-regularization (switches LBFGS to OWL-QN for that). Regularization strength is defined in terms of fraction of maximal feasible regularization (deduced using http://jmlr.org/papers/volume8/koh07a/koh07a.pdf).

Linear Supertypes
HasNetlibBlas, HasBatchSize, HasRegularizeLast, HasRegParam, HasMaxIter, HasTol, PredictorParams, HasPredictionCol, HasFeaturesCol, HasLabelCol, SummarizableEstimator[LinearCombinationModel[LogisticRegressionModel]], Estimator[LinearCombinationModel[LogisticRegressionModel]], PipelineStage, Logging, Params, Serializable, Serializable, Identifiable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. MatrixLBFGS
  2. HasNetlibBlas
  3. HasBatchSize
  4. HasRegularizeLast
  5. HasRegParam
  6. HasMaxIter
  7. HasTol
  8. PredictorParams
  9. HasPredictionCol
  10. HasFeaturesCol
  11. HasLabelCol
  12. SummarizableEstimator
  13. Estimator
  14. PipelineStage
  15. Logging
  16. Params
  17. Serializable
  18. Serializable
  19. Identifiable
  20. AnyRef
  21. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new MatrixLBFGS()

  2. new MatrixLBFGS(uid: String)

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 $[T](param: Param[T]): T

    Attributes
    protected
    Definition Classes
    Params
  5. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  6. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  7. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  8. def axpy(a: Double, x: Vector, y: Array[Double]): Unit

    Definition Classes
    HasNetlibBlas
  9. def axpy(a: Double, x: Array[Double], y: Array[Double]): Unit

    Definition Classes
    HasNetlibBlas
  10. val batchSize: Param[Int]

    Definition Classes
    HasBatchSize
  11. def blas: BLAS

    Definition Classes
    HasNetlibBlas
  12. final def clear(param: Param[_]): MatrixLBFGS.this.type

    Definition Classes
    Params
  13. def clone(): AnyRef

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

    Definition Classes
    MatrixLBFGSSummarizableEstimator → Estimator → PipelineStage → Params
  15. def copy(x: Array[Double], y: Array[Double]): Unit

    Definition Classes
    HasNetlibBlas
  16. def copyValues[T <: Params](to: T, extra: ParamMap): T

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

    Attributes
    protected
    Definition Classes
    Params
  18. def dscal(a: Double, data: Array[Double]): Unit

    Definition Classes
    HasNetlibBlas
  19. final def eq(arg0: AnyRef): Boolean

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

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

    Definition Classes
    Params
  22. def explainParams(): String

    Definition Classes
    Params
  23. final def extractParamMap(): ParamMap

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

    Definition Classes
    Params
  25. def f2jBLAS: BLAS

    Definition Classes
    HasNetlibBlas
  26. final val featuresCol: Param[String]

    Definition Classes
    HasFeaturesCol
  27. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  28. def fit(dataset: DataFrame): LinearCombinationModel[LogisticRegressionModel]

    Definition Classes
    MatrixLBFGS → Estimator
  29. def fit(dataset: DataFrame, paramMaps: Array[ParamMap]): Seq[LinearCombinationModel[LogisticRegressionModel]]

    Definition Classes
    Estimator
  30. def fit(dataset: DataFrame, paramMap: ParamMap): LinearCombinationModel[LogisticRegressionModel]

    Definition Classes
    Estimator
  31. def fit(dataset: DataFrame, firstParamPair: ParamPair[_], otherParamPairs: ParamPair[_]*): LinearCombinationModel[LogisticRegressionModel]

    Definition Classes
    Estimator
    Annotations
    @varargs()
  32. final def get[T](param: Param[T]): Option[T]

    Definition Classes
    Params
  33. def getBatchSize: Int

    Definition Classes
    HasBatchSize
  34. final def getClass(): Class[_]

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

    Definition Classes
    Params
  36. final def getFeaturesCol: String

    Definition Classes
    HasFeaturesCol
  37. final def getLabelCol: String

    Definition Classes
    HasLabelCol
  38. final def getMaxIter: Int

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

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

    Definition Classes
    Params
  41. final def getPredictionCol: String

    Definition Classes
    HasPredictionCol
  42. final def getRegParam: Double

    Definition Classes
    HasRegParam
  43. def getRegularizeLast: Boolean

    Definition Classes
    HasRegularizeLast
  44. final def getTol: Double

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

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

    Definition Classes
    Params
  47. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  48. final def isDefined(param: Param[_]): Boolean

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

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

    Definition Classes
    Params
  51. def isTraceEnabled(): Boolean

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

    Definition Classes
    HasLabelCol
  53. def log: Logger

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

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

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  60. def logName: String

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  65. final val maxIter: IntParam

    Definition Classes
    HasMaxIter
  66. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  67. final def notify(): Unit

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

    Definition Classes
    AnyRef
  69. val numCorrections: Param[Int]

  70. lazy val params: Array[Param[_]]

    Definition Classes
    Params
  71. val predictVector: Param[Boolean]

  72. final val predictionCol: Param[String]

    Definition Classes
    HasPredictionCol
  73. final val regParam: DoubleParam

    Definition Classes
    HasRegParam
  74. val regularizeLast: BooleanParam

    Definition Classes
    HasRegularizeLast
  75. final def set(paramPair: ParamPair[_]): MatrixLBFGS.this.type

    Attributes
    protected
    Definition Classes
    Params
  76. final def set(param: String, value: Any): MatrixLBFGS.this.type

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

    Definition Classes
    Params
  78. def setBatchSize(value: Int): MatrixLBFGS.this.type

    Definition Classes
    HasBatchSize
  79. final def setDefault(paramPairs: ParamPair[_]*): MatrixLBFGS.this.type

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

    Attributes
    protected
    Definition Classes
    Params
  81. def setPredictVector(value: Boolean): MatrixLBFGS.this.type

  82. def setRegParam(value: Double): MatrixLBFGS.this.type

  83. def setRegularizeLast(value: Boolean): MatrixLBFGS.this.type

    Definition Classes
    HasRegularizeLast
  84. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  85. def toString(): String

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

    Definition Classes
    HasTol
  87. def transformSchema(schema: StructType): StructType

    Definition Classes
    MatrixLBFGS → PipelineStage
    Annotations
    @DeveloperApi()
  88. def transformSchema(schema: StructType, logging: Boolean): StructType

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

    Definition Classes
    MatrixLBFGS → Identifiable
  90. def validateAndTransformSchema(schema: StructType, fitting: Boolean, featuresDataType: DataType): StructType

    Attributes
    protected
    Definition Classes
    PredictorParams
  91. def validateParams(): Unit

    Definition Classes
    Params
  92. final def wait(): Unit

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from HasNetlibBlas

Inherited from HasBatchSize

Inherited from HasRegularizeLast

Inherited from HasRegParam

Inherited from HasMaxIter

Inherited from HasTol

Inherited from PredictorParams

Inherited from HasPredictionCol

Inherited from HasFeaturesCol

Inherited from HasLabelCol

Inherited from Estimator[LinearCombinationModel[LogisticRegressionModel]]

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