Class/Object

org.apache.spark.ml.odkl

LogisticRegressionLBFSG

Related Docs: object LogisticRegressionLBFSG | package odkl

Permalink

class LogisticRegressionLBFSG extends LinearRegressor[LogisticRegressionModel, LogisticRegressionLBFSG, LogisticRegressionLBFSG] with HasRegParam with HasTol with HasMaxIter with Optimizer with HasElasticNetParam with HasRegularizeLast with HasBatchSize

Linear Supertypes
HasBatchSize, HasRegularizeLast, HasElasticNetParam, Optimizer, HasMaxIter, HasTol, HasRegParam, LinearRegressor[LogisticRegressionModel, LogisticRegressionLBFSG, LogisticRegressionLBFSG], HasCacheTrainData, DefaultParamsWritable, MLWritable, LinearEstimator[LogisticRegressionModel, LogisticRegressionLBFSG], HasWeights, LinearModelParams, SummarizableEstimator[LogisticRegressionModel], Predictor[Vector, LogisticRegressionLBFSG, LogisticRegressionModel], PredictorParams, HasPredictionCol, HasFeaturesCol, HasLabelCol, Estimator[LogisticRegressionModel], PipelineStage, Logging, Params, Serializable, Serializable, Identifiable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. LogisticRegressionLBFSG
  2. HasBatchSize
  3. HasRegularizeLast
  4. HasElasticNetParam
  5. Optimizer
  6. HasMaxIter
  7. HasTol
  8. HasRegParam
  9. LinearRegressor
  10. HasCacheTrainData
  11. DefaultParamsWritable
  12. MLWritable
  13. LinearEstimator
  14. HasWeights
  15. LinearModelParams
  16. SummarizableEstimator
  17. Predictor
  18. PredictorParams
  19. HasPredictionCol
  20. HasFeaturesCol
  21. HasLabelCol
  22. Estimator
  23. PipelineStage
  24. Logging
  25. Params
  26. Serializable
  27. Serializable
  28. Identifiable
  29. AnyRef
  30. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new LogisticRegressionLBFSG()

    Permalink
  2. new LogisticRegressionLBFSG(uid: String)

    Permalink

