Packages

  • package root
    Definition Classes
    root
  • package scala
    Definition Classes
    root
  • package collection
    Definition Classes
    scala
  • package parallel

    Package object for parallel collections.

    Package object for parallel collections.

    Definition Classes
    collection
  • package immutable
    Definition Classes
    parallel
  • class ParRange extends ParSeq[Int] with Serializable

    Parallel ranges.

    Parallel ranges.

    This is a base trait for Scala parallel collections. It defines behaviour common to all parallel collections. Concrete parallel collections should inherit this trait and ParIterable if they want to define specific combiner factories.

    Parallel operations are implemented with divide and conquer style algorithms that parallelize well. The basic idea is to split the collection into smaller parts until they are small enough to be operated on sequentially.

    All of the parallel operations are implemented as tasks within this trait. Tasks rely on the concept of splitters, which extend iterators. Every parallel collection defines:

    def splitter: IterableSplitter[T]

    which returns an instance of IterableSplitter[T], which is a subtype of Splitter[T]. Splitters have a method remaining to check the remaining number of elements, and method split which is defined by splitters. Method split divides the splitters iterate over into disjunct subsets:

    def split: Seq[Splitter]

    which splits the splitter into a sequence of disjunct subsplitters. This is typically a very fast operation which simply creates wrappers around the receiver collection. This can be repeated recursively.

    Tasks are scheduled for execution through a scala.collection.parallel.TaskSupport object, which can be changed through the tasksupport setter of the collection.

    Method newCombiner produces a new combiner. Combiners are an extension of builders. They provide a method combine which combines two combiners and returns a combiner containing elements of both combiners. This method can be implemented by aggressively copying all the elements into the new combiner or by lazily binding their results. It is recommended to avoid copying all of the elements for performance reasons, although that cost might be negligible depending on the use case. Standard parallel collection combiners avoid copying when merging results, relying either on a two-step lazy construction or specific data-structure properties.

    Methods:

    def seq: Sequential
    def par: Repr

    produce the sequential or parallel implementation of the collection, respectively. Method par just returns a reference to this parallel collection. Method seq is efficient - it will not copy the elements. Instead, it will create a sequential version of the collection using the same underlying data structure. Note that this is not the case for sequential collections in general - they may copy the elements and produce a different underlying data structure.

    The combination of methods toMap, toSeq or toSet along with par and seq is a flexible way to change between different collection types.

    Since this trait extends the GenIterable trait, methods like size must also be implemented in concrete collections, while iterator forwards to splitter by default.

    Each parallel collection is bound to a specific fork/join pool, on which dormant worker threads are kept. The fork/join pool contains other information such as the parallelism level, that is, the number of processors used. When a collection is created, it is assigned the default fork/join pool found in the scala.parallel package object.

    Parallel collections are not necessarily ordered in terms of the foreach operation (see Traversable). Parallel sequences have a well defined order for iterators - creating an iterator and traversing the elements linearly will always yield the same order. However, bulk operations such as foreach, map or filter always occur in undefined orders for all parallel collections.

    Existing parallel collection implementations provide strict parallel iterators. Strict parallel iterators are aware of the number of elements they have yet to traverse. It's also possible to provide non-strict parallel iterators, which do not know the number of elements remaining. To do this, the new collection implementation must override isStrictSplitterCollection to false. This will make some operations unavailable.

    To create a new parallel collection, extend the ParIterable trait, and implement size, splitter, newCombiner and seq. Having an implicit combiner factory requires extending this trait in addition, as well as providing a companion object, as with regular collections.

    Method size is implemented as a constant time operation for parallel collections, and parallel collection operations rely on this assumption.

    The higher-order functions passed to certain operations may contain side-effects. Since implementations of bulk operations may not be sequential, this means that side-effects may not be predictable and may produce data-races, deadlocks or invalidation of state if care is not taken. It is up to the programmer to either avoid using side-effects or to use some form of synchronization when accessing mutable data.

    Definition Classes
    immutable
    Annotations
    @SerialVersionUID()
    Since

    2.9

    See also

    Scala's Parallel Collections Library overview section on ParRange for more information.

  • Accessor
  • Aggregate
  • BuilderOps
  • Collect
  • Composite
  • Copy
  • CopyToArray
  • Corresponds
  • Count
  • CreateScanTree
  • Drop
  • Elements
  • Exists
  • Filter
  • FilterNot
  • Find
  • FlatMap
  • Fold
  • Forall
  • Foreach
  • FromScanTree
  • GroupBy
  • IndexWhere
  • LastIndexWhere
  • Map
  • Max
  • Min
  • NonDivisible
  • NonDivisibleTask
  • ParComposite
  • ParRangeIterator
  • Partition
  • Product
  • Reduce
  • ResultMapping
  • Reverse
  • ReverseMap
  • SameElements
  • ScanLeaf
  • ScanNode
  • ScanTree
  • SegmentLength
  • SeqComposite
  • SignallingOps
  • Slice
  • Span
  • SplitAt
  • StrictSplitterCheckTask
  • Sum
  • Take
  • TakeWhile
  • TaskOps
  • ToParCollection
  • ToParMap
  • Transformer
  • Updated
  • Zip
  • ZipAll

