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 mutable
    Definition Classes
    parallel
  • trait ParHashTable [K, Entry >: Null <: HashEntry[K, Entry]] extends HashTable[K, Entry]

    Provides functionality for hash tables with linked list buckets, enriching the data structure by fulfilling certain requirements for their parallel construction and iteration.

    Provides functionality for hash tables with linked list buckets, enriching the data structure by fulfilling certain requirements for their parallel construction and iteration.

    Definition Classes
    mutable
  • EntryIterator

abstract class EntryIterator[T, +IterRepr <: IterableSplitter[T]] extends IterableSplitter[T] with SizeMapUtils

A parallel iterator returning all the entries.

Linear Supertypes
SizeMapUtils, IterableSplitter[T], DelegatedSignalling, Signalling, Splitter[T], AugmentedIterableIterator[T], RemainsIterator[T], Iterator[T], TraversableOnce[T], GenTraversableOnce[T], AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. EntryIterator
  2. SizeMapUtils
  3. IterableSplitter
  4. DelegatedSignalling
  5. Signalling
  6. Splitter
  7. AugmentedIterableIterator
  8. RemainsIterator
  9. Iterator
  10. TraversableOnce
  11. GenTraversableOnce
  12. AnyRef
  13. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new EntryIterator(idx: Int, until: Int, totalsize: Int, es: Entry)

Type Members

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

Abstract Value Members

  1. abstract def entry2item(e: Entry): T
  2. abstract def newIterator(idxFrom: Int, idxUntil: Int, totalSize: Int, es: Entry): IterRepr