Type Members

  1. case class LossInfo(name: String, value: Double) extends Product with Serializable

    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 batchSize: IntParam

    Permalink
    Definition Classes
    HasBatchSize
  7. final val cacheTrainData: BooleanParam

    Permalink
    Definition Classes
    HasCacheTrainData
  8. final def clear(param: Param[_]): LogisticRegressionLBFSG.this.type

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  12. def createModel(optimizer: LogisticRegressionLBFSG, coefficients: Vector, sqlContext: SQLContext, features: StructField): LogisticRegressionModel

    Permalink
    Attributes
    protected
    Definition Classes
    LogisticRegressionLBFSGLinearRegressor
  13. def createOptimizer(): LogisticRegressionLBFSG

    Permalink
    Attributes
    protected
    Definition Classes
    LogisticRegressionLBFSGLinearRegressor
  14. def createWeightsSummary(coefficients: Vector, sqlContext: SQLContext, features: StructField): DataFrame

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

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  16. final val elasticNetParam: DoubleParam

    Permalink
    Definition Classes
    HasElasticNetParam
  17. final def eq(arg0: AnyRef): Boolean

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

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

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

    Permalink
    Definition Classes
    Params
  21. def extractLabeledPoints(dataset: Dataset[_]): RDD[LabeledPoint]

    Permalink
    Attributes
    protected
    Definition Classes
    Predictor
  22. final def extractParamMap(): ParamMap

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

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

    Permalink
    Definition Classes
    HasFeaturesCol
  25. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  26. def fit(dataset: Dataset[_]): LogisticRegressionModel

    Permalink
    Definition Classes
    Predictor → Estimator
  27. def fit(dataset: Dataset[_], paramMaps: Array[ParamMap]): Seq[LogisticRegressionModel]

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

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

    Permalink
    Definition Classes
    Estimator
    Annotations
    @Since( "2.0.0" ) @varargs()
  30. final def get[T](param: Param[T]): Option[T]

    Permalink
    Definition Classes
    Params
  31. def getBatchSize: Int

    Permalink
    Definition Classes
    HasBatchSize
  32. final def getCacheTrainData: Boolean

    Permalink

    Definition Classes
    HasCacheTrainData
  33. final def getClass(): Class[_]

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

    Permalink
    Definition Classes
    Params
  35. final def getElasticNetParam: Double

    Permalink
    Definition Classes
    HasElasticNetParam
  36. final def getFeaturesCol: String

    Permalink
    Definition Classes
    HasFeaturesCol
  37. final def getLabelCol: String

    Permalink
    Definition Classes
    HasLabelCol
  38. final def getMaxIter: Int

    Permalink
    Definition Classes
    HasMaxIter
  39. final def getNumCorrections: Int

    Permalink
  40. final def getOrDefault[T](param: Param[T]): T

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

    Permalink
    Definition Classes
    Params
  42. final def getPredictionCol: String

    Permalink
    Definition Classes
    HasPredictionCol
  43. final def getRegParam: Double

    Permalink
    Definition Classes
    HasRegParam
  44. def getRegularizeLast: Boolean

    Permalink
    Definition Classes
    HasRegularizeLast
  45. final def getTol: Double

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

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  49. val index: String

    Permalink
    Definition Classes
    HasWeights
  50. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean

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

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

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

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

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

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

    Permalink
    Definition Classes
    HasLabelCol
  57. def log: Logger

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

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

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

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

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

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

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

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

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

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

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

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

    Permalink
    Definition Classes
    HasMaxIter
  70. val name: String

    Permalink
    Definition Classes
    HasWeights
  71. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  74. final val numCorrections: IntParam

    Permalink
  75. def optimize(data: RDD[(Double, Vector)], initialWeights: Vector): Vector

    Permalink
    Definition Classes
    LogisticRegressionLBFSG → Optimizer
  76. lazy val params: Array[Param[_]]

    Permalink
    Definition Classes
    Params
  77. final val preInitIntercept: BooleanParam

    Permalink
  78. final val predictionCol: Param[String]

    Permalink
    Definition Classes
    HasPredictionCol
  79. final val regParam: DoubleParam

    Permalink
    Definition Classes
    HasRegParam
  80. val regularizeLast: BooleanParam

    Permalink
    Definition Classes
    HasRegularizeLast
  81. def save(path: String): Unit

    Permalink
    Definition Classes
    MLWritable
    Annotations
    @Since( "1.6.0" ) @throws( ... )
  82. final def set(paramPair: ParamPair[_]): LogisticRegressionLBFSG.this.type

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

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

    Permalink
    Definition Classes
    Params
  85. def setBatchSize(value: Int): LogisticRegressionLBFSG.this.type

    Permalink
    Definition Classes
    HasBatchSize
  86. def setCacheTrainData(value: Boolean): LogisticRegressionLBFSG.this.type

    Permalink
    Definition Classes
    HasCacheTrainData
  87. final def setDefault(paramPairs: ParamPair[_]*): LogisticRegressionLBFSG.this.type

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

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  89. def setElasticNetParam(value: Double): LogisticRegressionLBFSG.this.type

    Permalink
  90. def setFeaturesCol(value: String): LogisticRegressionLBFSG

    Permalink
    Definition Classes
    Predictor
  91. def setLabelCol(value: String): LogisticRegressionLBFSG

    Permalink
    Definition Classes
    Predictor
  92. def setMaxIter(value: Int): LogisticRegressionLBFSG.this.type

    Permalink
  93. def setPreInitIntercept(value: Boolean): LogisticRegressionLBFSG.this.type

    Permalink
  94. def setPredictionCol(value: String): LogisticRegressionLBFSG

    Permalink
    Definition Classes
    Predictor
  95. def setRegParam(value: Double): LogisticRegressionLBFSG.this.type

    Permalink
  96. def setRegularizeLast(value: Boolean): LogisticRegressionLBFSG.this.type

    Permalink
    Definition Classes
    HasRegularizeLast
  97. def setTol(value: Double): LogisticRegressionLBFSG.this.type

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

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

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

    Permalink
    Definition Classes
    HasTol
  101. def train(dataset: Dataset[_]): LogisticRegressionModel

    Permalink
    Attributes
    protected
    Definition Classes
    LinearRegressor → Predictor
  102. def transformSchema(schema: StructType): StructType

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    PredictorParams
  106. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  109. val weight: String

    Permalink
    Definition Classes
    HasWeights
  110. val weights: Block

    Permalink
    Definition Classes
    HasWeights
  111. def write: MLWriter

    Permalink
    Definition Classes
    DefaultParamsWritable → MLWritable

Inherited from HasBatchSize

Inherited from HasRegularizeLast

Inherited from HasElasticNetParam

Inherited from Optimizer

Inherited from HasMaxIter

Inherited from HasTol

Inherited from HasRegParam

Inherited from HasCacheTrainData

Inherited from DefaultParamsWritable

Inherited from MLWritable

Inherited from HasWeights

Inherited from LinearModelParams

Inherited from Predictor[Vector, LogisticRegressionLBFSG, LogisticRegressionModel]

Inherited from PredictorParams

Inherited from HasPredictionCol

Inherited from HasFeaturesCol

Inherited from HasLabelCol

Inherited from Estimator[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

getParam

Ungrouped