Spark 4.1.0 ScalaDoc - org.apache.spark.ml.Pipeline (original) (raw)

class Pipeline extends Estimator[PipelineModel] with MLWritable

Ordering

  1. Grouped
  2. Alphabetic
  3. By Inheritance

Inherited

  1. Pipeline

  2. MLWritable

  3. Estimator

  4. PipelineStage

  5. Logging

  6. Params

  7. Serializable

  8. Identifiable

  9. AnyRef

  10. Any

  11. Hide All

  12. Show All

Visibility

  1. Public
  2. Protected

Instance Constructors

  1. new Pipeline()
  2. new Pipeline(uid: String)

Type Members

  1. implicit class LogStringContext extends AnyRef

Value Members

  1. final def !=(arg0: Any): Boolean
  2. final def ##: Int
  3. final def $[T](param: Param[T]): T
  4. final def ==(arg0: Any): Boolean
  5. def MDC(key: LogKey, value: Any): MDC
  6. final def asInstanceOf[T0]: T0
  7. final def clear(param: Param[_]): Pipeline.this.type
  8. def clone(): AnyRef
  9. def copy(extra: ParamMap): Pipeline
  10. def copyValues[T <: Params](to: T, extra: ParamMap = ParamMap.empty): T
  11. final def defaultCopy[T <: Params](extra: ParamMap): T
  12. final def eq(arg0: AnyRef): Boolean
  13. def equals(arg0: AnyRef): Boolean
  14. def explainParam(param: Param[_]): String
  15. def explainParams(): String
  16. final def extractParamMap(): ParamMap
  17. final def extractParamMap(extra: ParamMap): ParamMap
  18. def fit(dataset: Dataset[_]): PipelineModel
  19. def fit(dataset: Dataset[_], paramMaps: Seq[ParamMap]): Seq[PipelineModel]
  20. def fit(dataset: Dataset[_], paramMap: ParamMap): PipelineModel
  21. def fit(dataset: Dataset[_], firstParamPair: ParamPair[_], otherParamPairs: ParamPair[_]*): PipelineModel
  22. final def get[T](param: Param[T]): Option[T]
  23. final def getClass(): Class[_ <: AnyRef]
  24. final def getDefault[T](param: Param[T]): Option[T]
  25. final def getOrDefault[T](param: Param[T]): T
  26. def getParam(paramName: String): Param[Any]
  27. def getStages: Array[PipelineStage]
  28. final def hasDefault[T](param: Param[T]): Boolean
  29. def hasParam(paramName: String): Boolean
  30. def hashCode(): Int
  31. def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
  32. def initializeLogIfNecessary(isInterpreter: Boolean): Unit
  33. final def isDefined(param: Param[_]): Boolean
  34. final def isInstanceOf[T0]: Boolean
  35. final def isSet(param: Param[_]): Boolean
  36. def isTraceEnabled(): Boolean
  37. def log: Logger
  38. def logBasedOnLevel(level: Level)(f: => MessageWithContext): Unit
  39. def logDebug(msg: => String, throwable: Throwable): Unit
  40. def logDebug(entry: LogEntry, throwable: Throwable): Unit
  41. def logDebug(entry: LogEntry): Unit
  42. def logDebug(msg: => String): Unit
  43. def logError(msg: => String, throwable: Throwable): Unit
  44. def logError(entry: LogEntry, throwable: Throwable): Unit
  45. def logError(entry: LogEntry): Unit
  46. def logError(msg: => String): Unit
  47. def logInfo(msg: => String, throwable: Throwable): Unit
  48. def logInfo(entry: LogEntry, throwable: Throwable): Unit
  49. def logInfo(entry: LogEntry): Unit
  50. def logInfo(msg: => String): Unit
  51. def logName: String
  52. def logTrace(msg: => String, throwable: Throwable): Unit
  53. def logTrace(entry: LogEntry, throwable: Throwable): Unit
  54. def logTrace(entry: LogEntry): Unit
  55. def logTrace(msg: => String): Unit
  56. def logWarning(msg: => String, throwable: Throwable): Unit
  57. def logWarning(entry: LogEntry, throwable: Throwable): Unit
  58. def logWarning(entry: LogEntry): Unit
  59. def logWarning(msg: => String): Unit
  60. final def ne(arg0: AnyRef): Boolean
  61. final def notify(): Unit
  62. final def notifyAll(): Unit
  63. lazy val params: Array[Param[_]]
  64. def save(path: String): Unit
  65. final def set(paramPair: ParamPair[_]): Pipeline.this.type
  66. final def set(param: String, value: Any): Pipeline.this.type
  67. final def set[T](param: Param[T], value: T): Pipeline.this.type
  68. final def setDefault(paramPairs: ParamPair[_]*): Pipeline.this.type
  69. final def setDefault[T](param: Param[T], value: T): Pipeline.this.type
  70. def setStages(value: Array[_ <: PipelineStage]): Pipeline.this.type
  71. val stages: Param[Array[PipelineStage]]
  72. final def synchronized[T0](arg0: => T0): T0
  73. def toString(): String
  74. def transformSchema(schema: StructType): StructType
  75. def transformSchema(schema: StructType, logging: Boolean): StructType
  76. val uid: String
  77. final def wait(arg0: Long, arg1: Int): Unit
  78. final def wait(arg0: Long): Unit
  79. final def wait(): Unit
  80. def withLogContext(context: Map[String, String])(body: => Unit): Unit
  81. def write: MLWriter

Deprecated Value Members

  1. def finalize(): Unit

Parameters

Members

Parameter setters

Parameter getters