Skip to content

Commit cbe15f2

Browse files
committed
Remove specialized annotation from VertexRDD and EdgeRDD
It makes no difference in benchmarks.
1 parent 931b587 commit cbe15f2

File tree

4 files changed

+4
-4
lines changed

4 files changed

+4
-4
lines changed

graphx/src/main/scala/org/apache/spark/graphx/EdgeRDD.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -34,7 +34,7 @@ import org.apache.spark.graphx.impl.EdgeRDDImpl
3434
* edge to provide the triplet view. Shipping of the vertex attributes is managed by
3535
* `impl.ReplicatedVertexView`.
3636
*/
37-
abstract class EdgeRDD[@specialized ED, VD](
37+
abstract class EdgeRDD[ED, VD](
3838
@transient sc: SparkContext,
3939
@transient deps: Seq[Dependency[_]]) extends RDD[Edge[ED]](sc, deps) {
4040
/**

graphx/src/main/scala/org/apache/spark/graphx/VertexRDD.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -56,7 +56,7 @@ import org.apache.spark.graphx.impl.VertexRDDFunctions._
5656
*
5757
* @tparam VD the vertex attribute associated with each vertex in the set.
5858
*/
59-
abstract class VertexRDD[@specialized VD](
59+
abstract class VertexRDD[VD](
6060
@transient sc: SparkContext,
6161
@transient deps: Seq[Dependency[_]]) extends RDD[(VertexId, VD)](sc, deps) {
6262

graphx/src/main/scala/org/apache/spark/graphx/impl/EdgeRDDImpl.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -25,7 +25,7 @@ import org.apache.spark.storage.StorageLevel
2525

2626
import org.apache.spark.graphx._
2727

28-
class EdgeRDDImpl[@specialized ED: ClassTag, VD: ClassTag] private[graphx] (
28+
class EdgeRDDImpl[ED: ClassTag, VD: ClassTag] private[graphx] (
2929
override val partitionsRDD: RDD[(PartitionID, EdgePartition[ED, VD])],
3030
val targetStorageLevel: StorageLevel = StorageLevel.MEMORY_ONLY)
3131
extends EdgeRDD[ED, VD](partitionsRDD.context, List(new OneToOneDependency(partitionsRDD))) {

graphx/src/main/scala/org/apache/spark/graphx/impl/VertexRDDImpl.scala

Lines changed: 1 addition & 1 deletion
Original file line numberDiff line numberDiff line change
@@ -28,7 +28,7 @@ import org.apache.spark.graphx._
2828
import org.apache.spark.graphx.impl.RoutingTableMessageRDDFunctions._
2929
import org.apache.spark.graphx.impl.VertexRDDFunctions._
3030

31-
class VertexRDDImpl[@specialized VD] private[graphx] (
31+
class VertexRDDImpl[VD] private[graphx] (
3232
val partitionsRDD: RDD[ShippableVertexPartition[VD]],
3333
val targetStorageLevel: StorageLevel = StorageLevel.MEMORY_ONLY)
3434
(implicit override protected val vdTag: ClassTag[VD])

0 commit comments

Comments
 (0)