org.apache.spark.mllib.clustering

MCLUtils

object MCLUtils

Utils functions for MCL algorithm implementation.

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. MCLUtils
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  7. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  8. def displayBlockMatrix(mat: BlockMatrix): Unit

  9. def displayMatrix(mat: IndexedRowMatrix): Unit

    Print an adjacency matrix in nice format.

    Print an adjacency matrix in nice format.

    mat

    an adjacency matrix

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

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

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

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

    Definition Classes
    AnyRef → Any
  14. def graphOrientationManager(graph: Graph[Int, Double], graphOrientationStrategy: String): RDD[(Int, (Int, Double))]

    Deal with multiple adjacency matrix filling strategy depending on graph orientation

    Deal with multiple adjacency matrix filling strategy depending on graph orientation

    graph

    original graph

    graphOrientationStrategy

    chose a graph strategy completion depending on its nature. 3 choices: undirected, directed, birected.

    returns

    an RDD of new edges weights and associated coordinates.

  15. def hashCode(): Int

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

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

    Definition Classes
    AnyRef
  18. final def notify(): Unit

    Definition Classes
    AnyRef
  19. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  20. def preprocessGraph[VD](graph: Graph[VD, Double], lookupTable: DataFrame): Graph[Int, Double]

    Get a suitable graph for MCL model algorithm.

    Get a suitable graph for MCL model algorithm.

    Each vertex id in the graph corresponds to a row id in the adjacency matrix.

    graph

    original graph

    lookupTable

    a matching table with nodes ids and new ordered ids

    returns

    prepared graph for MCL algorithm

  21. def selfLoopManager(graph: Graph[Int, Double], selfLoopWeight: Double): RDD[(Int, (Int, Double))]

    Deal with self loop

    Deal with self loop

    Add one when weight is nil and remain as it is otherwise

    graph

    original graph

    selfLoopWeight

    a coefficient between 0 and 1 to influence clustering granularity and objective

    returns

    an RDD of self loops weights and associated coordinates.

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

    Definition Classes
    AnyRef
  23. def toGraph(mat: IndexedRowMatrix, vertices: RDD[(VertexId, String)]): Graph[String, Double]

    Transform an IndexedRowMatrix into a Graph

    Transform an IndexedRowMatrix into a Graph

    mat

    an adjacency matrix

    vertices

    vertices of original graph

    returns

    associated graph

  24. def toIndexedRowMatrix(graph: Graph[Int, Double], selfLoopWeight: Double, graphOrientationStrategy: String): IndexedRowMatrix

    Transform a Graph into an IndexedRowMatrix

    Transform a Graph into an IndexedRowMatrix

    graph

    original graph

    selfLoopWeight

    a coefficient between 0 and 1 to influence clustering granularity and objective

    graphOrientationStrategy

    chose a graph strategy completion depending on its nature. 3 choices: undirected, directed, birected.

    returns

    a ready adjacency matrix for MCL process.

    To do

    Check graphOrientationStrategy choice for current graph

  25. def toString(): String

    Definition Classes
    AnyRef → Any
  26. final def wait(): Unit

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from AnyRef

Inherited from Any

Ungrouped