Concrete Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. def ++[B >: T](that: ⇒ GenTraversableOnce[B]): Iterator[B]
    Definition Classes
    Iterator
  4. def /:[B](z: B)(op: (B, T) ⇒ B): B
    Definition Classes
    TraversableOnce → GenTraversableOnce
  5. def :\[B](z: B)(op: (T, 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, T) ⇒ B, combop: (B, B) ⇒ B): B
    Definition Classes
    TraversableOnce → GenTraversableOnce
  12. def appendParIterable[U >: T, PI <: IterableSplitter[U]](that: PI): Appended[U, PI]
    Definition Classes
    IterableSplitter
  13. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  14. def buffered: BufferedIterator[T]
    Definition Classes
    Iterator
  15. def buildString(closure: ((String) ⇒ Unit) ⇒ Unit): String
    Attributes
    protected
    Definition Classes
    IterableSplitter
  16. def calcNumElems(from: Int, until: Int, tableLength: Int, sizeMapBucketSize: Int): Int
    Attributes
    protected
    Definition Classes
    SizeMapUtils
  17. def clone(): AnyRef
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  18. def collect[B](pf: PartialFunction[T, 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[T, S], cb: Combiner[S, That]): Combiner[S, That]
    Definition Classes
    AugmentedIterableIterator
  20. def collectFirst[B](pf: PartialFunction[T, B]): Option[B]
    Definition Classes
    TraversableOnce
  21. def contains(elem: Any): Boolean
    Definition Classes
    Iterator
  22. def copy2builder[U >: T, Coll, Bld <: Builder[U, Coll]](b: Bld): Bld
    Definition Classes
    AugmentedIterableIterator
  23. def copyToArray[U >: T](array: Array[U], from: Int, len: Int): Unit
    Definition Classes
    AugmentedIterableIterator → Iterator → TraversableOnce → GenTraversableOnce
  24. def copyToArray[B >: T](xs: Array[B]): Unit
    Definition Classes
    TraversableOnce → GenTraversableOnce
  25. def copyToArray[B >: T](xs: Array[B], start: Int): Unit
    Definition Classes
    TraversableOnce → GenTraversableOnce
  26. def copyToBuffer[B >: T](dest: Buffer[B]): Unit
    Definition Classes
    TraversableOnce
  27. def corresponds[B](that: GenTraversableOnce[B])(p: (T, B) ⇒ Boolean): Boolean
    Definition Classes
    Iterator
  28. def count(p: (T) ⇒ Boolean): Int
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  29. def countBucketSizes(fromBucket: Int, untilBucket: Int): Int
    Attributes
    protected
    Definition Classes
    EntryIterator → SizeMapUtils
  30. def countElems(from: Int, until: Int): Int
    Attributes
    protected
    Definition Classes
    EntryIterator → SizeMapUtils
  31. def drop(n: Int): IterableSplitter[T]

    Drop implemented as simple eager consumption.

    Drop implemented as simple eager consumption.

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

    Creates a copy of this iterator.

    Creates a copy of this iterator.

    Definition Classes
    EntryIteratorIterableSplitter
  35. def duplicate: (Iterator[T], Iterator[T])
    Definition Classes
    Iterator
  36. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  37. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  38. def exists(p: (T) ⇒ Boolean): Boolean
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  39. def filter(p: (T) ⇒ Boolean): Iterator[T]
    Definition Classes
    Iterator
  40. def filter2combiner[U >: T, This](pred: (T) ⇒ Boolean, cb: Combiner[U, This]): Combiner[U, This]
    Definition Classes
    AugmentedIterableIterator
  41. def filterNot(p: (T) ⇒ Boolean): Iterator[T]
    Definition Classes
    Iterator
  42. def filterNot2combiner[U >: T, This](pred: (T) ⇒ Boolean, cb: Combiner[U, This]): Combiner[U, This]
    Definition Classes
    AugmentedIterableIterator
  43. def finalize(): Unit
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  44. def find(p: (T) ⇒ Boolean): Option[T]
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  45. def flatMap[B](f: (T) ⇒ GenTraversableOnce[B]): Iterator[B]
    Definition Classes
    Iterator
  46. def flatmap2combiner[S, That](f: (T) ⇒ GenTraversableOnce[S], cb: Combiner[S, That]): Combiner[S, That]
    Definition Classes
    AugmentedIterableIterator
  47. def fold[U >: T](z: U)(op: (U, U) ⇒ U): U
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  48. def foldLeft[B](z: B)(op: (B, T) ⇒ B): B
    Definition Classes
    TraversableOnce → GenTraversableOnce
  49. def foldRight[B](z: B)(op: (T, B) ⇒ B): B
    Definition Classes
    TraversableOnce → GenTraversableOnce
  50. def forall(p: (T) ⇒ Boolean): Boolean
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  51. def foreach[U](f: (T) ⇒ U): Unit
    Definition Classes
    Iterator → GenTraversableOnce
  52. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
  53. def grouped[B >: T](size: Int): GroupedIterator[B]
    Definition Classes
    Iterator
  54. def hasDefiniteSize: Boolean
    Definition Classes
    Iterator → GenTraversableOnce
  55. def hasNext: Boolean
    Definition Classes
    EntryIterator → Iterator
  56. def hashCode(): Int
    Definition Classes
    AnyRef → Any
  57. def indexFlag: Int
    Definition Classes
    DelegatedSignalling → Signalling
  58. def indexOf[B >: T](elem: B, from: Int): Int
    Definition Classes
    Iterator
  59. def indexOf[B >: T](elem: B): Int
    Definition Classes
    Iterator
  60. def indexWhere(p: (T) ⇒ Boolean, from: Int): Int
    Definition Classes
    Iterator
  61. def indexWhere(p: (T) ⇒ Boolean): Int
    Definition Classes
    Iterator
  62. def isAborted: Boolean
    Definition Classes
    DelegatedSignalling → Signalling
  63. def isEmpty: Boolean
    Definition Classes
    Iterator → GenTraversableOnce
  64. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  65. 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
  66. def isTraversableAgain: Boolean
    Definition Classes
    Iterator → GenTraversableOnce
  67. def length: Int
    Definition Classes
    Iterator
  68. def map[S](f: (T) ⇒ S): Mapped[S]
    Definition Classes
    IterableSplitter → Iterator
  69. def map2combiner[S, That](f: (T) ⇒ S, cb: Combiner[S, That]): Combiner[S, That]
    Definition Classes
    AugmentedIterableIterator
  70. def max[U >: T](implicit ord: Ordering[U]): T
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  71. def maxBy[B](f: (T) ⇒ B)(implicit cmp: Ordering[B]): T
    Definition Classes
    TraversableOnce → GenTraversableOnce
  72. def min[U >: T](implicit ord: Ordering[U]): T
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  73. def minBy[B](f: (T) ⇒ B)(implicit cmp: Ordering[B]): T
    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. def next(): T
    Definition Classes
    EntryIterator → 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 >: T](len: Int, elem: A1): Iterator[A1]
    Definition Classes
    Iterator
  83. def partition(p: (T) ⇒ Boolean): (Iterator[T], Iterator[T])
    Definition Classes
    Iterator
  84. def partition2combiners[U >: T, This](pred: (T) ⇒ Boolean, btrue: Combiner[U, This], bfalse: Combiner[U, This]): (Combiner[U, This], Combiner[U, This])
    Definition Classes
    AugmentedIterableIterator
  85. def patch[B >: T](from: Int, patchElems: Iterator[B], replaced: Int): Iterator[B]
    Definition Classes
    Iterator
  86. def product[U >: T](implicit num: Numeric[U]): U
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  87. def reduce[U >: T](op: (U, U) ⇒ U): U
    Definition Classes
    AugmentedIterableIterator → TraversableOnce → GenTraversableOnce
  88. def reduceLeft[U >: T](howmany: Int, op: (U, U) ⇒ U): U
    Definition Classes
    AugmentedIterableIterator
  89. def reduceLeft[B >: T](op: (B, T) ⇒ B): B
    Definition Classes
    TraversableOnce
  90. def reduceLeftOption[B >: T](op: (B, T) ⇒ B): Option[B]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  91. def reduceOption[A1 >: T](op: (A1, A1) ⇒ A1): Option[A1]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  92. def reduceRight[B >: T](op: (T, B) ⇒ B): B
    Definition Classes
    TraversableOnce → GenTraversableOnce
  93. def reduceRightOption[B >: T](op: (T, B) ⇒ B): Option[B]
    Definition Classes
    TraversableOnce → GenTraversableOnce
  94. 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.

    This method is used to provide size hints to builders and combiners, and to approximate positions of iterators within a data structure.

    Note: This method may be implemented to return an upper bound on the number of elements in the iterator, instead of the exact number of elements to iterate. Parallel collections which have such iterators are called non-strict-splitter collections.

    In that case, 2 considerations must be taken into account:

    1) classes that inherit ParIterable must reimplement methods take, drop, slice, splitAt, copyToArray and all others using this information.

    2) if an iterator provides an upper bound on the number of elements, then after splitting the sum of remaining values of split iterators must be less than or equal to this upper bound.

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

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

Inherited from SizeMapUtils

Inherited from IterableSplitter[T]

Inherited from DelegatedSignalling

Inherited from Signalling

Inherited from Splitter[T]

Inherited from AugmentedIterableIterator[T]

Inherited from RemainsIterator[T]

Inherited from Iterator[T]

Inherited from TraversableOnce[T]

Inherited from GenTraversableOnce[T]

Inherited from AnyRef

Inherited from Any

Ungrouped