Showing content from http://www.scala-lang.org/api/2.12.19/scala/collection/parallel/immutable/ParIterable.html below:
Scala Standard Library 2.12.19 - scala.collection.parallel.immutable.ParIterable
trait ParIterable[+T] extends GenIterable[T] with parallel.ParIterable[T] with GenericParTemplate[T, ParIterable] with ParIterableLike[T, ParIterable[T], immutable.Iterable[T]] with Immutable
î· î
Ordering
- Alphabetic
- By Inheritance
Inherited
- ParIterable
- Immutable
- ParIterable
- ParIterableLike
- Parallel
- CustomParallelizable
- GenericParTemplate
- HasNewCombiner
- GenIterable
- GenTraversable
- GenericTraversableTemplate
- HasNewBuilder
- GenIterableLike
- GenTraversableLike
- Parallelizable
- GenTraversableOnce
- AnyRef
- Any
Implicitly
- by CollectionsHaveToParArray
- by any2stringadd
- by StringFormat
- by Ensuring
- by ArrowAssoc
Type Members
- î
trait Accessor[R, Tp] extends StrictSplitterCheckTask[R, Tp]
- î
class Aggregate[S] extends Accessor[S, Aggregate[S]]
- î
trait BuilderOps[Elem, To] extends AnyRef
- î
class Collect[S, That] extends Transformer[Combiner[S, That], Collect[S, That]]
- î
abstract class Composite[FR, SR, R, First <: StrictSplitterCheckTask[FR, _], Second <: StrictSplitterCheckTask[SR, _]] extends NonDivisibleTask[R, Composite[FR, SR, R, First, Second]]
- î
class Copy[U >: T, That] extends Transformer[Combiner[U, That], Copy[U, That]]
- î
class CopyToArray[U >: T, This >: Repr] extends Accessor[Unit, CopyToArray[U, This]]
- î
class Count extends Accessor[Int, Count]
- î
class CreateScanTree[U >: T] extends Transformer[ScanTree[U], CreateScanTree[U]]
- î
class Drop[U >: T, This >: Repr] extends Transformer[Combiner[U, This], Drop[U, This]]
- î
class Exists extends Accessor[Boolean, Exists]
- î
class Filter[U >: T, This >: Repr] extends Transformer[Combiner[U, This], Filter[U, This]]
- î
class FilterNot[U >: T, This >: Repr] extends Transformer[Combiner[U, This], FilterNot[U, This]]
- î
class Find[U >: T] extends Accessor[Option[U], Find[U]]
- î
class FlatMap[S, That] extends Transformer[Combiner[S, That], FlatMap[S, That]]
- î
class Fold[U >: T] extends Accessor[U, Fold[U]]
- î
class Forall extends Accessor[Boolean, Forall]
- î
class Foreach[S] extends Accessor[Unit, Foreach[S]]
- î
class FromScanTree[U >: T, That] extends StrictSplitterCheckTask[Combiner[U, That], FromScanTree[U, That]]
- î
class GroupBy[K, U >: T] extends Transformer[HashMapCombiner[K, U], GroupBy[K, U]]
- î
class Map[S, That] extends Transformer[Combiner[S, That], Map[S, That]]
- î
class Max[U >: T] extends Accessor[Option[U], Max[U]]
- î
class Min[U >: T] extends Accessor[Option[U], Min[U]]
- î
trait NonDivisible[R] extends NonDivisibleTask[R, NonDivisible[R]]
- î
trait NonDivisibleTask[R, Tp] extends StrictSplitterCheckTask[R, Tp]
- î
abstract class ParComposite[FR, SR, R, First <: StrictSplitterCheckTask[FR, _], Second <: StrictSplitterCheckTask[SR, _]] extends Composite[FR, SR, R, First, Second]
- î
class Partition[U >: T, This >: Repr] extends Transformer[(Combiner[U, This], Combiner[U, This]), Partition[U, This]]
- î
class Product[U >: T] extends Accessor[U, Product[U]]
- î
class Reduce[U >: T] extends Accessor[Option[U], Reduce[U]]
- î
abstract class ResultMapping[R, Tp, R1] extends NonDivisibleTask[R1, ResultMapping[R, Tp, R1]]
- î
case class ScanLeaf[U >: T](pit: IterableSplitter[U], op: (U, U) â U, from: Int, len: Int, prev: Option[ScanLeaf[U]], acc: U) extends ScanTree[U] with scala.Product with Serializable
- î
case class ScanNode[U >: T](left: ScanTree[U], right: ScanTree[U]) extends ScanTree[U] with scala.Product with Serializable
- î
trait ScanTree[U >: T] extends AnyRef
- î
abstract class SeqComposite[FR, SR, R, First <: StrictSplitterCheckTask[FR, _], Second <: StrictSplitterCheckTask[SR, _]] extends Composite[FR, SR, R, First, Second]
- î
trait SignallingOps[PI <: DelegatedSignalling] extends AnyRef
- î
class Slice[U >: T, This >: Repr] extends Transformer[Combiner[U, This], Slice[U, This]]
- î
class Span[U >: T, This >: Repr] extends Transformer[(Combiner[U, This], Combiner[U, This]), Span[U, This]]
- î
class SplitAt[U >: T, This >: Repr] extends Transformer[(Combiner[U, This], Combiner[U, This]), SplitAt[U, This]]
- î
trait StrictSplitterCheckTask[R, Tp] extends Task[R, Tp]
- î
class Sum[U >: T] extends Accessor[U, Sum[U]]
- î
class Take[U >: T, This >: Repr] extends Transformer[Combiner[U, This], Take[U, This]]
- î
class TakeWhile[U >: T, This >: Repr] extends Transformer[(Combiner[U, This], Boolean), TakeWhile[U, This]]
- î
trait TaskOps[R, Tp] extends AnyRef
- î
class ToParCollection[U >: T, That] extends Transformer[Combiner[U, That], ToParCollection[U, That]]
- î
class ToParMap[K, V, That] extends Transformer[Combiner[(K, V), That], ToParMap[K, V, That]]
- î
trait Transformer[R, Tp] extends Accessor[R, Tp]
- î
class Zip[U >: T, S, That] extends Transformer[Combiner[(U, S), That], Zip[U, S, That]]
- î
class ZipAll[U >: T, S, That] extends Transformer[Combiner[(U, S), That], ZipAll[U, S, That]]
- î
type SSCTask[R, Tp] = StrictSplitterCheckTask[R, Tp]
Concrete Value Members
- î
final def !=(arg0: Any): Boolean
- î
final def ##(): Int
- î
def +(other: String): String
- î
def ++[U >: T, That](that: GenTraversableOnce[U])(implicit bf: CanBuildFrom[ParIterable[T], U, That]): That
- î
def ->[B](y: B): (ParIterable[T], B)
- î
final def ==(arg0: Any): Boolean
- î
def aggregate[S](z: â S)(seqop: (S, T) â S, combop: (S, S) â S): S
- î
final def asInstanceOf[T0]: T0
- î
def bf2seq[S, That](bf: CanBuildFrom[ParIterable[T], S, That]): CanBuildFrom[immutable.Iterable[T], S, That]
- î
implicit def builder2ops[Elem, To](cb: Builder[Elem, To]): BuilderOps[Elem, To]
- î
def canEqual(other: Any): Boolean
- î
def clone(): AnyRef
- î
def collect[B](pf: PartialFunction[A, B]): ParIterable[B]
- î
def combinerFactory[S, That](cbf: () â Combiner[S, That]): CombinerFactory[S, That]
- î
def combinerFactory: CombinerFactory[T, ParIterable[T]]
- î
def companion: GenericCompanion[ParIterable] with GenericParCompanion[ParIterable]
- î
def copyToArray(xs: Array[A], start: Int, len: Int): Unit
- î
def copyToArray(xs: Array[A], start: Int): Unit
- î
def copyToArray(xs: Array[A]): Unit
- î
def count(p: (T) â Boolean): Int
- î
def debugBuffer: ArrayBuffer[String]
- î
implicit def delegatedSignalling2ops[PI <: DelegatedSignalling](it: PI): SignallingOps[PI]
- î
def drop(n: Int): ParIterable[T]
- î
def dropWhile(pred: (T) â Boolean): ParIterable[T]
- î
def ensuring(cond: (ParIterable[T]) â Boolean, msg: â Any): ParIterable[T]
- î
def ensuring(cond: (ParIterable[T]) â Boolean): ParIterable[T]
- î
def ensuring(cond: Boolean, msg: â Any): ParIterable[T]
- î
def ensuring(cond: Boolean): ParIterable[T]
- î
final def eq(arg0: AnyRef): Boolean
- î
def equals(arg0: Any): Boolean
- î
def exists(p: (T) â Boolean): Boolean
- î
def filter(pred: (T) â Boolean): ParIterable[T]
- î
def filterNot(pred: (T) â Boolean): ParIterable[T]
- î
def finalize(): Unit
- î
def find(p: (T) â Boolean): Option[T]
- î
def flatMap[B](f: (A) â GenTraversableOnce[B]): ParIterable[B]
- î
def flatten[B]: ParIterable[B]
- î
def fold[U >: T](z: U)(op: (U, U) â U): U
- î
def foldLeft[S](z: S)(op: (S, T) â S): S
- î
def foldRight[S](z: S)(op: (T, S) â S): S
- î
def forall(p: (T) â Boolean): Boolean
- î
def foreach[U](f: (T) â U): Unit
- î
def genericBuilder[B]: Combiner[B, ParIterable[B]]
- î
def genericCombiner[B]: Combiner[B, ParIterable[B]]
- î
final def getClass(): Class[_]
- î
def groupBy[K](f: (T) â K): ParMap[K, ParIterable[T]]
- î
def hasDefiniteSize: Boolean
- î
def hashCode(): Int
- î
def head: T
- î
def headOption: Option[T]
- î
def init: ParIterable[T]
- î
def initTaskSupport(): Unit
- î
def isEmpty: Boolean
- î
final def isInstanceOf[T0]: Boolean
- î
def isStrictSplitterCollection: Boolean
- î
final def isTraversableAgain: Boolean
- î
def iterator: Splitter[T]
- î
def last: T
- î
def lastOption: Option[T]
- î
def map[B](f: (A) â B): ParIterable[B]
- î
def max: A
- î
def maxBy[B](f: (A) â B): A
- î
def min: A
- î
def minBy[B](f: (A) â B): A
- î
def mkString: String
- î
def mkString(sep: String): String
- î
def mkString(start: String, sep: String, end: String): String
- î
final def ne(arg0: AnyRef): Boolean
- î
def newBuilder: Builder[T, ParIterable[T]]
- î
def newCombiner: Combiner[T, ParIterable[T]]
- î
def nonEmpty: Boolean
- î
final def notify(): Unit
- î
final def notifyAll(): Unit
- î
def par: ParIterable[T]
- î
def parCombiner: Combiner[T, ParIterable[T]]
- î
def partition(pred: (T) â Boolean): (ParIterable[T], ParIterable[T])
- î
def product: A
- î
def reduce[U >: T](op: (U, U) â U): U
- î
def reduceLeft[U >: T](op: (U, T) â U): U
- î
def reduceLeftOption[U >: T](op: (U, T) â U): Option[U]
- î
def reduceOption[U >: T](op: (U, U) â U): Option[U]
- î
def reduceRight[U >: T](op: (T, U) â U): U
- î
def reduceRightOption[U >: T](op: (T, U) â U): Option[U]
- î
def repr: ParIterable[T]
- î
def reuse[S, That](oldc: Option[Combiner[S, That]], newc: Combiner[S, That]): Combiner[S, That]
- î
def sameElements(that: GenIterable[A]): Boolean
- î
def scan(z: T)(op: (T, T) â T): ParIterable[T]
- î
def scanBlockSize: Int
- î
def scanLeft[S, That](z: S)(op: (S, T) â S)(implicit bf: CanBuildFrom[ParIterable[T], S, That]): That
- î
def scanRight[S, That](z: S)(op: (T, S) â S)(implicit bf: CanBuildFrom[ParIterable[T], S, That]): That
- î
def sequentially[S, That <: Parallel](b: (immutable.Iterable[T]) â Parallelizable[S, That]): ParIterable[T]
- î
def sizeHintIfCheap: Int
- î
def slice(unc_from: Int, unc_until: Int): ParIterable[T]
- î
def span(pred: (T) â Boolean): (ParIterable[T], ParIterable[T])
- î
def splitAt(n: Int): (ParIterable[T], ParIterable[T])
- î
def stringPrefix: String
- î
def sum: A
- î
final def synchronized[T0](arg0: â T0): T0
- î
def tail: ParIterable[T]
- î
def take(n: Int): ParIterable[T]
- î
def takeWhile(pred: (T) â Boolean): ParIterable[T]
- î
implicit def task2ops[R, Tp](tsk: SSCTask[R, Tp]): TaskOps[R, Tp]
- î
def tasksupport: TaskSupport
- î
def tasksupport_=(ts: TaskSupport): Unit
- î
def to[Col[_]]: Col[A]
- î
def toArray: Array[A]
- î
def toBuffer[U >: T]: Buffer[U]
- î
def toIndexedSeq: immutable.IndexedSeq[T]
- î
def toIterable: ParIterable[T]
- î
def toIterator: scala.Iterator[T]
- î
def toList: List[T]
- î
def toMap[T, U]: collection.Map[T, U]
- î
def toParArray: ParArray[T]
- î
def toParCollection[U >: T, That](cbf: () â Combiner[U, That]): That
- î
def toParMap[K, V, That](cbf: () â Combiner[(K, V), That])(implicit ev: <:<[T, (K, V)]): That
- î
def toSeq: ParSeq[T]
- î
def toSet[U >: T]: ParSet[U]
- î
def toStream: Stream[T]
- î
def toString(): String
- î
def toTraversable: GenTraversable[T]
- î
def toVector: Vector[T]
- î
def transpose[B](implicit asTraversable: (T) â GenTraversableOnce[B]): ParIterable[ParIterable[B]]
- î
def unzip[A1, A2](implicit asPair: (T) â (A1, A2)): (ParIterable[A1], ParIterable[A2])
- î
def unzip3[A1, A2, A3](implicit asTriple: (T) â (A1, A2, A3)): (ParIterable[A1], ParIterable[A2], ParIterable[A3])
- î
final def wait(): Unit
- î
final def wait(arg0: Long, arg1: Int): Unit
- î
final def wait(arg0: Long): Unit
- î
def withFilter(pred: (T) â Boolean): ParIterable[T]
- î
def wrap[R](body: â R): NonDivisible[R]
- î
def zip[B](that: GenIterable[B]): ParIterable[(A, B)]
- î
def zipAll[B](that: Iterable[B], thisElem: A, thatElem: B): ParIterable[(A, B)]
- î
def zipWithIndex: ParIterable[(A, Int)]
- î
def â[B](y: B): (ParIterable[T], B)
Inherited from HasNewCombiner[T, scala.collection.parallel.immutable.ParIterable[T] @scala.annotation.unchecked.uncheckedVariance] Inherited from HasNewBuilder[T, scala.collection.parallel.immutable.ParIterable[T] @scala.annotation.unchecked.uncheckedVariance]
RetroSearch is an open source project built by @garambo
| Open a GitHub Issue
Search and Browse the WWW like it's 1997 | Search results from DuckDuckGo
HTML:
3.2
| Encoding:
UTF-8
| Version:
0.7.4