Object/Class

org.apache.flink.ml.outlier

StochasticOutlierSelection

Related Docs: class StochasticOutlierSelection | package outlier

Permalink

object StochasticOutlierSelection extends WithParameters with Serializable

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

Type Members

  1. case class BreezeLabeledVector(idx: Int, data: Vector[Double]) extends Product with Serializable

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

    Permalink
    Definition Classes
    AnyRef → Any
  4. object ErrorTolerance extends Parameter[Double] with Product with Serializable

    Permalink
  5. object MaxIterations extends Parameter[Int] with Product with Serializable

    Permalink
  6. object Perplexity extends Parameter[Double] with Product with Serializable

    Permalink
  7. def apply(): StochasticOutlierSelection

    Permalink
  8. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  9. def binarySearch(dissimilarityVector: Vector[Double], logPerplexity: Double, maxIterations: Int, tolerance: Double, beta: Double = 1.0, betaMin: Double = Double.NegativeInfinity, betaMax: Double = Double.PositiveInfinity, iteration: Int = 0): Vector[Double]

    Permalink

    Performs a binary search to get affinities in such a way that each conditional Gaussian has the same perplexity.

    Performs a binary search to get affinities in such a way that each conditional Gaussian has the same perplexity.

    dissimilarityVector

    The input dissimilarity vector which represents the current vector distance to the other vectors in the data set

    logPerplexity

    The log of the perplexity, which represents the probability of having affinity with another vector.

    maxIterations

    The maximum iterations to limit the computational time.

    tolerance

    The allowed tolerance to sacrifice precision for decreased computational time.

    betaMin

    The lower bound of beta

    betaMax

    The upper bound of beta

    iteration

    The current iteration

    returns

    Returns the affinity vector of the input vector.

  10. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  11. def computeAffinity(dissimilarityVectors: DataSet[BreezeLabeledVector], resultingParameters: ParameterMap): DataSet[BreezeLabeledVector]

    Permalink

    Approximate the affinity by fitting a Gaussian-like function

    Approximate the affinity by fitting a Gaussian-like function

    dissimilarityVectors

    The dissimilarity vectors which represents the distance to the other vectors in the data set.

    resultingParameters

    The user defined parameters of the algorithm

    returns

    Returns new set of BreezeLabeledVector with dissimilarity vector

  12. def computeBindingProbabilities(affinityVectors: DataSet[BreezeLabeledVector]): DataSet[BreezeLabeledVector]

    Permalink

    Normalizes the input vectors so each row sums up to one.

    Normalizes the input vectors so each row sums up to one.

    affinityVectors

    The affinity vectors which is the quantification of the relationship between the original vectors.

    returns

    Returns new set of BreezeLabeledVector with represents the binding probabilities, which is in fact the affinity where each row sums up to one.

  13. def computeDissimilarityVectors(inputVectors: DataSet[BreezeLabeledVector]): DataSet[BreezeLabeledVector]

    Permalink

    Compute pair-wise distance from each vector, to all other vectors.

    Compute pair-wise distance from each vector, to all other vectors.

    inputVectors

    The input vectors, will compare the vector to all other vectors based on an distance method.

    returns

    Returns new set of BreezeLabeledVector with dissimilarity vector

  14. def computeOutlierProbability(bindingProbabilityVectors: DataSet[BreezeLabeledVector]): DataSet[(Int, Double)]

    Permalink

    Compute the final outlier probability by taking the product of the column.

    Compute the final outlier probability by taking the product of the column.

    bindingProbabilityVectors

    The binding probability vectors where the binding probability is based on the affinity and represents the probability of a vector binding with another vector.

    returns

    Returns a single double which represents the final outlierness of the input vector.

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  17. def finalize(): Unit

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

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

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

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

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

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

    Permalink
    Definition Classes
    AnyRef
  24. val parameters: ParameterMap

    Permalink
    Definition Classes
    WithParameters
  25. final def synchronized[T0](arg0: ⇒ T0): T0

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

    Permalink
    Definition Classes
    AnyRef → Any
  27. implicit val transformLabeledVectors: TransformDataSetOperation[StochasticOutlierSelection, LabeledVector, (Int, Double)]

    Permalink
  28. implicit def transformVectors[T <: Vector](implicit arg0: BreezeVectorConverter[T], arg1: TypeInformation[T], arg2: ClassTag[T]): TransformDataSetOperation[StochasticOutlierSelection, T, Double]

    Permalink

    TransformDataSetOperation applies the stochastic outlier selection algorithm on a Vector which will transform the high-dimensional input to a single Double output.

    TransformDataSetOperation applies the stochastic outlier selection algorithm on a Vector which will transform the high-dimensional input to a single Double output.

    T

    Type of the input and output data which has to be a subtype of Vector

    returns

    TransformDataSetOperation a single double which represents the oulierness of the input vectors, where the output is in [0, 1]

  29. final def wait(): Unit

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

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

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

Inherited from Serializable

Inherited from Serializable

Inherited from WithParameters

Inherited from AnyRef

Inherited from Any

Ungrouped