Class/Object

org.apache.flink.ml.pipeline

ChainedPredictor

Related Docs: object ChainedPredictor | package pipeline

Permalink

case class ChainedPredictor[T <: Transformer[T], P <: Predictor[P]](transformer: T, predictor: P) extends Predictor[ChainedPredictor[T, P]] with Product with Serializable

Predictor which represents a pipeline of possibly multiple Transformer and a trailing Predictor.

The ChainedPredictor can be used as a regular Predictor. Upon calling the fit method, the input data is piped through all preceding Transformer in the pipeline and the resulting data is given to the trailing Predictor. The same holds true for the predict operation.

The pipeline mechanism has been inspired by scikit-learn

T

Type of the preceding Transformer

P

Type of the trailing Predictor

transformer

Preceding Transformer of the pipeline

predictor

Trailing Predictor of the pipeline

Linear Supertypes
Serializable, Serializable, Product, Equals, Predictor[ChainedPredictor[T, P]], Estimator[ChainedPredictor[T, P]], WithParameters, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ChainedPredictor
  2. Serializable
  3. Serializable
  4. Product
  5. Equals
  6. Predictor
  7. Estimator
  8. WithParameters
  9. AnyRef
  10. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ChainedPredictor(transformer: T, predictor: P)

    Permalink

    transformer

    Preceding Transformer of the pipeline

    predictor

    Trailing Predictor of the pipeline

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 ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  5. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  6. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  7. def evaluate[Testing, PredictionValue](testing: DataSet[Testing], evaluateParameters: ParameterMap = ParameterMap.Empty)(implicit evaluator: EvaluateDataSetOperation[ChainedPredictor[T, P], Testing, PredictionValue]): DataSet[(PredictionValue, PredictionValue)]

    Permalink

    Evaluates the testing data by computing the prediction value and returning a pair of true label value and prediction value.

    Evaluates the testing data by computing the prediction value and returning a pair of true label value and prediction value. It is important that the implementation chooses a Testing type from which it can extract the true label value.

    Definition Classes
    Predictor
  8. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  9. def fit[Training](training: DataSet[Training], fitParameters: ParameterMap = ParameterMap.Empty)(implicit fitOperation: FitOperation[ChainedPredictor[T, P], Training]): Unit

    Permalink

    Fits the estimator to the given input data.

    Fits the estimator to the given input data. The fitting logic is contained in the FitOperation. The computed state will be stored in the implementing class.

    Training

    Type of the training data

    training

    Training data

    fitParameters

    Additional parameters for the FitOperation

    fitOperation

    FitOperation which encapsulates the algorithm logic

    Definition Classes
    Estimator
  10. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  11. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  12. final def ne(arg0: AnyRef): Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  15. val parameters: ParameterMap

    Permalink
    Definition Classes
    WithParameters
  16. def predict[Testing, Prediction](testing: DataSet[Testing], predictParameters: ParameterMap = ParameterMap.Empty)(implicit predictor: PredictDataSetOperation[ChainedPredictor[T, P], Testing, Prediction]): DataSet[Prediction]

    Permalink

    Predict testing data according the learned model.

    Predict testing data according the learned model. The implementing class has to provide a corresponding implementation of PredictDataSetOperation which contains the prediction logic.

    Testing

    Type of the testing data

    Prediction

    Type of the prediction data

    testing

    Testing data which shall be predicted

    predictParameters

    Additional parameters for the prediction

    predictor

    PredictDataSetOperation which encapsulates the prediction logic

    Definition Classes
    Predictor
  17. val predictor: P

    Permalink

    Trailing Predictor of the pipeline

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

    Permalink
    Definition Classes
    AnyRef
  19. val transformer: T

    Permalink

    Preceding Transformer of the pipeline

  20. final def wait(): Unit

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

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

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

Inherited from Serializable

Inherited from Serializable

Inherited from Product

Inherited from Equals

Inherited from Predictor[ChainedPredictor[T, P]]

Inherited from Estimator[ChainedPredictor[T, P]]

Inherited from WithParameters

Inherited from AnyRef

Inherited from Any

Ungrouped