class ParRangeIterator extends SeqSplitter[Int]

Linear Supertypes
SeqSplitter[Int], PreciseSplitter[Int], AugmentedSeqIterator[Int], IterableSplitter[Int], DelegatedSignalling, Signalling, Splitter[Int], AugmentedIterableIterator[Int], RemainsIterator[Int], Iterator[Int], TraversableOnce[Int], GenTraversableOnce[Int], AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ParRangeIterator
  2. SeqSplitter
  3. PreciseSplitter
  4. AugmentedSeqIterator
  5. IterableSplitter
  6. DelegatedSignalling
  7. Signalling
  8. Splitter
  9. AugmentedIterableIterator
  10. RemainsIterator
  11. Iterator
  12. TraversableOnce
  13. GenTraversableOnce
  14. AnyRef
  15. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ParRangeIterator(range: immutable.Range = self.range)

Type Members

  1. class Appended [U >: T, PI <: SeqSplitter[U]] extends SeqSplitter.Appended[U, PI] with SeqSplitter[U]
    Definition Classes
    SeqSplitter
  2. class Mapped [S] extends SeqSplitter.Mapped[S] with SeqSplitter[S]
    Definition Classes
    SeqSplitter
  3. class Patched [U >: T] extends SeqSplitter[U]
    Definition Classes
    SeqSplitter
  4. class Taken extends SeqSplitter.Taken with SeqSplitter[T]
    Definition Classes
    SeqSplitter
  5. class Zipped [S] extends SeqSplitter.Zipped[S] with SeqSplitter[(T, S)]
    Definition Classes
    SeqSplitter
  6. class ZippedAll [U >: T, S] extends SeqSplitter.ZippedAll[U, S] with SeqSplitter[(U, S)]
    Definition Classes
    SeqSplitter
  7. class GroupedIterator[B >: A] extends AbstractIterator[Seq[B]] with Iterator[Seq[B]]
    Definition Classes
    Iterator

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. def ++[B >: Int](that: ⇒ GenTraversableOnce[B]): Iterator[B]
    Definition Classes
    Iterator
  4. def /:[B](z: B)(op: (B, Int) ⇒ B): B
    Definition Classes
    TraversableOnce → GenTraversableOnce
  5. def :\[B](z: B)(op: (Int, B) ⇒ B): B
    Definition Classes
    TraversableOnce → GenTraversableOnce
  6. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  7. def abort(): Unit
    Definition Classes
    DelegatedSignalling → Signalling
  8. def addString(b: StringBuilder): StringBuilder
    Definition Classes
    TraversableOnce
  9. def addString(b: StringBuilder, sep: String): StringBuilder
    Definition Classes
    TraversableOnce
  10. def addString(b: StringBuilder, start: String, sep: String, end: String): StringBuilder
    Definition Classes
    TraversableOnce
  11. def aggregate[B](z: ⇒ B)(seqop: (B, Int) ⇒ B, combop: (B, B) ⇒ B): B
    Definition Classes
    TraversableOnce → GenTraversableOnce
  12. def appendParIterable[U >: Int, PI <: IterableSplitter[U]](that: PI): ParRangeIterator.Appended[U, PI]
    Definition Classes
    IterableSplitter
  13. def appendParSeq[U >: Int, PI <: SeqSplitter[U]](that: PI): Appended[U, PI]
    Definition Classes
    SeqSplitter
  14. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  15. def buffered: BufferedIterator[Int]
    Definition Classes
    Iterator
  16. def buildString(closure: ((String) ⇒ Unit) ⇒ Unit): String
    Attributes
    protected
    Definition Classes
    IterableSplitter
  17. def clone(): AnyRef
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  18. def collect[B](pf: PartialFunction[Int, B]): Iterator[B]
    Definition Classes
    Iterator
    Annotations
    @migration
    Migration

    (Changed in version 2.8.0) collect has changed. The previous behavior can be reproduced with toSeq.

  19. def collect2combiner[S, That](pf: PartialFunction[Int, S], cb: Combiner[S, That]): Combiner[S, That]
    Definition Classes
    AugmentedIterableIterator
  20. def collectFirst[B](pf: PartialFunction[Int, B]): Option[B]
    Definition Classes
    TraversableOnce
  21. def contains(elem: Any): Boolean
    Definition Classes
    Iterator
  22. def copy2builder[U >: Int, Coll, Bld <: Builder[U, Coll]](b: Bld): Bld
    Definition Classes
    AugmentedIterableIterator
  23. def copyToArray[U >: Int](array: Array[U], from: Int, len: Int): Unit
    Definition Classes
    AugmentedIterableIterator → Iterator → TraversableOnce → GenTraversableOnce
  24. def copyToArray[B >: Int](xs: Array[B]): Unit
    Definition Classes
    TraversableOnce → GenTraversableOnce
  25. def copyToArray[B >: Int](xs: Array[B], start: Int): Unit
    Definition Classes
    TraversableOnce → GenTraversableOnce
  26. def copyToBuffer[B >: Int](dest: Buffer[B]): Unit
    Definition Classes
    TraversableOnce
  27. def corresponds[S](corr: (Int, S) ⇒ Boolean)(that: scala.Iterator[S]): Boolean
    Definition Classes
    AugmentedSeqIterator
  28. def corresponds[B](that: GenTraversableOnce[B])(p: (Int, B) ⇒ Boolean): Boolean
    Definition Classes
    Iterator
  29. def count(p: (Int) ⇒ Boolean): Int
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  30. def drop(n: Int): IterableSplitter[Int]

    Drop implemented as simple eager consumption.

    Drop implemented as simple eager consumption.

    Definition Classes
    IterableSplitter → Iterator
  31. def drop2combiner[U >: Int, This](n: Int, cb: Combiner[U, This]): Combiner[U, This]
    Definition Classes
    AugmentedIterableIterator
  32. def dropWhile(p: (Int) ⇒ Boolean): Iterator[Int]
    Definition Classes
    Iterator
  33. def dup: ParRangeIterator

    Creates a copy of this iterator.

    Creates a copy of this iterator.

    Definition Classes
    ParRangeIteratorSeqSplitterIterableSplitter
  34. def duplicate: (Iterator[Int], Iterator[Int])
    Definition Classes
    Iterator
  35. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  36. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  37. def exists(p: (Int) ⇒ Boolean): Boolean
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  38. def filter(p: (Int) ⇒ Boolean): Iterator[Int]
    Definition Classes
    Iterator
  39. def filter2combiner[U >: Int, This](pred: (Int) ⇒ Boolean, cb: Combiner[U, This]): Combiner[U, This]
    Definition Classes
    AugmentedIterableIterator
  40. def filterNot(p: (Int) ⇒ Boolean): Iterator[Int]
    Definition Classes
    Iterator
  41. def filterNot2combiner[U >: Int, This](pred: (Int) ⇒ Boolean, cb: Combiner[U, This]): Combiner[U, This]
    Definition Classes
    AugmentedIterableIterator
  42. def finalize(): Unit
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  43. def find(p: (Int) ⇒ Boolean): Option[Int]
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  44. def flatMap[B](f: (Int) ⇒ GenTraversableOnce[B]): Iterator[B]
    Definition Classes
    Iterator
  45. def flatmap2combiner[S, That](f: (Int) ⇒ GenTraversableOnce[S], cb: Combiner[S, That]): Combiner[S, That]
    Definition Classes
    AugmentedIterableIterator
  46. def fold[U >: Int](z: U)(op: (U, U) ⇒ U): U
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  47. def foldLeft[B](z: B)(op: (B, Int) ⇒ B): B
    Definition Classes
    TraversableOnce → GenTraversableOnce
  48. def foldRight[B](z: B)(op: (Int, B) ⇒ B): B
    Definition Classes
    TraversableOnce → GenTraversableOnce
  49. def forall(p: (Int) ⇒ Boolean): Boolean
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  50. def foreach[U](f: (Int) ⇒ U): Unit
    Definition Classes
    ParRangeIterator → Iterator → GenTraversableOnce
  51. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
  52. def grouped[B >: Int](size: Int): GroupedIterator[B]
    Definition Classes
    Iterator
  53. def hasDefiniteSize: Boolean
    Definition Classes
    Iterator → GenTraversableOnce
  54. final def hasNext: Boolean
    Definition Classes
    ParRangeIterator → Iterator
  55. def hashCode(): Int
    Definition Classes
    AnyRef → Any
  56. def indexFlag: Int
    Definition Classes
    DelegatedSignalling → Signalling
  57. def indexOf[B >: Int](elem: B, from: Int): Int
    Definition Classes
    Iterator
  58. def indexOf[B >: Int](elem: B): Int
    Definition Classes
    Iterator
  59. def indexWhere(pred: (Int) ⇒ Boolean): Int
    Definition Classes
    AugmentedSeqIterator → Iterator
  60. def indexWhere(p: (Int) ⇒ Boolean, from: Int): Int
    Definition Classes
    Iterator
  61. def isAborted: Boolean
    Definition Classes
    DelegatedSignalling → Signalling
  62. def isEmpty: Boolean
    Definition Classes
    Iterator → GenTraversableOnce
  63. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  64. def isRemainingCheap: Boolean

    For most collections, this is a cheap operation.

    For most collections, this is a cheap operation. Exceptions can override this method.

    Definition Classes
    RemainsIterator
  65. def isTraversableAgain: Boolean
    Definition Classes
    Iterator → GenTraversableOnce
  66. def lastIndexWhere(pred: (Int) ⇒ Boolean): Int
    Definition Classes
    AugmentedSeqIterator
  67. def length: Int
    Definition Classes
    Iterator
  68. def map[S](f: (Int) ⇒ S): Mapped[S]
    Definition Classes
    SeqSplitterIterableSplitter → Iterator
  69. def map2combiner[S, That](f: (Int) ⇒ S, cb: Combiner[S, That]): Combiner[S, That]
    Definition Classes
    ParRangeIterator → AugmentedIterableIterator
  70. def max[U >: Int](implicit ord: Ordering[U]): Int
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  71. def maxBy[B](f: (Int) ⇒ B)(implicit cmp: Ordering[B]): Int
    Definition Classes
    TraversableOnce → GenTraversableOnce
  72. def min[U >: Int](implicit ord: Ordering[U]): Int
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  73. def minBy[B](f: (Int) ⇒ B)(implicit cmp: Ordering[B]): Int
    Definition Classes
    TraversableOnce → GenTraversableOnce
  74. def mkString: String
    Definition Classes
    TraversableOnce → GenTraversableOnce
  75. def mkString(sep: String): String
    Definition Classes
    TraversableOnce → GenTraversableOnce
  76. def mkString(start: String, sep: String, end: String): String
    Definition Classes
    TraversableOnce → GenTraversableOnce
  77. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  78. final def next(): Int
    Definition Classes
    ParRangeIterator → Iterator
  79. def nonEmpty: Boolean
    Definition Classes
    TraversableOnce → GenTraversableOnce
  80. final def notify(): Unit
    Definition Classes
    AnyRef
  81. final def notifyAll(): Unit
    Definition Classes
    AnyRef
  82. def padTo[A1 >: Int](len: Int, elem: A1): Iterator[A1]
    Definition Classes
    Iterator
  83. def partition(p: (Int) ⇒ Boolean): (Iterator[Int], Iterator[Int])
    Definition Classes
    Iterator
  84. def partition2combiners[U >: Int, This](pred: (Int) ⇒ Boolean, btrue: Combiner[U, This], bfalse: Combiner[U, This]): (Combiner[U, This], Combiner[U, This])
    Definition Classes
    AugmentedIterableIterator
  85. def patch[B >: Int](from: Int, patchElems: Iterator[B], replaced: Int): Iterator[B]
    Definition Classes
    Iterator
  86. def patchParSeq[U >: Int](from: Int, patchElems: SeqSplitter[U], replaced: Int): Patched[U]
    Definition Classes
    SeqSplitter
  87. def prefixLength(pred: (Int) ⇒ Boolean): Int
    Definition Classes
    AugmentedSeqIterator
  88. def product[U >: Int](implicit num: Numeric[U]): U
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  89. def psplit(sizes: Int*): scala.Seq[SeqSplitter[Int]]

    Splits the splitter into disjunct views.

    Splits the splitter into disjunct views.

    This overloaded version of the split method is specific to precise splitters. It returns a sequence of splitters, each iterating some subset of the elements in this splitter. The sizes of the subsplitters in the partition is equal to the size in the corresponding argument, as long as there are enough elements in this splitter to split it that way.

    If there aren't enough elements, a zero element splitter is appended for each additional argument. If there are additional elements, an additional splitter is appended at the end to compensate.

    For example, say we have a splitter ps with 100 elements. Invoking:

    ps.split(50, 25, 25, 10, 5)

    will return a sequence of five splitters, last two views being empty. On the other hand, calling:

    ps.split(50, 40)

    will return a sequence of three splitters, last of them containing ten elements.

    Note: this method actually invalidates the current splitter.

    Unlike the case with split found in splitters, views returned by this method can be empty.

    sizes

    the sizes used to split this split iterator into iterators that traverse disjunct subsets

    returns

    a sequence of disjunct subsequence iterators of this parallel iterator

    Definition Classes
    ParRangeIteratorSeqSplitterPreciseSplitter
  90. def psplitWithSignalling(sizes: Int*): scala.Seq[SeqSplitter[Int]]
    Definition Classes
    SeqSplitter
  91. def reduce[U >: Int](op: (U, U) ⇒ U): U
    Definition Classes
    ParRangeIterator → AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  92. def reduceLeft[U >: Int](howmany: Int, op: (U, U) ⇒ U): U
    Definition Classes
    AugmentedIterableIterator
  93. def reduceLeft[B >: Int](op: (B, Int) ⇒ B): B
    Definition Classes
    TraversableOnce
  94. def reduceLeftOption[B >: Int](op: (B, Int) ⇒ B): Option[B]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  95. def reduceOption[A1 >: Int](op: (A1, A1) ⇒ A1): Option[A1]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  96. def reduceRight[B >: Int](op: (Int, B) ⇒ B): B
    Definition Classes
    TraversableOnce → GenTraversableOnce
  97. def reduceRightOption[B >: Int](op: (Int, B) ⇒ B): Option[B]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  98. final def remaining: Int

    The number of elements this iterator has yet to traverse.

    The number of elements this iterator has yet to traverse. This method doesn't change the state of the iterator. Unlike the version of this method in the supertrait, method remaining in ParSeqLike.this.ParIterator must return an exact number of elements remaining in the iterator.

    returns

    an exact number of elements this iterator has yet to iterate

    Definition Classes
    ParRangeIteratorSeqSplitter → AugmentedSeqIterator → IterableSplitter → RemainsIterator
  99. def reverse: SeqSplitter[Int]
    Definition Classes
    SeqSplitter
  100. def reverse2combiner[U >: Int, This](cb: Combiner[U, This]): Combiner[U, This]
    Definition Classes
    AugmentedSeqIterator
  101. def reverseMap2combiner[S, That](f: (Int) ⇒ S, cb: Combiner[S, That]): Combiner[S, That]
    Definition Classes
    AugmentedSeqIterator
  102. def reversed: List[Int]
    Attributes
    protected[this]
    Definition Classes
    TraversableOnce
  103. def sameElements(that: Iterator[_]): Boolean
    Definition Classes
    Iterator
  104. def scanLeft[B](z: B)(op: (B, Int) ⇒ B): Iterator[B]
    Definition Classes
    Iterator
  105. def scanRight[B](z: B)(op: (Int, B) ⇒ B): Iterator[B]
    Definition Classes
    Iterator
  106. def scanToArray[U >: Int, A >: U](z: U, op: (U, U) ⇒ U, array: Array[A], from: Int): Unit
    Definition Classes
    AugmentedIterableIterator
  107. def scanToCombiner[U >: Int, That](howmany: Int, startValue: U, op: (U, U) ⇒ U, cb: Combiner[U, That]): Combiner[U, That]
    Definition Classes
    AugmentedIterableIterator
  108. def scanToCombiner[U >: Int, That](startValue: U, op: (U, U) ⇒ U, cb: Combiner[U, That]): Combiner[U, That]
    Definition Classes
    AugmentedIterableIterator
  109. def seq: Iterator[Int]
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  110. def setIndexFlag(f: Int): Unit
    Definition Classes
    DelegatedSignalling → Signalling
  111. def setIndexFlagIfGreater(f: Int): Unit
    Definition Classes
    DelegatedSignalling → Signalling
  112. def setIndexFlagIfLesser(f: Int): Unit
    Definition Classes
    DelegatedSignalling → Signalling
  113. def shouldSplitFurther[S](coll: parallel.ParIterable[S], parallelismLevel: Int): Boolean
    Definition Classes
    IterableSplitter
  114. val signalDelegate: Signalling
    Definition Classes
    IterableSplitter → DelegatedSignalling
  115. def size: Int
    Definition Classes
    TraversableOnce → GenTraversableOnce
  116. def sizeHintIfCheap: Int
    Attributes
    protected[scala.collection]
    Definition Classes
    GenTraversableOnce
  117. def slice(from1: Int, until1: Int): SeqSplitter[Int]
    Definition Classes
    SeqSplitterIterableSplitter → Iterator
  118. def slice2combiner[U >: Int, This](from: Int, until: Int, cb: Combiner[U, This]): Combiner[U, This]
    Definition Classes
    AugmentedIterableIterator
  119. def sliceIterator(from: Int, until: Int): Iterator[Int]
    Attributes
    protected
    Definition Classes
    Iterator
  120. def sliding[B >: Int](size: Int, step: Int): GroupedIterator[B]
    Definition Classes
    Iterator
  121. def span(p: (Int) ⇒ Boolean): (Iterator[Int], Iterator[Int])
    Definition Classes
    Iterator
  122. def span2combiners[U >: Int, This](p: (Int) ⇒ Boolean, before: Combiner[U, This], after: Combiner[U, This]): (Combiner[U, This], Combiner[U, This])
    Definition Classes
    AugmentedIterableIterator
  123. def split: scala.Seq[SeqSplitter[Int]]

    Splits the iterator into a sequence of disjunct views.

    Splits the iterator into a sequence of disjunct views.

    Returns a sequence of split iterators, each iterating over some subset of the elements in the collection. These subsets are disjoint and should be approximately equal in size. These subsets are not empty, unless the iterator is empty in which case this method returns a sequence with a single empty iterator. If the splitter has more than two elements, this method will return two or more splitters.

    Implementors are advised to keep this partition relatively small - two splitters are already enough when partitioning the collection, although there may be a few more.

    Note: this method actually invalidates the current splitter.

    returns

    a sequence of disjunct iterators of the collection

    Definition Classes
    ParRangeIteratorSeqSplitterPreciseSplitterIterableSplitterSplitter
  124. def splitAt2combiners[U >: Int, This](at: Int, before: Combiner[U, This], after: Combiner[U, This]): (Combiner[U, This], Combiner[U, This])
    Definition Classes
    AugmentedIterableIterator
  125. def splitWithSignalling: scala.Seq[SeqSplitter[Int]]
    Definition Classes
    SeqSplitterIterableSplitter
  126. def sum[U >: Int](implicit num: Numeric[U]): U
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  127. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  128. def tag: Int
    Definition Classes
    DelegatedSignalling → Signalling
  129. def take(n: Int): SeqSplitter[Int]
    Definition Classes
    SeqSplitterIterableSplitter → Iterator
  130. def take2combiner[U >: Int, This](n: Int, cb: Combiner[U, This]): Combiner[U, This]
    Definition Classes
    AugmentedIterableIterator
  131. def takeWhile(p: (Int) ⇒ Boolean): Iterator[Int]
    Definition Classes
    Iterator
  132. def takeWhile2combiner[U >: Int, This](p: (Int) ⇒ Boolean, cb: Combiner[U, This]): (Combiner[U, This], Boolean)
    Definition Classes
    AugmentedIterableIterator
  133. def to[Col[_]](implicit cbf: CanBuildFrom[Nothing, Int, Col[Int]]): Col[Int]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  134. def toArray[B >: Int](implicit arg0: ClassTag[B]): Array[B]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  135. def toBuffer[B >: Int]: Buffer[B]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  136. def toIndexedSeq: immutable.IndexedSeq[Int]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  137. def toIterable: Iterable[Int]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  138. def toIterator: Iterator[Int]
    Definition Classes
    Iterator → GenTraversableOnce
  139. def toList: List[Int]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  140. def toMap[T, U](implicit ev: <:<[Int, (T, U)]): immutable.Map[T, U]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  141. def toSeq: Seq[Int]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  142. def toSet[B >: Int]: immutable.Set[B]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  143. def toStream: immutable.Stream[Int]
    Definition Classes
    Iterator → GenTraversableOnce
  144. def toString(): String
    Definition Classes
    ParRangeIterator → Iterator → AnyRef → Any
  145. def toTraversable: Traversable[Int]
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  146. def toVector: Vector[Int]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  147. def updated2combiner[U >: Int, That](index: Int, elem: U, cb: Combiner[U, That]): Combiner[U, That]
    Definition Classes
    AugmentedSeqIterator
  148. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  149. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  150. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  151. def withFilter(p: (Int) ⇒ Boolean): Iterator[Int]
    Definition Classes
    Iterator
  152. def zip[B](that: Iterator[B]): Iterator[(Int, B)]
    Definition Classes
    Iterator
  153. def zip2combiner[U >: Int, S, That](otherpit: RemainsIterator[S], cb: Combiner[(U, S), That]): Combiner[(U, S), That]
    Definition Classes
    AugmentedIterableIterator
  154. def zipAll[B, A1 >: Int, B1 >: B](that: Iterator[B], thisElem: A1, thatElem: B1): Iterator[(A1, B1)]
    Definition Classes
    Iterator
  155. def zipAll2combiner[U >: Int, S, That](that: RemainsIterator[S], thiselem: U, thatelem: S, cb: Combiner[(U, S), That]): Combiner[(U, S), That]
    Definition Classes
    AugmentedIterableIterator
  156. def zipAllParSeq[S, U >: Int, R >: S](that: SeqSplitter[S], thisElem: U, thatElem: R): ZippedAll[U, R]
    Definition Classes
    SeqSplitterIterableSplitter
  157. def zipParSeq[S](that: SeqSplitter[S]): Zipped[S]
    Definition Classes
    SeqSplitterIterableSplitter
  158. def zipWithIndex: Iterator[(Int, Int)]
    Definition Classes
    Iterator

Inherited from SeqSplitter[Int]

Inherited from PreciseSplitter[Int]

Inherited from AugmentedSeqIterator[Int]

Inherited from IterableSplitter[Int]

Inherited from DelegatedSignalling

Inherited from Signalling

Inherited from Splitter[Int]

Inherited from AugmentedIterableIterator[Int]

Inherited from RemainsIterator[Int]

Inherited from Iterator[Int]

Inherited from TraversableOnce[Int]

Inherited from GenTraversableOnce[Int]

Inherited from AnyRef

Inherited from Any

Ungrouped