Scala Standard Library 2.12.18 - scala.collection.parallel.mutable.ParArray (original) (raw)
class ParArray[T] extends ParSeq[T] with GenericParTemplate[T, ParArray] with ParSeqLike[T, ParArray[T], ArraySeq[T]] with Serializable
Ordering
- Alphabetic
- By Inheritance
Inherited
- ParArray
- Serializable
- Serializable
- ParSeq
- ParSeq
- ParSeqLike
- ParIterable
- Mutable
- ParIterable
- ParIterableLike
- Parallel
- CustomParallelizable
- GenericParTemplate
- HasNewCombiner
- GenSeq
- GenIterable
- GenTraversable
- GenericTraversableTemplate
- HasNewBuilder
- GenSeqLike
- Equals
- GenIterableLike
- GenTraversableLike
- Parallelizable
- GenTraversableOnce
- AnyRef
- Any
Implicitly
by CollectionsHaveToParArray
by any2stringadd
by StringFormat
by Ensuring
by ArrowAssoc
Hide All
Show All
Instance Constructors
Type Members
- 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 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]]
- class ZipAll[U >: T, S, That] extends Transformer[Combiner[(U, S), That], ZipAll[U, S, That]]
- trait Accessor[R, Tp] extends ParSeqLike.Accessor[R, Tp]
- class Corresponds[S] extends Accessor[Boolean, Corresponds[S]]
- abstract class Elements extends SeqSplitter[T] with scala.BufferedIterator[T]
- class IndexWhere extends Accessor[Int, IndexWhere]
- class LastIndexWhere extends Accessor[Int, LastIndexWhere]
- class Reverse[U >: T, This >: Repr] extends Transformer[Combiner[U, This], Reverse[U, This]]
- class ReverseMap[S, That] extends Transformer[Combiner[S, That], ReverseMap[S, That]]
- class SameElements[U >: T] extends Accessor[Boolean, SameElements[U]]
- class SegmentLength extends Accessor[(Int, Boolean), SegmentLength]
- trait Transformer[R, Tp] extends Accessor[R, Tp] with ParSeqLike.Transformer[R, Tp]
- class Updated[U >: T, That] extends Transformer[Combiner[U, That], Updated[U, That]]
- class Zip[U >: T, S, That] extends Transformer[Combiner[(U, S), That], Zip[U, S, That]]
- class Map[S] extends Task[Unit, Map[S]]
- class ParArrayIterator extends SeqSplitter[T]
- type SSCTask[R, Tp] = StrictSplitterCheckTask[R, Tp]
- class ScanToArray[U >: T] extends Task[Unit, ScanToArray[U]]
- type SuperParIterator = IterableSplitter[T]
Value Members
- final def !=(arg0: Any): Boolean
- final def ##(): Int
- def +(other: String): String
- def ++[U >: T, That](that: GenTraversableOnce[U])(implicit bf: CanBuildFrom[ParArray[T], U, That]): That
- def +:(elem: A): ParArray[A]
- def ->[B](y: B): (ParArray[T], B)
- def :+(elem: A): ParArray[A]
- final def ==(arg0: Any): Boolean
- def aggregate[S](z: ⇒ S)(seqop: (S, T) ⇒ S, combop: (S, S) ⇒ S): S
- def apply(i: Int): T
- val arrayseq: ArraySeq[T]
- final def asInstanceOf[T0]: T0
- def bf2seq[S, That](bf: CanBuildFrom[ParArray[T], S, That]): CanBuildFrom[ArraySeq[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]): ParArray[B]
- def combinerFactory[S, That](cbf: () ⇒ Combiner[S, That]): CombinerFactory[S, That]
- def combinerFactory: CombinerFactory[T, ParArray[T]]
- def companion: GenericCompanion[ParArray] with GenericParCompanion[ParArray]
- 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 corresponds[S](that: GenSeq[S])(p: (T, S) ⇒ Boolean): Boolean
- def count(p: (T) ⇒ Boolean): Int
- def debugBuffer: ArrayBuffer[String]
- implicit def delegatedSignalling2ops[PI <: DelegatedSignalling](it: PI): SignallingOps[PI]
- def diff(that: GenSeq[A]): ParArray[A]
- def distinct: ParArray[T]
- def down(p: IterableSplitter[_]): SeqSplitter[T]
- def drop(n: Int): ParArray[T]
- def dropWhile(pred: (T) ⇒ Boolean): ParArray[T]
- def endsWith[S](that: GenSeq[S]): Boolean
- def ensuring(cond: (ParArray[T]) ⇒ Boolean, msg: ⇒ Any): ParArray[T]
- def ensuring(cond: (ParArray[T]) ⇒ Boolean): ParArray[T]
- def ensuring(cond: Boolean, msg: ⇒ Any): ParArray[T]
- def ensuring(cond: Boolean): ParArray[T]
- final def eq(arg0: AnyRef): Boolean
- def equals(that: Any): Boolean
- def exists(p: (T) ⇒ Boolean): Boolean
- def filter(pred: (T) ⇒ Boolean): ParArray[T]
- def filterNot(pred: (T) ⇒ Boolean): ParArray[T]
- def finalize(): Unit
- def find(p: (T) ⇒ Boolean): Option[T]
- def flatMap[B](f: (A) ⇒ GenTraversableOnce[B]): ParArray[B]
- def flatten[B]: ParArray[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, ParArray[B]]
- def genericCombiner[B]: Combiner[B, ParArray[B]]
- final def getClass(): Class[_]
- def groupBy[K](f: (T) ⇒ K): immutable.ParMap[K, ParArray[T]]
- def hasDefiniteSize: Boolean
- def hashCode(): Int
- def head: T
- def headOption: Option[T]
- def indexOf(elem: T, from: Int): Int
- def indexOf(elem: T): Int
- def indexWhere(p: (T) ⇒ Boolean, from: Int): Int
- def indexWhere(p: (T) ⇒ Boolean): Int
- def init: ParArray[T]
- def initTaskSupport(): Unit
- def intersect(that: scala.Seq[T]): ParArray[T]
- def isDefinedAt(idx: Int): Boolean
- def isEmpty: Boolean
- final def isInstanceOf[T0]: Boolean
- def isStrictSplitterCollection: Boolean
- final def isTraversableAgain: Boolean
- def iterator: PreciseSplitter[T]
- def last: T
- def lastIndexOf(elem: T, end: Int): Int
- def lastIndexOf(elem: T): Int
- def lastIndexWhere(p: (T) ⇒ Boolean, end: Int): Int
- def lastIndexWhere(p: (T) ⇒ Boolean): Int
- def lastOption: Option[T]
- def length: Int
- def map[B](f: (A) ⇒ B): ParArray[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, ParArray[T]]
- def newCombiner: Combiner[T, ParArray[T]]
- def nonEmpty: Boolean
- final def notify(): Unit
- final def notifyAll(): Unit
- def padTo(len: Int, elem: A): ParArray[A]
- def par: ParArray[T]
- def parCombiner: Combiner[T, ParArray[T]]
- def partition(pred: (T) ⇒ Boolean): (ParArray[T], ParArray[T])
- def patch(from: Int, that: GenSeq[A], replaced: Int): ParArray[A]
- def prefixLength(p: (T) ⇒ Boolean): Int
- 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: ParArray[T]
- def reuse[S, That](oldc: Option[Combiner[S, That]], newc: Combiner[S, That]): Combiner[S, That]
- def reverse: ParArray[T]
- def reverseMap[B](f: (A) ⇒ B): ParArray[B]
- def sameElements(that: GenIterable[A]): Boolean
- def scan(z: T)(op: (T, T) ⇒ T): ParArray[T]
- def scanBlockSize: Int
- def scanLeft[S, That](z: S)(op: (S, T) ⇒ S)(implicit bf: CanBuildFrom[ParArray[T], S, That]): That
- def scanRight[S, That](z: S)(op: (T, S) ⇒ S)(implicit bf: CanBuildFrom[ParArray[T], S, That]): That
- def segmentLength(p: (T) ⇒ Boolean, from: Int): Int
- def seq: ArraySeq[T]
- def sequentially[S, That <: Parallel](b: (ArraySeq[T]) ⇒ Parallelizable[S, That]): ParArray[T]
- def size: Int
- def sizeHintIfCheap: Int
- def slice(unc_from: Int, unc_until: Int): ParArray[T]
- def span(pred: (T) ⇒ Boolean): (ParArray[T], ParArray[T])
- def splitAt(n: Int): (ParArray[T], ParArray[T])
- def splitter: ParArrayIterator
- def startsWith[S](that: GenSeq[S], offset: Int): Boolean
- def startsWith[B](that: GenSeq[B]): Boolean
- def stringPrefix: String
- def sum: A
- final def synchronized[T0](arg0: ⇒ T0): T0
- def tail: ParArray[T]
- def take(n: Int): ParArray[T]
- def takeWhile(pred: (T) ⇒ Boolean): ParArray[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]: immutable.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]): ParArray[ParArray[B]]
- def union(that: GenSeq[T]): ParArray[T]
- def unzip[A1, A2](implicit asPair: (T) ⇒ (A1, A2)): (ParArray[A1], ParArray[A2])
- def unzip3[A1, A2, A3](implicit asTriple: (T) ⇒ (A1, A2, A3)): (ParArray[A1], ParArray[A2], ParArray[A3])
- def update(i: Int, elem: T): Unit
- def updated(index: Int, elem: A): ParArray[A]
- final def wait(): Unit
- final def wait(arg0: Long, arg1: Int): Unit
- final def wait(arg0: Long): Unit
- def withFilter(pred: (T) ⇒ Boolean): ParArray[T]
- def wrap[R](body: ⇒ R): NonDivisible[R]
- def zip[B](that: GenIterable[B]): ParArray[(A, B)]
- def zipAll[B](that: Iterable[B], thisElem: A, thatElem: B): ParArray[(A, B)]
- def zipWithIndex: ParArray[(A, Int)]
- def →[B](y: B): (ParArray[T], B)
Deprecated Value Members
- def /:[S](z: S)(op: (S, T) ⇒ S): S
- def :\[S](z: S)(op: (T, S) ⇒ S): S
- def formatted(fmtstr: String): String
- def view: SeqView[T, ArraySeq[T]]