You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@spark.apache.org by pw...@apache.org on 2014/01/14 08:00:04 UTC

[40/50] git commit: Improve scaladoc links

Improve scaladoc links


Project: http://git-wip-us.apache.org/repos/asf/incubator-spark/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-spark/commit/c28e5a08
Tree: http://git-wip-us.apache.org/repos/asf/incubator-spark/tree/c28e5a08
Diff: http://git-wip-us.apache.org/repos/asf/incubator-spark/diff/c28e5a08

Branch: refs/heads/master
Commit: c28e5a08eea4f295676ea591c877c648f9f29847
Parents: 59e4384
Author: Ankur Dave <an...@gmail.com>
Authored: Mon Jan 13 21:11:39 2014 -0800
Committer: Ankur Dave <an...@gmail.com>
Committed: Mon Jan 13 21:11:39 2014 -0800

----------------------------------------------------------------------
 .../src/main/scala/org/apache/spark/graphx/EdgeRDD.scala  |  2 +-
 .../src/main/scala/org/apache/spark/graphx/GraphOps.scala | 10 +++++-----
 2 files changed, 6 insertions(+), 6 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/incubator-spark/blob/c28e5a08/graphx/src/main/scala/org/apache/spark/graphx/EdgeRDD.scala
----------------------------------------------------------------------
diff --git a/graphx/src/main/scala/org/apache/spark/graphx/EdgeRDD.scala b/graphx/src/main/scala/org/apache/spark/graphx/EdgeRDD.scala
index 0269ed3..c0a23d1 100644
--- a/graphx/src/main/scala/org/apache/spark/graphx/EdgeRDD.scala
+++ b/graphx/src/main/scala/org/apache/spark/graphx/EdgeRDD.scala
@@ -9,7 +9,7 @@ import org.apache.spark.storage.StorageLevel
 
 /**
  * `EdgeRDD[ED]` extends `RDD[Edge[ED]]` by storing the edges in columnar format on each partition
- * for performance. It is constructed using [[impl.EdgePartitionBuilder]].
+ * for performance.
  */
 class EdgeRDD[@specialized ED: ClassTag](
     val partitionsRDD: RDD[(PartitionID, EdgePartition[ED])])

http://git-wip-us.apache.org/repos/asf/incubator-spark/blob/c28e5a08/graphx/src/main/scala/org/apache/spark/graphx/GraphOps.scala
----------------------------------------------------------------------
diff --git a/graphx/src/main/scala/org/apache/spark/graphx/GraphOps.scala b/graphx/src/main/scala/org/apache/spark/graphx/GraphOps.scala
index 233adb9..f10e63f 100644
--- a/graphx/src/main/scala/org/apache/spark/graphx/GraphOps.scala
+++ b/graphx/src/main/scala/org/apache/spark/graphx/GraphOps.scala
@@ -254,7 +254,7 @@ class GraphOps[VD: ClassTag, ED: ClassTag](graph: Graph[VD, ED]) extends Seriali
    * Run a dynamic version of PageRank returning a graph with vertex attributes containing the
    * PageRank and edge attributes containing the normalized edge weight.
    *
-   * @see [[org.apache.spark.graphx.lib.PageRank]], method `runUntilConvergence`.
+   * @see [[org.apache.spark.graphx.lib.PageRank$#runUntilConvergence]]
    */
   def pageRank(tol: Double, resetProb: Double = 0.15): Graph[Double, Double] = {
     PageRank.runUntilConvergence(graph, tol, resetProb)
@@ -264,7 +264,7 @@ class GraphOps[VD: ClassTag, ED: ClassTag](graph: Graph[VD, ED]) extends Seriali
    * Run PageRank for a fixed number of iterations returning a graph with vertex attributes
    * containing the PageRank and edge attributes the normalized edge weight.
    *
-   * @see [[org.apache.spark.graphx.lib.PageRank]], method `run`.
+   * @see [[org.apache.spark.graphx.lib.PageRank$#run]]
    */
   def staticPageRank(numIter: Int, resetProb: Double = 0.15): Graph[Double, Double] = {
     PageRank.run(graph, numIter, resetProb)
@@ -274,7 +274,7 @@ class GraphOps[VD: ClassTag, ED: ClassTag](graph: Graph[VD, ED]) extends Seriali
    * Compute the connected component membership of each vertex and return a graph with the vertex
    * value containing the lowest vertex id in the connected component containing that vertex.
    *
-   * @see [[org.apache.spark.graphx.lib.ConnectedComponents]]
+   * @see [[org.apache.spark.graphx.lib.ConnectedComponents$#run]]
    */
   def connectedComponents(): Graph[VertexID, ED] = {
     ConnectedComponents.run(graph)
@@ -283,7 +283,7 @@ class GraphOps[VD: ClassTag, ED: ClassTag](graph: Graph[VD, ED]) extends Seriali
   /**
    * Compute the number of triangles passing through each vertex.
    *
-   * @see [[org.apache.spark.graphx.lib.TriangleCount]]
+   * @see [[org.apache.spark.graphx.lib.TriangleCount$#run]]
    */
   def triangleCount(): Graph[Int, ED] = {
     TriangleCount.run(graph)
@@ -293,7 +293,7 @@ class GraphOps[VD: ClassTag, ED: ClassTag](graph: Graph[VD, ED]) extends Seriali
    * Compute the strongly connected component (SCC) of each vertex and return a graph with the
    * vertex value containing the lowest vertex id in the SCC containing that vertex.
    *
-   * @see [[org.apache.spark.graphx.lib.StronglyConnectedComponents]]
+   * @see [[org.apache.spark.graphx.lib.StronglyConnectedComponents$#run]]
    */
   def stronglyConnectedComponents(numIter: Int): Graph[VertexID, ED] = {
     StronglyConnectedComponents.run(graph, numIter)