class EdgeRDDImpl[ED, VD] extends EdgeRDD[ED]
- Alphabetic
- By Inheritance
- EdgeRDDImpl
- EdgeRDD
- RDD
- Logging
- Serializable
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Type Members
- implicit class LogStringContext extends AnyRef
- Definition Classes
- Logging
Value Members
- final def !=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def ##: Int
- Definition Classes
- AnyRef → Any
- def ++(other: RDD[Edge[ED]]): RDD[Edge[ED]]
- Definition Classes
- RDD
- final def ==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- def aggregate[U](zeroValue: U)(seqOp: (U, Edge[ED]) => U, combOp: (U, U) => U)(implicit arg0: ClassTag[U]): U
- Definition Classes
- RDD
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- def barrier(): RDDBarrier[Edge[ED]]
- Definition Classes
- RDD
- Annotations
- @Experimental() @Since("2.4.0")
- def cache(): EdgeRDDImpl.this.type
Persists the edge partitions using
targetStorageLevel
, which defaults to MEMORY_ONLY.Persists the edge partitions using
targetStorageLevel
, which defaults to MEMORY_ONLY.- Definition Classes
- EdgeRDDImpl → RDD
- def cartesian[U](other: RDD[U])(implicit arg0: ClassTag[U]): RDD[(Edge[ED], U)]
- Definition Classes
- RDD
- def checkpoint(): Unit
- Definition Classes
- EdgeRDDImpl → RDD
- def cleanShuffleDependencies(blocking: Boolean): Unit
- Definition Classes
- RDD
- Annotations
- @DeveloperApi() @Since("3.1.0")
- def clearDependencies(): Unit
- Attributes
- protected
- Definition Classes
- RDD
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
- def coalesce(numPartitions: Int, shuffle: Boolean, partitionCoalescer: Option[PartitionCoalescer])(implicit ord: Ordering[Edge[ED]]): RDD[Edge[ED]]
- Definition Classes
- RDD
- def collect(): Array[Edge[ED]]
- Definition Classes
- EdgeRDDImpl → RDD
- def collect[U](f: PartialFunction[Edge[ED], U])(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- def compute(part: Partition, context: TaskContext): Iterator[Edge[ED]]
- Definition Classes
- EdgeRDD → RDD
- def context: SparkContext
- Definition Classes
- RDD
- def count(): Long
The number of edges in the RDD.
The number of edges in the RDD.
- Definition Classes
- EdgeRDDImpl → RDD
- def countApprox(timeout: Long, confidence: Double): PartialResult[BoundedDouble]
- Definition Classes
- RDD
- def countApproxDistinct(relativeSD: Double): Long
- Definition Classes
- RDD
- def countApproxDistinct(p: Int, sp: Int): Long
- Definition Classes
- RDD
- def countByValue()(implicit ord: Ordering[Edge[ED]]): Map[Edge[ED], Long]
- Definition Classes
- RDD
- def countByValueApprox(timeout: Long, confidence: Double)(implicit ord: Ordering[Edge[ED]]): PartialResult[Map[Edge[ED], BoundedDouble]]
- Definition Classes
- RDD
- final def dependencies: Seq[Dependency[_]]
- Definition Classes
- RDD
- def distinct(): RDD[Edge[ED]]
- Definition Classes
- RDD
- def distinct(numPartitions: Int)(implicit ord: Ordering[Edge[ED]]): RDD[Edge[ED]]
- Definition Classes
- RDD
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef → Any
- def filter(epred: (EdgeTriplet[VD, ED]) => Boolean, vpred: (VertexId, VD) => Boolean): EdgeRDDImpl[ED, VD]
- def filter(f: (Edge[ED]) => Boolean): RDD[Edge[ED]]
- Definition Classes
- RDD
- def first(): Edge[ED]
- Definition Classes
- RDD
- def firstParent[U](implicit arg0: ClassTag[U]): RDD[U]
- Attributes
- protected[spark]
- Definition Classes
- RDD
- def flatMap[U](f: (Edge[ED]) => IterableOnce[U])(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- def fold(zeroValue: Edge[ED])(op: (Edge[ED], Edge[ED]) => Edge[ED]): Edge[ED]
- Definition Classes
- RDD
- def foreach(f: (Edge[ED]) => Unit): Unit
- Definition Classes
- RDD
- def foreachPartition(f: (Iterator[Edge[ED]]) => Unit): Unit
- Definition Classes
- RDD
- def getCheckpointFile: Option[String]
- Definition Classes
- EdgeRDDImpl → RDD
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- def getDependencies: Seq[Dependency[_]]
- Attributes
- protected
- Definition Classes
- RDD
- final def getNumPartitions: Int
- Definition Classes
- RDD
- Annotations
- @Since("1.6.0")
- def getOutputDeterministicLevel: rdd.DeterministicLevel.Value
- Attributes
- protected
- Definition Classes
- RDD
- Annotations
- @DeveloperApi()
- def getPartitions: Array[Partition]
- Attributes
- protected
- Definition Classes
- EdgeRDD → RDD
- def getPreferredLocations(split: Partition): Seq[String]
- Attributes
- protected
- Definition Classes
- RDD
- def getResourceProfile(): ResourceProfile
- Definition Classes
- RDD
- Annotations
- @Experimental() @Since("3.1.0")
- def getStorageLevel: StorageLevel
- Definition Classes
- EdgeRDDImpl → RDD
- def glom(): RDD[Array[Edge[ED]]]
- Definition Classes
- RDD
- def groupBy[K](f: (Edge[ED]) => K, p: Partitioner)(implicit kt: ClassTag[K], ord: Ordering[K]): RDD[(K, Iterable[Edge[ED]])]
- Definition Classes
- RDD
- def groupBy[K](f: (Edge[ED]) => K, numPartitions: Int)(implicit kt: ClassTag[K]): RDD[(K, Iterable[Edge[ED]])]
- Definition Classes
- RDD
- def groupBy[K](f: (Edge[ED]) => K)(implicit kt: ClassTag[K]): RDD[(K, Iterable[Edge[ED]])]
- Definition Classes
- RDD
- def hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- val id: Int
- Definition Classes
- RDD
- def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
- Attributes
- protected
- Definition Classes
- Logging
- def initializeLogIfNecessary(isInterpreter: Boolean): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def innerJoin[ED2, ED3](other: EdgeRDD[ED2])(f: (VertexId, VertexId, ED, ED2) => ED3)(implicit arg0: ClassTag[ED2], arg1: ClassTag[ED3]): EdgeRDDImpl[ED3, VD]
Inner joins this EdgeRDD with another EdgeRDD, assuming both are partitioned using the same PartitionStrategy.
Inner joins this EdgeRDD with another EdgeRDD, assuming both are partitioned using the same PartitionStrategy.
- other
the EdgeRDD to join with
- f
the join function applied to corresponding values of
this
andother
- returns
a new EdgeRDD containing only edges that appear in both
this
andother
, with values supplied byf
- Definition Classes
- EdgeRDDImpl → EdgeRDD
- def intersection(other: RDD[Edge[ED]], numPartitions: Int): RDD[Edge[ED]]
- Definition Classes
- RDD
- def intersection(other: RDD[Edge[ED]], partitioner: Partitioner)(implicit ord: Ordering[Edge[ED]]): RDD[Edge[ED]]
- Definition Classes
- RDD
- def intersection(other: RDD[Edge[ED]]): RDD[Edge[ED]]
- Definition Classes
- RDD
- lazy val isBarrier_: Boolean
- Attributes
- protected
- Definition Classes
- RDD
- Annotations
- @transient()
- def isCheckpointed: Boolean
- Definition Classes
- EdgeRDDImpl → RDD
- def isEmpty(): Boolean
- Definition Classes
- RDD
- final def isInstanceOf[T0]: Boolean
- Definition Classes
- Any
- def isTraceEnabled(): Boolean
- Attributes
- protected
- Definition Classes
- Logging
- final def iterator(split: Partition, context: TaskContext): Iterator[Edge[ED]]
- Definition Classes
- RDD
- def keyBy[K](f: (Edge[ED]) => K): RDD[(K, Edge[ED])]
- Definition Classes
- RDD
- def localCheckpoint(): EdgeRDDImpl.this.type
- Definition Classes
- RDD
- def log: Logger
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(entry: LogEntry): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logError(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logError(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logError(entry: LogEntry): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logError(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logInfo(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logInfo(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logInfo(entry: LogEntry): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logInfo(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logName: String
- Attributes
- protected
- Definition Classes
- Logging
- def logTrace(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logTrace(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logTrace(entry: LogEntry): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logTrace(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(entry: LogEntry, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(entry: LogEntry): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def map[U](f: (Edge[ED]) => U)(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- def mapEdgePartitions[ED2, VD2](f: (PartitionID, EdgePartition[ED, VD]) => EdgePartition[ED2, VD2])(implicit arg0: ClassTag[ED2], arg1: ClassTag[VD2]): EdgeRDDImpl[ED2, VD2]
- def mapPartitions[U](f: (Iterator[Edge[ED]]) => Iterator[U], preservesPartitioning: Boolean)(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- def mapPartitionsWithEvaluator[U](evaluatorFactory: PartitionEvaluatorFactory[Edge[ED], U])(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- Annotations
- @DeveloperApi() @Since("3.5.0")
- def mapPartitionsWithIndex[U](f: (Int, Iterator[Edge[ED]]) => Iterator[U], preservesPartitioning: Boolean)(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- def mapValues[ED2](f: (Edge[ED]) => ED2)(implicit arg0: ClassTag[ED2]): EdgeRDDImpl[ED2, VD]
Map the values in an edge partitioning preserving the structure but changing the values.
Map the values in an edge partitioning preserving the structure but changing the values.
- ED2
the new edge value type
- f
the function from an edge to a new edge value
- returns
a new EdgeRDD containing the new edge values
- Definition Classes
- EdgeRDDImpl → EdgeRDD
- def max()(implicit ord: Ordering[Edge[ED]]): Edge[ED]
- Definition Classes
- RDD
- def min()(implicit ord: Ordering[Edge[ED]]): Edge[ED]
- Definition Classes
- RDD
- var name: String
- Definition Classes
- RDD
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- def parent[U](j: Int)(implicit arg0: ClassTag[U]): RDD[U]
- Attributes
- protected[spark]
- Definition Classes
- RDD
- val partitioner: Option[Partitioner]
If
partitionsRDD
already has a partitioner, use it.If
partitionsRDD
already has a partitioner, use it. Otherwise assume that thePartitionID
s inpartitionsRDD
correspond to the actual partitions and create a new partitioner that allows co-partitioning withpartitionsRDD
.- Definition Classes
- EdgeRDDImpl → RDD
- final def partitions: Array[Partition]
- Definition Classes
- RDD
- val partitionsRDD: RDD[(PartitionID, EdgePartition[ED, VD])]
- Definition Classes
- EdgeRDDImpl → EdgeRDD
- def persist(newLevel: StorageLevel): EdgeRDDImpl.this.type
Persists the edge partitions at the specified storage level, ignoring any existing target storage level.
Persists the edge partitions at the specified storage level, ignoring any existing target storage level.
- Definition Classes
- EdgeRDDImpl → RDD
- def persist(): EdgeRDDImpl.this.type
- Definition Classes
- RDD
- def pipe(command: Seq[String], env: Map[String, String], printPipeContext: ((String) => Unit) => Unit, printRDDElement: (Edge[ED], (String) => Unit) => Unit, separateWorkingDir: Boolean, bufferSize: Int, encoding: String): RDD[String]
- Definition Classes
- RDD
- def pipe(command: String, env: Map[String, String]): RDD[String]
- Definition Classes
- RDD
- def pipe(command: String): RDD[String]
- Definition Classes
- RDD
- final def preferredLocations(split: Partition): Seq[String]
- Definition Classes
- RDD
- def randomSplit(weights: Array[Double], seed: Long): Array[RDD[Edge[ED]]]
- Definition Classes
- RDD
- def reduce(f: (Edge[ED], Edge[ED]) => Edge[ED]): Edge[ED]
- Definition Classes
- RDD
- def repartition(numPartitions: Int)(implicit ord: Ordering[Edge[ED]]): RDD[Edge[ED]]
- Definition Classes
- RDD
- def reverse: EdgeRDDImpl[ED, VD]
Reverse all the edges in this RDD.
Reverse all the edges in this RDD.
- returns
a new EdgeRDD containing all the edges reversed
- Definition Classes
- EdgeRDDImpl → EdgeRDD
- def sample(withReplacement: Boolean, fraction: Double, seed: Long): RDD[Edge[ED]]
- Definition Classes
- RDD
- def saveAsObjectFile(path: String): Unit
- Definition Classes
- RDD
- def saveAsTextFile(path: String, codec: Class[_ <: CompressionCodec]): Unit
- Definition Classes
- RDD
- def saveAsTextFile(path: String): Unit
- Definition Classes
- RDD
- def setName(_name: String): EdgeRDDImpl.this.type
- Definition Classes
- EdgeRDDImpl → RDD
- def sortBy[K](f: (Edge[ED]) => K, ascending: Boolean, numPartitions: Int)(implicit ord: Ordering[K], ctag: ClassTag[K]): RDD[Edge[ED]]
- Definition Classes
- RDD
- def sparkContext: SparkContext
- Definition Classes
- RDD
- def subtract(other: RDD[Edge[ED]], p: Partitioner)(implicit ord: Ordering[Edge[ED]]): RDD[Edge[ED]]
- Definition Classes
- RDD
- def subtract(other: RDD[Edge[ED]], numPartitions: Int): RDD[Edge[ED]]
- Definition Classes
- RDD
- def subtract(other: RDD[Edge[ED]]): RDD[Edge[ED]]
- Definition Classes
- RDD
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- def take(num: Int): Array[Edge[ED]]
- Definition Classes
- RDD
- def takeOrdered(num: Int)(implicit ord: Ordering[Edge[ED]]): Array[Edge[ED]]
- Definition Classes
- RDD
- def takeSample(withReplacement: Boolean, num: Int, seed: Long): Array[Edge[ED]]
- Definition Classes
- RDD
- val targetStorageLevel: StorageLevel
- def toDebugString: String
- Definition Classes
- RDD
- def toJavaRDD(): JavaRDD[Edge[ED]]
- Definition Classes
- RDD
- def toLocalIterator: Iterator[Edge[ED]]
- Definition Classes
- RDD
- def toString(): String
- Definition Classes
- RDD → AnyRef → Any
- def top(num: Int)(implicit ord: Ordering[Edge[ED]]): Array[Edge[ED]]
- Definition Classes
- RDD
- def treeAggregate[U](zeroValue: U, seqOp: (U, Edge[ED]) => U, combOp: (U, U) => U, depth: Int, finalAggregateOnExecutor: Boolean)(implicit arg0: ClassTag[U]): U
- Definition Classes
- RDD
- def treeAggregate[U](zeroValue: U)(seqOp: (U, Edge[ED]) => U, combOp: (U, U) => U, depth: Int)(implicit arg0: ClassTag[U]): U
- Definition Classes
- RDD
- def treeReduce(f: (Edge[ED], Edge[ED]) => Edge[ED], depth: Int): Edge[ED]
- Definition Classes
- RDD
- def union(other: RDD[Edge[ED]]): RDD[Edge[ED]]
- Definition Classes
- RDD
- def unpersist(blocking: Boolean = false): EdgeRDDImpl.this.type
- Definition Classes
- EdgeRDDImpl → RDD
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- def withLogContext(context: Map[String, String])(body: => Unit): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def withResources(rp: ResourceProfile): EdgeRDDImpl.this.type
- Definition Classes
- RDD
- Annotations
- @Experimental() @Since("3.1.0")
- def zip[U](other: RDD[U])(implicit arg0: ClassTag[U]): RDD[(Edge[ED], U)]
- Definition Classes
- RDD
- def zipPartitions[B, C, D, V](rdd2: RDD[B], rdd3: RDD[C], rdd4: RDD[D])(f: (Iterator[Edge[ED]], Iterator[B], Iterator[C], Iterator[D]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[D], arg3: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitions[B, C, D, V](rdd2: RDD[B], rdd3: RDD[C], rdd4: RDD[D], preservesPartitioning: Boolean)(f: (Iterator[Edge[ED]], Iterator[B], Iterator[C], Iterator[D]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[D], arg3: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitions[B, C, V](rdd2: RDD[B], rdd3: RDD[C])(f: (Iterator[Edge[ED]], Iterator[B], Iterator[C]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitions[B, C, V](rdd2: RDD[B], rdd3: RDD[C], preservesPartitioning: Boolean)(f: (Iterator[Edge[ED]], Iterator[B], Iterator[C]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitions[B, V](rdd2: RDD[B])(f: (Iterator[Edge[ED]], Iterator[B]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitions[B, V](rdd2: RDD[B], preservesPartitioning: Boolean)(f: (Iterator[Edge[ED]], Iterator[B]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitionsWithEvaluator[U](rdd2: RDD[Edge[ED]], evaluatorFactory: PartitionEvaluatorFactory[Edge[ED], U])(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- Annotations
- @DeveloperApi() @Since("3.5.0")
- def zipWithIndex(): RDD[(Edge[ED], Long)]
- Definition Classes
- RDD
- def zipWithUniqueId(): RDD[(Edge[ED], Long)]
- Definition Classes
- RDD
Deprecated Value Members
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable]) @Deprecated
- Deprecated
(Since version 9)