Object/Class

org.apache.spark.ml.odkl

Evaluator

Related Docs: class Evaluator | package odkl

Permalink

object Evaluator extends Serializable

Linear Supertypes
Serializable, Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Evaluator
  2. Serializable
  3. Serializable
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. class EmptyEvaluator extends Evaluator[EmptyEvaluator]

    Permalink

    Used in case when folding is needed, but not the evaluation

  2. class EvaluatingTransformer[M <: ModelWithSummary[M], E <: Evaluator[E]] extends ModelOnlyTransformer[M, EvaluatingTransformer[M, E]] with HasMetricsBlock

    Permalink

    Utility used for transparent injection of the evaluator into training chain.

    Utility used for transparent injection of the evaluator into training chain. Evaluator is applied only while fitting (it adds an extra summary block), but has no other traces in the final model (does not affect predictions).

  3. class PostProcessingEvaluator[E <: Evaluator[E]] extends Evaluator[PostProcessingEvaluator[E]]

    Permalink
  4. class TrainOnlyFilter extends Transformer with HasIsTestCol

    Permalink

    Utility used to filter out test data before passing to estimator.

  5. class TrainTestEvaluator[N <: Evaluator[N]] extends Evaluator[TrainTestEvaluator[N]] with HasIsTestCol

    Permalink

    This is a simple workaround to add kind of grouping by test/train column for evaluators without embedded support for grouping (eg.

    This is a simple workaround to add kind of grouping by test/train column for evaluators without embedded support for grouping (eg. BinaryClassificationEvaluator).

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. def addFolds[M <: ModelWithSummary[M]](estimator: SummarizableEstimator[M], folder: FoldsAssigner = new FoldsAssigner()): UnwrappedStage[M, IdentityModelTransformer[M]]

    Permalink

    Adds folds (foldNum column) to the dataset before passing it to the nested estimator.

    Adds folds (foldNum column) to the dataset before passing it to the nested estimator.

    estimator

    Nested predictor for fitting the model

    folder

    Transformer adding folds (by default based on row hash)

    returns

    Estimator returning a model fit by nested predictor on a dataset with extra foldNum column

  5. final def asInstanceOf[T0]: T0

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

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  7. def crossValidate[M <: ModelWithSummary[M], E <: Evaluator[E]](estimator: SummarizableEstimator[M], evaluator: E, numFolds: Int = 10, numThreads: Int = 1, prefix: String = "", addGlobal: Boolean = true): SummarizableEstimator[M]

    Permalink

    Performs a cross validation given predictor and evaluator.

    Performs a cross validation given predictor and evaluator. Returns a model with summary blocks extended with foldNum column.

    Split into folds is done based on the hash of entire row.

    estimator

    Nested predictor for fitting the model.

    evaluator

    Evaluator for creating a metric.

    numFolds

    Number of folds for validation (defeult 10)

    numThreads

    Number of parallel folds training.

    returns

    Estimator which returns a model fit by the nested predictor on the entire dataset with summary blocks extended with numFolds column.

  8. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  10. def evaluate[M <: ModelWithSummary[M], E <: Evaluator[E]](estimator: SummarizableEstimator[M], evaluator: E): SummarizableEstimator[M]

    Permalink

    Fit and then evaluate model.

    Fit and then evaluate model. Results of evaluation is stored into a dedicated summary block.

    estimator

    Used to fit the model

    evaluator

    Used to evaluate the model.

    returns

    Estimator which returns a model fit by nested predictor with extra summary block for metrics, produced by evaluator.

  11. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  12. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  13. def hashCode(): Int

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

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

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

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

    Permalink
    Definition Classes
    AnyRef
  18. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink
    Definition Classes
    AnyRef → Any
  20. def validateInFolds[M <: ModelWithSummary[M], E <: Evaluator[E]](estimator: SummarizableEstimator[M], evaluator: E, numFolds: Int = 10, numThreads: Int = 1, prefix: String = "", addGlobal: Boolean = true): CrossValidator[M]

    Permalink

    Performs a cross validation given predictor and evaluator.

    Performs a cross validation given predictor and evaluator. Returns a model with summary blocks extended with foldNum column.

    Split into folds is expected to be done externaly.

    estimator

    Nested predictor for fitting the model.

    evaluator

    Evaluator for creating a metric.

    numFolds

    Number of folds for validation (defeult 10)

    numThreads

    Number of threads to run validation.

    returns

    Estimator which returns a model fit by the nested predictor on the entire dataset with summary blocks extended with numFolds column.

  21. final def wait(): Unit

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

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

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

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped