package ml
DataFrame-based machine learning APIs to let users quickly assemble and configure practical machine learning pipelines.
- Source
- package.scala
- Alphabetic
- By Inheritance
- ml
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
Type Members
-
abstract
class
Estimator[M <: Model[M]] extends PipelineStage
Abstract class for estimators that fit models to data.
-
case class
FitEnd[M <: Model[M]]() extends MLEvent with Product with Serializable
Event fired after
Estimator.fit
.Event fired after
Estimator.fit
.- Annotations
- @Evolving()
-
case class
FitStart[M <: Model[M]]() extends MLEvent with Product with Serializable
Event fired before
Estimator.fit
.Event fired before
Estimator.fit
.- Annotations
- @Evolving()
-
case class
LoadInstanceEnd[T]() extends MLEvent with Product with Serializable
Event fired after
MLReader.load
.Event fired after
MLReader.load
.- Annotations
- @Evolving()
-
case class
LoadInstanceStart[T](path: String) extends MLEvent with Product with Serializable
Event fired before
MLReader.load
.Event fired before
MLReader.load
.- Annotations
- @Evolving()
-
sealed
trait
MLEvent extends SparkListenerEvent
Event emitted by ML operations.
Event emitted by ML operations. Events are either fired before and/or after each operation (the event should document this).
- Annotations
- @Evolving()
- Note
This is supported via Pipeline and PipelineModel.
-
abstract
class
Model[M <: Model[M]] extends Transformer
A fitted model, i.e., a Transformer produced by an Estimator.
A fitted model, i.e., a Transformer produced by an Estimator.
- M
model type
-
class
Pipeline extends Estimator[PipelineModel] with MLWritable
A simple pipeline, which acts as an estimator.
A simple pipeline, which acts as an estimator. A Pipeline consists of a sequence of stages, each of which is either an Estimator or a Transformer. When
Pipeline.fit
is called, the stages are executed in order. If a stage is an Estimator, itsEstimator.fit
method will be called on the input dataset to fit a model. Then the model, which is a transformer, will be used to transform the dataset as the input to the next stage. If a stage is a Transformer, itsTransformer.transform
method will be called to produce the dataset for the next stage. The fitted model from a Pipeline is a PipelineModel, which consists of fitted models and transformers, corresponding to the pipeline stages. If there are no stages, the pipeline acts as an identity transformer.- Annotations
- @Since( "1.2.0" )
-
class
PipelineModel extends Model[PipelineModel] with MLWritable with Logging
Represents a fitted pipeline.
Represents a fitted pipeline.
- Annotations
- @Since( "1.2.0" )
-
abstract
class
PipelineStage extends Params with Logging
A stage in a pipeline, either an Estimator or a Transformer.
-
abstract
class
PredictionModel[FeaturesType, M <: PredictionModel[FeaturesType, M]] extends Model[M] with PredictorParams
Abstraction for a model for prediction tasks (regression and classification).
Abstraction for a model for prediction tasks (regression and classification).
- FeaturesType
Type of features. E.g.,
VectorUDT
for vector features.- M
Specialization of PredictionModel. If you subclass this type, use this type parameter to specify the concrete type for the corresponding model.
-
abstract
class
Predictor[FeaturesType, Learner <: Predictor[FeaturesType, Learner, M], M <: PredictionModel[FeaturesType, M]] extends Estimator[M] with PredictorParams
Abstraction for prediction problems (regression and classification).
Abstraction for prediction problems (regression and classification). It accepts all NumericType labels and will automatically cast it to DoubleType in
fit()
. If this predictor supports weights, it accepts all NumericType weights, which will be automatically casted to DoubleType infit()
.- FeaturesType
Type of features. E.g.,
VectorUDT
for vector features.- Learner
Specialization of this class. If you subclass this type, use this type parameter to specify the concrete type.
- M
Specialization of PredictionModel. If you subclass this type, use this type parameter to specify the concrete type for the corresponding model.
-
case class
SaveInstanceEnd(path: String) extends MLEvent with Product with Serializable
Event fired after
MLWriter.save
.Event fired after
MLWriter.save
.- Annotations
- @Evolving()
-
case class
SaveInstanceStart(path: String) extends MLEvent with Product with Serializable
Event fired before
MLWriter.save
.Event fired before
MLWriter.save
.- Annotations
- @Evolving()
-
case class
TransformEnd() extends MLEvent with Product with Serializable
Event fired after
Transformer.transform
.Event fired after
Transformer.transform
.- Annotations
- @Evolving()
-
case class
TransformStart() extends MLEvent with Product with Serializable
Event fired before
Transformer.transform
.Event fired before
Transformer.transform
.- Annotations
- @Evolving()
-
abstract
class
Transformer extends PipelineStage
Abstract class for transformers that transform one dataset into another.
-
abstract
class
UnaryTransformer[IN, OUT, T <: UnaryTransformer[IN, OUT, T]] extends Transformer with HasInputCol with HasOutputCol with Logging
Abstract class for transformers that take one input column, apply transformation, and output the result as a new column.
Value Members
-
object
Pipeline extends MLReadable[Pipeline] with Serializable
- Annotations
- @Since( "1.6.0" )
-
object
PipelineModel extends MLReadable[PipelineModel] with Serializable
- Annotations
- @Since( "1.6.0" )
-
object
functions
- Annotations
- @Since( "3.0.0" )