Class/Object

org.apache.spark.ml

DLClassifier

Related Docs: object DLClassifier | package ml

Permalink

class DLClassifier[T] extends MlTransformer with HasInputCol with HasOutputCol with DataParams[T]

A general Classifier to classify the input data in inputCol, and write the results to outputCol. Use setInputCol to set inputCol name, and use setOutputCol to set outputCol name.

DLClassifier is compatible with both spark 1.5-plus and 2.0 by extending MLTransform.

Linear Supertypes
DataParams[T], HasOutputCol, HasInputCol, MlTransformer, Transformer, PipelineStage, Logging, Params, Serializable, Serializable, Identifiable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. DLClassifier
  2. DataParams
  3. HasOutputCol
  4. HasInputCol
  5. MlTransformer
  6. Transformer
  7. PipelineStage
  8. Logging
  9. Params
  10. Serializable
  11. Serializable
  12. Identifiable
  13. AnyRef
  14. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new DLClassifier(uid: String = "DLClassifier")(implicit arg0: ClassTag[T], ev: TensorNumeric[T])

    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 val batchShape: Param[Array[Int]]

    Permalink
    Definition Classes
    DataParams
  7. final def clear(param: Param[_]): DLClassifier.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): DLClassifier[T]

    Permalink
    Definition Classes
    DLClassifier → MlTransformer → 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. def finalize(): Unit

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

    Permalink
    Definition Classes
    Params
  20. final def getBatchSize: Array[Int]

    Permalink

    get the batch shape

    get the batch shape

    returns

    batchShape

    Definition Classes
    DataParams
  21. final def getClass(): Class[_]

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

    Permalink
    Definition Classes
    Params
  23. final def getInputCol: String

    Permalink
    Definition Classes
    HasInputCol
  24. final def getModel: Module[T]

    Permalink

    get the model

    get the model

    returns

    modelTrain

    Definition Classes
    DataParams
  25. final def getOrDefault[T](param: Param[T]): T

    Permalink
    Definition Classes
    Params
  26. final def getOutputCol: String

    Permalink
    Definition Classes
    HasOutputCol
  27. def getParam(paramName: String): Param[Any]

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

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  31. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  32. final val inputCol: Param[String]

    Permalink
    Definition Classes
    HasInputCol
  33. final def isDefined(param: Param[_]): Boolean

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

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

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

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

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

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

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

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

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

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  49. final val modelTrain: Param[Module[T]]

    Permalink
    Definition Classes
    DataParams
  50. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  53. final val outputCol: Param[String]

    Permalink
    Definition Classes
    HasOutputCol
  54. lazy val params: Array[Param[_]]

    Permalink
    Definition Classes
    Params
  55. def process(dataset: DataFrame): DataFrame

    Permalink

    Perform a prediction on inputCol, and write result to the outputCol.

    Perform a prediction on inputCol, and write result to the outputCol.

    dataset

    input DataFrame

    returns

    output DataFrame

    Definition Classes
    DLClassifier → MlTransformer
  56. final def set(paramPair: ParamPair[_]): DLClassifier.this.type

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Params
  61. def setInputCol(inputColName: String): DLClassifier.this.type

    Permalink

    Set the input column name

    Set the input column name

    inputColName

    the name of the input column

    returns

    this.

  62. def setOutputCol(outputColName: String): DLClassifier.this.type

    Permalink

    Set the output column name, should not existed in the DataFrame.

    Set the output column name, should not existed in the DataFrame.

    outputColName

    the name of the output column

    returns

    this.

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

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

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

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

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

    Permalink
    Definition Classes
    Transformer
    Annotations
    @Since( "2.0.0" ) @varargs()
  68. def transformSchema(schema: StructType): StructType

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

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

    Permalink
    Definition Classes
    DLClassifier → Identifiable
  71. def validateParameters(): Unit

    Permalink
  72. final def wait(): Unit

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

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

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

Deprecated Value Members

  1. def validateParams(): Unit

    Permalink
    Definition Classes
    Params
    Annotations
    @deprecated
    Deprecated

    (Since version 2.0.0) Will be removed in 2.1.0. Checks should be merged into transformSchema.

Inherited from DataParams[T]

Inherited from HasOutputCol

Inherited from HasInputCol

Inherited from MlTransformer

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