Package org.apache.spark.status
Class RDDPartitionSeq
Object
org.apache.spark.status.RDDPartitionSeq
- All Implemented Interfaces:
scala.collection.generic.FilterMonadic<RDDPartitionInfo,,scala.collection.Traversable<RDDPartitionInfo>> scala.collection.generic.GenericTraversableTemplate<RDDPartitionInfo,,scala.collection.GenTraversable> scala.collection.generic.HasNewBuilder<RDDPartitionInfo,,scala.collection.Traversable<RDDPartitionInfo>> scala.collection.GenIterable<RDDPartitionInfo>,scala.collection.GenIterableLike<RDDPartitionInfo,,scala.collection.GenIterable<RDDPartitionInfo>> scala.collection.GenSeq<RDDPartitionInfo>,scala.collection.GenSeqLike<RDDPartitionInfo,,scala.collection.GenSeq<RDDPartitionInfo>> scala.collection.GenTraversable<RDDPartitionInfo>,scala.collection.GenTraversableLike<RDDPartitionInfo,,scala.collection.Traversable<RDDPartitionInfo>> scala.collection.GenTraversableOnce<RDDPartitionInfo>,scala.collection.Iterable<RDDPartitionInfo>,scala.collection.IterableLike<RDDPartitionInfo,,scala.collection.Iterable<RDDPartitionInfo>> scala.collection.Parallelizable<RDDPartitionInfo,,scala.collection.parallel.ParIterable<RDDPartitionInfo>> scala.collection.Seq<RDDPartitionInfo>,scala.collection.SeqLike<RDDPartitionInfo,,scala.collection.Seq<RDDPartitionInfo>> scala.collection.Traversable<RDDPartitionInfo>,scala.collection.TraversableLike<RDDPartitionInfo,,scala.collection.Traversable<RDDPartitionInfo>> scala.collection.TraversableOnce<RDDPartitionInfo>,scala.Equals,scala.Function1<Object,,RDDPartitionInfo> scala.PartialFunction<Object,RDDPartitionInfo>
A custom sequence of partitions based on a mutable linked list.
The external interface is an immutable Seq, which is thread-safe for traversal. There are no guarantees about consistency though - iteration might return elements that have been removed or miss added elements.
Internally, the sequence is mutable, and elements can modify the data they expose. Additions and removals are O(1). It is not safe to do multiple writes concurrently.
-
Nested Class Summary
Nested classes/interfaces inherited from interface scala.collection.TraversableLike
scala.collection.TraversableLike.WithFilterNested classes/interfaces inherited from interface scala.collection.TraversableOnce
scala.collection.TraversableOnce.BufferedCanBuildFrom<A extends Object,CC extends scala.collection.TraversableOnce<Object>>, scala.collection.TraversableOnce.FlattenOps<A extends Object>, scala.collection.TraversableOnce.ForceImplicitAmbiguity, scala.collection.TraversableOnce.MonadOps<A extends Object>, scala.collection.TraversableOnce.OnceCanBuildFrom<A extends Object> -
Constructor Summary
Constructors -
Method Summary
Modifier and TypeMethodDescriptionvoidaddPartition(LiveRDDPartition part) apply(int idx) intcount()scala.collection.Iterator<RDDPartitionInfo>iterator()intlength()voidMethods inherited from class java.lang.Object
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, waitMethods inherited from interface scala.Function1
apply, apply$mcDD$sp, apply$mcDF$sp, apply$mcDI$sp, apply$mcDJ$sp, apply$mcFD$sp, apply$mcFF$sp, apply$mcFI$sp, apply$mcFJ$sp, apply$mcID$sp, apply$mcIF$sp, apply$mcII$sp, apply$mcIJ$sp, apply$mcJD$sp, apply$mcJF$sp, apply$mcJI$sp, apply$mcJJ$sp, apply$mcVD$sp, apply$mcVF$sp, apply$mcVI$sp, apply$mcVJ$sp, apply$mcZD$sp, apply$mcZF$sp, apply$mcZI$sp, apply$mcZJ$sp, compose, toStringMethods inherited from interface scala.collection.generic.GenericTraversableTemplate
flatten, foreach, genericBuilder, head, isEmpty, newBuilder, transpose, unzip, unzip3Methods inherited from interface scala.collection.GenSeqLike
equals, hashCode, indexOf, indexOf, indexWhere, isDefinedAt, lastIndexOf, lastIndexOf, lastIndexWhere, prefixLength, startsWith, toSeqMethods inherited from interface scala.collection.GenTraversableLike
flatMap, foreach, map, sizeMethods inherited from interface scala.collection.GenTraversableOnce
sizeHintIfCheapMethods inherited from interface scala.collection.IterableLike
canEqual, copyToArray, drop, dropRight, exists, find, foldRight, forall, foreach, grouped, head, reduceRight, sameElements, slice, sliding, sliding, take, takeRight, takeWhile, toIterable, toIterator, toStream, zip, zipAll, zipWithIndexMethods inherited from interface scala.collection.Parallelizable
parMethods inherited from interface scala.PartialFunction
andThen, applyOrElse, isDefinedAt, lift, orElse, runWithMethods inherited from interface scala.collection.Seq
companion, seqMethods inherited from interface scala.collection.SeqLike
$colon$plus, $plus$colon, combinations, contains, containsSlice, corresponds, diff, distinct, endsWith, indexOfSlice, indexOfSlice, indexWhere, indices, intersect, isEmpty, lastIndexOfSlice, lastIndexOfSlice, lastIndexWhere, lengthCompare, padTo, parCombiner, patch, permutations, reverse, reverseIterator, reverseMap, segmentLength, size, sortBy, sorted, sortWith, startsWith, thisCollection, toCollection, toSeq, toString, union, updated, view, viewMethods inherited from interface scala.collection.TraversableLike
$plus$plus, $plus$plus$colon, $plus$plus$colon, collect, dropWhile, filter, filterImpl, filterNot, flatMap, groupBy, hasDefiniteSize, headOption, init, inits, isTraversableAgain, last, lastOption, map, newBuilder, partition, repr, scan, scanLeft, scanRight, sliceWithKnownBound, sliceWithKnownDelta, span, splitAt, stringPrefix, tail, tails, to, toTraversable, withFilterMethods inherited from interface scala.collection.TraversableOnce
$colon$bslash, $div$colon, addString, addString, addString, aggregate, collectFirst, copyToArray, copyToArray, copyToBuffer, count, fold, foldLeft, max, maxBy, min, minBy, mkString, mkString, mkString, nonEmpty, product, reduce, reduceLeft, reduceLeftOption, reduceOption, reduceRightOption, reversed, sum, toArray, toBuffer, toIndexedSeq, toList, toMap, toSet, toVector
-
Constructor Details
-
RDDPartitionSeq
public RDDPartitionSeq()
-
-
Method Details
-
addPartition
-
apply
- Specified by:
applyin interfacescala.collection.GenSeqLike<RDDPartitionInfo,scala.collection.GenSeq<RDDPartitionInfo>> - Specified by:
applyin interfacescala.collection.SeqLike<RDDPartitionInfo,scala.collection.Seq<RDDPartitionInfo>>
-
count
public int count() -
iterator
- Specified by:
iteratorin interfacescala.collection.GenIterableLike<RDDPartitionInfo,scala.collection.GenIterable<RDDPartitionInfo>> - Specified by:
iteratorin interfacescala.collection.IterableLike<RDDPartitionInfo,scala.collection.Iterable<RDDPartitionInfo>>
-
length
public int length()- Specified by:
lengthin interfacescala.collection.GenSeqLike<RDDPartitionInfo,scala.collection.GenSeq<RDDPartitionInfo>> - Specified by:
lengthin interfacescala.collection.SeqLike<RDDPartitionInfo,scala.collection.Seq<RDDPartitionInfo>>
-
removePartition
-