org.apache.spark.ml

DLClassifierModel

class DLClassifierModel[T] extends DLModel[T]

DLClassifierModel is a specialized DLModel for classification tasks. The prediction column will have the datatype of Double.

Linear Supertypes
DLModel[T], DLParams[T], HasBatchSize, VectorCompatibility, HasPredictionCol, HasFeaturesCol, DLTransformerBase[DLModel[T]], Model[DLModel[T]], Transformer, PipelineStage, Logging, Params, Serializable, Serializable, Identifiable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. DLClassifierModel
  2. DLModel
  3. DLParams
  4. HasBatchSize
  5. VectorCompatibility
  6. HasPredictionCol
  7. HasFeaturesCol
  8. DLTransformerBase
  9. Model
  10. Transformer
  11. PipelineStage
  12. Logging
  13. Params
  14. Serializable
  15. Serializable
  16. Identifiable
  17. AnyRef
  18. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new DLClassifierModel(model: Module[T], featureSize: Array[Int], uid: String = "DLClassifierModel")(implicit arg0: ClassTag[T], ev: TensorNumeric[T])

    model

    BigDL module to be optimized

    featureSize

    The size (Tensor dimensions) of the feature data.

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. final val batchSize: Param[Int]

    Definition Classes
    HasBatchSize
  9. final def clear(param: Param[_]): DLClassifierModel.this.type

    Attributes
    protected
    Definition Classes
    Params
  10. def clone(): AnyRef

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

    Definition Classes
    DLModel → DLTransformerBase → Model → Transformer → PipelineStage → Params
  12. def copyValues[T <: Params](to: T, extra: ParamMap): T

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

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

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

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

    Definition Classes
    Params
  17. def explainParams(): String

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

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

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

    Definition Classes
    HasFeaturesCol
  21. def finalize(): Unit

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

    Definition Classes
    Params
  23. def getBatchSize: Int

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

    Definition Classes
    AnyRef → Any
  25. def getConvertFunc(colType: DataType): (Row, Int) ⇒ Seq[AnyVal]

    Get conversion function to extract data from original DataFrame Default: 0

    Get conversion function to extract data from original DataFrame Default: 0

    Attributes
    protected
    Definition Classes
    DLParams
  26. final def getDefault[T](param: Param[T]): Option[T]

    Definition Classes
    Params
  27. def getFeatureSize: Array[Int]

    Definition Classes
    DLModel
  28. final def getFeaturesCol: String

    Definition Classes
    HasFeaturesCol
  29. def getLearningRate: Double

    Definition Classes
    DLParams
  30. def getLearningRateDecay: Double

    Definition Classes
    DLParams
  31. def getMaxEpoch: Int

    Definition Classes
    DLParams
  32. def getOptimMethod: OptimMethod[T]

    Definition Classes
    DLParams
  33. final def getOrDefault[T](param: Param[T]): T

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

    Definition Classes
    Params
  35. final def getPredictionCol: String

    Definition Classes
    HasPredictionCol
  36. def getVectorSeq(row: Row, colType: DataType, index: Int): Seq[AnyVal]

    Definition Classes
    VectorCompatibility
  37. final def hasDefault[T](param: Param[T]): Boolean

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

    Definition Classes
    Params
  39. def hasParent: Boolean

    Definition Classes
    Model
  40. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  41. def internalTransform(dataFrame: DataFrame): DataFrame

    Perform a prediction on featureCol, and write result to the predictionCol.

    Perform a prediction on featureCol, and write result to the predictionCol.

    Attributes
    protected
    Definition Classes
    DLModel → DLTransformerBase
  42. final def isDefined(param: Param[_]): Boolean

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

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

    Definition Classes
    Params
  45. def isTraceEnabled(): Boolean

    Attributes
    protected
    Definition Classes
    Logging
  46. final val learningRate: DoubleParam

    learning rate for the optimizer in the DLEstimator.

    learning rate for the optimizer in the DLEstimator. Default: 0.001

    Definition Classes
    DLParams
  47. final val learningRateDecay: DoubleParam

    learning rate decay for each iteration.

    learning rate decay for each iteration. Default: 0

    Definition Classes
    DLParams
  48. def log: Logger

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

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

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  55. def logName: String

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  60. final val maxEpoch: IntParam

    number of max Epoch for the training, an epoch refers to a traverse over the training data Default: 100

    number of max Epoch for the training, an epoch refers to a traverse over the training data Default: 100

    Definition Classes
    DLParams
  61. val model: Module[T]

    BigDL module to be optimized

    BigDL module to be optimized

    Definition Classes
    DLClassifierModelDLModel
  62. final def ne(arg0: AnyRef): Boolean

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

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

    Definition Classes
    AnyRef
  65. final val optimMethod: Param[OptimMethod[T]]

    optimization method to be used.

    optimization method to be used. BigDL supports many optimization methods like Adam, SGD and LBFGS. Refer to package com.intel.analytics.bigdl.optim for all the options. Default: SGD

    Definition Classes
    DLParams
  66. def outputToPrediction(output: Tensor[T]): Any

    Attributes
    protected
    Definition Classes
    DLClassifierModelDLModel
  67. lazy val params: Array[Param[_]]

    Definition Classes
    Params
  68. var parent: Estimator[DLModel[T]]

    Definition Classes
    Model
  69. final val predictionCol: Param[String]

    Definition Classes
    HasPredictionCol
  70. final def set(paramPair: ParamPair[_]): DLClassifierModel.this.type

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

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

    Attributes
    protected
    Definition Classes
    Params
  73. def setBatchSize(value: Int): DLClassifierModel.this.type

    Definition Classes
    DLModel
  74. final def setDefault(paramPairs: ParamPair[_]*): DLClassifierModel.this.type

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

    Attributes
    protected
    Definition Classes
    Params
  76. def setFeatureSize(value: Array[Int]): DLClassifierModel.this.type

    Definition Classes
    DLModel
  77. def setFeaturesCol(featuresColName: String): DLClassifierModel.this.type

    Definition Classes
    DLModel
  78. def setParent(parent: Estimator[DLModel[T]]): DLModel[T]

    Definition Classes
    Model
  79. def setPredictionCol(value: String): DLClassifierModel.this.type

    Definition Classes
    DLModel
  80. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  81. def toString(): String

    Definition Classes
    Identifiable → AnyRef → Any
  82. def transform(dataFrame: DataFrame): DataFrame

    Definition Classes
    DLTransformerBase → Transformer
  83. def transform(dataset: DataFrame, paramMap: ParamMap): DataFrame

    Definition Classes
    Transformer
  84. def transform(dataset: DataFrame, firstParamPair: ParamPair[_], otherParamPairs: ParamPair[_]*): DataFrame

    Definition Classes
    Transformer
    Annotations
    @varargs()
  85. def transformSchema(schema: StructType): StructType

    Definition Classes
    DLClassifierModelDLModel → PipelineStage
  86. def transformSchema(schema: StructType, logging: Boolean): StructType

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

    Definition Classes
    DLClassifierModelDLModel → Identifiable
  88. val validVectorTypes: Seq[VectorUDT]

    Definition Classes
    VectorCompatibility
  89. def validateDataType(schema: StructType, colName: String): Unit

    Validate if feature and label columns are of supported data types.

    Validate if feature and label columns are of supported data types. Default: 0

    Attributes
    protected
    Definition Classes
    DLParams
  90. def validateParams(): Unit

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

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from DLModel[T]

Inherited from DLParams[T]

Inherited from HasBatchSize

Inherited from VectorCompatibility

Inherited from HasPredictionCol

Inherited from HasFeaturesCol

Inherited from DLTransformerBase[DLModel[T]]

Inherited from Model[DLModel[T]]

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

Ungrouped