final case class DoubleArray(array: Array[Double], offset: Int, length: Int) extends Arr[Double] with ChunkIterator[Double] with Product with Serializable
- Self Type
- DoubleArray
- Alphabetic
- By Inheritance
- DoubleArray
- Product
- ChunkIterator
- Arr
- Chunk
- Serializable
- ChunkLike
- StrictOptimizedSeqOps
- StrictOptimizedSeqOps
- StrictOptimizedIterableOps
- IndexedSeq
- IndexedSeqOps
- IndexedSeq
- IndexedSeqOps
- Seq
- SeqOps
- Seq
- Equals
- SeqOps
- PartialFunction
- Function1
- Iterable
- Iterable
- IterableFactoryDefaults
- IterableOps
- IterableOnceOps
- IterableOnce
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Value Members
- final def !=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def ##: Int
- Definition Classes
- AnyRef → Any
- def &(that: Chunk[Boolean])(implicit ev: <:<[Double, Boolean]): BitChunkByte
Returns the bitwise AND of this chunk and the specified chunk.
Returns the bitwise AND of this chunk and the specified chunk.
- Definition Classes
- Chunk
- final def ++[A1 >: Double](that: ChunkIterator[A1]): ChunkIterator[A1]
Concatenates this chunk iterator with the specified chunk iterator.
Concatenates this chunk iterator with the specified chunk iterator.
- Definition Classes
- ChunkIterator
- final def ++[A1 >: Double](that: NonEmptyChunk[A1]): NonEmptyChunk[A1]
Returns the concatenation of this chunk with the specified chunk.
Returns the concatenation of this chunk with the specified chunk.
- Definition Classes
- Chunk
- final def ++[A1 >: Double](that: Chunk[A1]): Chunk[A1]
Returns the concatenation of this chunk with the specified chunk.
Returns the concatenation of this chunk with the specified chunk.
- Definition Classes
- Chunk
- final def ++[B >: Double](suffix: IterableOnce[B]): Chunk[B]
- Definition Classes
- IterableOps
- Annotations
- @inline()
- final def ++:[B >: Double](prefix: IterableOnce[B]): Chunk[B]
- Definition Classes
- SeqOps → IterableOps
- Annotations
- @inline()
- final def +:[B >: Double](elem: B): Chunk[B]
- Definition Classes
- SeqOps
- Annotations
- @inline()
- final def :+[B >: Double](elem: B): Chunk[B]
- Definition Classes
- SeqOps
- Annotations
- @inline()
- final def :++[B >: Double](suffix: IterableOnce[B]): Chunk[B]
- Definition Classes
- SeqOps
- Annotations
- @inline()
- final def ==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- def ^(that: Chunk[Boolean])(implicit ev: <:<[Double, Boolean]): BitChunkByte
Returns the bitwise XOR of this chunk and the specified chunk.
Returns the bitwise XOR of this chunk and the specified chunk.
- Definition Classes
- Chunk
- final def addString(b: StringBuilder): b.type
- Definition Classes
- IterableOnceOps
- Annotations
- @inline()
- final def addString(b: StringBuilder, sep: String): b.type
- Definition Classes
- IterableOnceOps
- Annotations
- @inline()
- def addString(b: StringBuilder, start: String, sep: String, end: String): b.type
- Definition Classes
- IterableOnceOps
- def andThen[C](k: PartialFunction[Double, C]): PartialFunction[Int, C]
- Definition Classes
- PartialFunction
- def andThen[C](k: (Double) => C): PartialFunction[Int, C]
- Definition Classes
- PartialFunction → Function1
- def append[A1 >: Double](a1: A1): Chunk[A1]
Appends an element to the chunk.
Appends an element to the chunk.
- Attributes
- protected
- Definition Classes
- Chunk
- final def appended[A1 >: Double](a1: A1): Chunk[A1]
- Definition Classes
- ChunkLike → StrictOptimizedSeqOps → SeqOps
- def appendedAll[B >: Double](suffix: IterableOnce[B]): Chunk[B]
- Definition Classes
- StrictOptimizedSeqOps → SeqOps
- def apply(index: Int): Double
- Definition Classes
- DoubleArray → SeqOps → Function1
- def applyOrElse[A1 <: Int, B1 >: Double](x: A1, default: (A1) => B1): B1
- Definition Classes
- PartialFunction
- def applyPreferredMaxLength: Int
- Attributes
- protected
- Definition Classes
- IndexedSeq
- val array: Array[Double]
- Definition Classes
- DoubleArray → Arr
- def asBase64String(implicit ev: IsText[Double]): String
Crates a base64 encoded string based on the chunk's data.
Crates a base64 encoded string based on the chunk's data.
- Definition Classes
- Chunk
- final def asBitsByte(implicit ev: <:<[Double, Byte]): Chunk[Boolean]
Converts a chunk of bytes to a chunk of bits.
Converts a chunk of bytes to a chunk of bits.
- Definition Classes
- Chunk
- final def asBitsInt(endianness: Endianness)(implicit ev: <:<[Double, Int]): Chunk[Boolean]
Converts a chunk of ints to a chunk of bits.
Converts a chunk of ints to a chunk of bits.
- Definition Classes
- Chunk
- final def asBitsLong(endianness: Endianness)(implicit ev: <:<[Double, Long]): Chunk[Boolean]
Converts a chunk of longs to a chunk of bits.
Converts a chunk of longs to a chunk of bits.
- Definition Classes
- Chunk
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- final def asString(charset: Charset)(implicit ev: <:<[Double, Byte]): String
Crates a new String based on this chunk of bytes and using the given charset.
Crates a new String based on this chunk of bytes and using the given charset.
- Definition Classes
- Chunk
- final def asString(implicit ev: IsText[Double]): String
Crates a new String based on this chunks data.
Crates a new String based on this chunks data.
- Definition Classes
- Chunk
- def boolean(index: Int)(implicit ev: <:<[Double, Boolean]): Boolean
Get the element at the specified index.
Get the element at the specified index.
- Definition Classes
- Chunk
- def byte(index: Int)(implicit ev: <:<[Double, Byte]): Byte
Get the element at the specified index.
Get the element at the specified index.
- Definition Classes
- Chunk
- def canEqual(that: Any): Boolean
- Definition Classes
- IndexedSeq → Seq → Equals
- def char(index: Int)(implicit ev: <:<[Double, Char]): Char
Get the element at the specified index.
Get the element at the specified index.
- Definition Classes
- Chunk
- def chunkIterator: ChunkIterator[Double]
- Definition Classes
- DoubleArray → Chunk
- def className: String
- Attributes
- protected[this]
- Definition Classes
- Iterable
- implicit val classTag: ClassTag[Double]
- Definition Classes
- Arr
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @native()
- final def coll: DoubleArray.this.type
- Attributes
- protected
- Definition Classes
- Iterable → IterableOps
- def collect[B](pf: PartialFunction[Double, B]): Chunk[B]
Returns a filtered, mapped subset of the elements of this
Chunk
.Returns a filtered, mapped subset of the elements of this
Chunk
.- Definition Classes
- ChunkLike → StrictOptimizedIterableOps → IterableOps → IterableOnceOps
- def collectChunk[B](pf: PartialFunction[Double, B]): Chunk[B]
Returns a filtered, mapped subset of the elements of this chunk.
Returns a filtered, mapped subset of the elements of this chunk.
- Attributes
- protected
- Definition Classes
- Arr → Chunk
- def collectFirst[B](pf: PartialFunction[Double, B]): Option[B]
- Definition Classes
- IterableOnceOps
- def collectWhile[B](pf: PartialFunction[Double, B]): Chunk[B]
Transforms all elements of the chunk for as long as the specified partial function is defined.
Transforms all elements of the chunk for as long as the specified partial function is defined.
- Definition Classes
- Arr → Chunk
- def collectWhileZIO[R, E, B](pf: PartialFunction[Double, ZIO[R, E, B]])(implicit trace: Trace): ZIO[R, E, Chunk[B]]
- Definition Classes
- Arr → Chunk
- def collectZIO[R, E, B](pf: PartialFunction[Double, ZIO[R, E, B]])(implicit trace: Trace): ZIO[R, E, Chunk[B]]
Returns a filtered, mapped subset of the elements of this chunk based on a .
Returns a filtered, mapped subset of the elements of this chunk based on a .
- Definition Classes
- Arr → Chunk
- def combinations(n: Int): Iterator[Chunk[Double]]
- Definition Classes
- SeqOps
- def compose[R](k: PartialFunction[R, Int]): PartialFunction[R, Double]
- Definition Classes
- PartialFunction
- def compose[A](g: (A) => Int): (A) => Double
- Definition Classes
- Function1
- Annotations
- @unspecialized()
- final def concat[B >: Double](suffix: IterableOnce[B]): Chunk[B]
- Definition Classes
- SeqOps → IterableOps
- Annotations
- @inline()
- def concatDepth: Int
- Attributes
- protected
- Definition Classes
- Chunk
- def contains[A1 >: Double](elem: A1): Boolean
- Definition Classes
- SeqOps
- def containsSlice[B >: Double](that: Seq[B]): Boolean
- Definition Classes
- SeqOps
- def copyToArray[B >: Double](dest: Array[B], destPos: Int, length: Int): Int
- Definition Classes
- ChunkLike → IterableOnceOps
- def copyToArray[B >: Double](xs: Array[B], start: Int): Int
- Definition Classes
- IterableOnceOps
- Annotations
- @deprecatedOverriding()
- def copyToArray[B >: Double](xs: Array[B]): Int
- Definition Classes
- IterableOnceOps
- Annotations
- @deprecatedOverriding()
- final def corresponds[B](that: Chunk[B])(f: (Double, B) => Boolean): Boolean
Determines whether this chunk and the specified chunk have the same length and every pair of corresponding elements of this chunk and the specified chunk satisfy the specified predicate.
Determines whether this chunk and the specified chunk have the same length and every pair of corresponding elements of this chunk and the specified chunk satisfy the specified predicate.
- Definition Classes
- Chunk
- def corresponds[B](that: Seq[B])(p: (Double, B) => Boolean): Boolean
- Definition Classes
- SeqOps
- def corresponds[B](that: IterableOnce[B])(p: (Double, B) => Boolean): Boolean
- Definition Classes
- IterableOnceOps
- def count(p: (Double) => Boolean): Int
- Definition Classes
- IterableOnceOps
- def dedupe: Chunk[Double]
Deduplicates adjacent elements that are identical.
Deduplicates adjacent elements that are identical.
- Definition Classes
- Chunk
- def depth: Int
- Attributes
- protected
- Definition Classes
- Chunk
- def diff[B >: Double](that: Seq[B]): Chunk[Double]
- Definition Classes
- StrictOptimizedSeqOps → SeqOps
- def distinct: Chunk[Double]
- Definition Classes
- SeqOps
- def distinctBy[B](f: (Double) => B): Chunk[Double]
- Definition Classes
- StrictOptimizedSeqOps → StrictOptimizedSeqOps → SeqOps
- def double(index: Int)(implicit ev: <:<[Double, Double]): Double
Get the element at the specified index.
Get the element at the specified index.
- Definition Classes
- DoubleArray → Chunk
- def drop(n: Int): Chunk[Double]
Drops the first
n
elements of the chunk.Drops the first
n
elements of the chunk.- Definition Classes
- Chunk → IndexedSeqOps → IterableOps → IterableOnceOps
- def dropRight(n: Int): Chunk[Double]
Drops the last
n
elements of the chunk.Drops the last
n
elements of the chunk.- Definition Classes
- Chunk → StrictOptimizedIterableOps → IndexedSeqOps → IterableOps
- def dropUntil(f: (Double) => Boolean): Chunk[Double]
Drops all elements until the predicate returns true.
Drops all elements until the predicate returns true.
- Definition Classes
- Chunk
- def dropUntilZIO[R, E](p: (Double) => ZIO[R, E, Boolean])(implicit trace: Trace): ZIO[R, E, Chunk[Double]]
Drops all elements until the effectful predicate returns true.
Drops all elements until the effectful predicate returns true.
- Definition Classes
- Chunk
- def dropWhile(f: (Double) => Boolean): Chunk[Double]
Drops all elements so long as the predicate returns true.
Drops all elements so long as the predicate returns true.
- Definition Classes
- Arr → Chunk → IterableOps → IterableOnceOps
- def dropWhileZIO[R, E](p: (Double) => ZIO[R, E, Boolean])(implicit trace: Trace): ZIO[R, E, Chunk[Double]]
Drops all elements so long as the effectful predicate returns true.
Drops all elements so long as the effectful predicate returns true.
- Definition Classes
- Chunk
- def elementWise: ElementWiseExtractor[Int, Double]
- Definition Classes
- PartialFunction
- def empty: Chunk[Double]
- Definition Classes
- IterableFactoryDefaults → IterableOps
- def endsWith[B >: Double](that: Iterable[B]): Boolean
- Definition Classes
- SeqOps
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(that: Any): Boolean
- Definition Classes
- Chunk → Seq → Equals → AnyRef → Any
- final def exists(f: (Double) => Boolean): Boolean
Determines whether a predicate is satisfied for at least one element of this chunk.
Determines whether a predicate is satisfied for at least one element of this chunk.
- Definition Classes
- Chunk → IterableOnceOps
- def filter(f: (Double) => Boolean): Chunk[Double]
Returns a filtered subset of this chunk.
Returns a filtered subset of this chunk.
- Definition Classes
- DoubleArray → Arr → Chunk → StrictOptimizedIterableOps → IterableOps → IterableOnceOps
- def filterImpl(pred: (Double) => Boolean, isFlipped: Boolean): Chunk[Double]
- Attributes
- protected[collection]
- Definition Classes
- StrictOptimizedIterableOps
- def filterNot(pred: (Double) => Boolean): Chunk[Double]
- Definition Classes
- StrictOptimizedIterableOps → IterableOps → IterableOnceOps
- final def filterZIO[R, E](f: (Double) => ZIO[R, E, Boolean])(implicit trace: Trace): ZIO[R, E, Chunk[Double]]
Filters this chunk by the specified effectful predicate, retaining all elements for which the predicate evaluates to true.
Filters this chunk by the specified effectful predicate, retaining all elements for which the predicate evaluates to true.
- Definition Classes
- Chunk
- final def find(f: (Double) => Boolean): Option[Double]
Returns the first element that satisfies the predicate.
Returns the first element that satisfies the predicate.
- Definition Classes
- Chunk → IterableOnceOps
- def findLast(p: (Double) => Boolean): Option[Double]
- Definition Classes
- SeqOps
- final def findZIO[R, E](f: (Double) => ZIO[R, E, Boolean])(implicit trace: Trace): ZIO[R, E, Option[Double]]
Returns the first element that satisfies the effectful predicate.
Returns the first element that satisfies the effectful predicate.
- Definition Classes
- Chunk
- final def flatMap[B](f: (Double) => IterableOnce[B]): Chunk[B]
Returns the concatenation of mapping every element into a new chunk using the specified function.
Returns the concatenation of mapping every element into a new chunk using the specified function.
- Definition Classes
- ChunkLike → StrictOptimizedIterableOps → IterableOps → IterableOnceOps
- def flatten[B](implicit ev: (Double) => IterableOnce[B]): Chunk[B]
Flattens a chunk of chunks into a single chunk by concatenating all chunks.
Flattens a chunk of chunks into a single chunk by concatenating all chunks.
- Definition Classes
- ChunkLike → StrictOptimizedIterableOps → IterableOps → IterableOnceOps
- def float(index: Int)(implicit ev: <:<[Double, Float]): Float
Get the element at the specified index.
Get the element at the specified index.
- Definition Classes
- Chunk
- def fold[A1 >: Double](z: A1)(op: (A1, A1) => A1): A1
- Definition Classes
- IterableOnceOps
- def foldLeft[S](s0: S)(f: (S, Double) => S): S
Folds over the elements in this chunk from the left.
Folds over the elements in this chunk from the left.
- Definition Classes
- Arr → Chunk → IterableOnceOps
- def foldRight[S](s0: S)(f: (Double, S) => S): S
Folds over the elements in this chunk from the right.
Folds over the elements in this chunk from the right.
- Definition Classes
- Arr → Chunk → IndexedSeqOps → IterableOnceOps
- final def foldWhile[S](s0: S)(pred: (S) => Boolean)(f: (S, Double) => S): S
Folds over the elements in this chunk from the left.
Folds over the elements in this chunk from the left. Stops the fold early when the condition is not fulfilled.
- Definition Classes
- Chunk
- final def foldWhileZIO[R, E, S](z: S)(pred: (S) => Boolean)(f: (S, Double) => ZIO[R, E, S])(implicit trace: Trace): ZIO[R, E, S]
- Definition Classes
- Chunk
- final def foldZIO[R, E, S](s: S)(f: (S, Double) => ZIO[R, E, S])(implicit trace: Trace): ZIO[R, E, S]
Effectfully folds over the elements in this chunk from the left.
Effectfully folds over the elements in this chunk from the left.
- Definition Classes
- Chunk
- final def forall(f: (Double) => Boolean): Boolean
Determines whether a predicate is satisfied for all elements of this chunk.
Determines whether a predicate is satisfied for all elements of this chunk.
- Definition Classes
- Chunk → IterableOnceOps
- def foreach[B](f: (Double) => B): Unit
- Definition Classes
- Arr → IterableOnceOps
- def fromSpecific(coll: IterableOnce[Double]): Chunk[Double]
- Attributes
- protected
- Definition Classes
- IterableFactoryDefaults → IterableOps
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
- def groupBy[K](f: (Double) => K): Map[K, Chunk[Double]]
- Definition Classes
- IterableOps
- def groupMap[K, B](key: (Double) => K)(f: (Double) => B): Map[K, Chunk[B]]
- Definition Classes
- IterableOps
- def groupMapReduce[K, B](key: (Double) => K)(f: (Double) => B)(reduce: (B, B) => B): Map[K, B]
- Definition Classes
- IterableOps
- def grouped(size: Int): Iterator[Chunk[Double]]
- Definition Classes
- IterableOps
- def hasNextAt(index: Int): Boolean
Checks if the chunk iterator has another element.
Checks if the chunk iterator has another element.
- Definition Classes
- DoubleArray → ChunkIterator
- final def hashCode(): Int
- Definition Classes
- Chunk → Seq → AnyRef → Any
- def head: Double
Returns the first element of this chunk.
Returns the first element of this chunk. Note that this method is partial in that it will throw an exception if the chunk is empty. Consider using
headOption
to explicitly handle the possibility that the chunk is empty or iterating over the elements of the chunk in lower level, performance sensitive code unless you really only need the first element of the chunk.- Definition Classes
- Chunk → IndexedSeqOps → IterableOps
- final def headOption: Option[Double]
Returns the first element of this chunk if it exists.
Returns the first element of this chunk if it exists.
- Definition Classes
- Chunk → IndexedSeqOps → IterableOps
- def indexOf[B >: Double](elem: B): Int
- Definition Classes
- SeqOps
- Annotations
- @deprecatedOverriding()
- def indexOf[B >: Double](elem: B, from: Int): Int
- Definition Classes
- SeqOps
- def indexOfSlice[B >: Double](that: Seq[B]): Int
- Definition Classes
- SeqOps
- Annotations
- @deprecatedOverriding()
- def indexOfSlice[B >: Double](that: Seq[B], from: Int): Int
- Definition Classes
- SeqOps
- final def indexWhere(f: (Double) => Boolean, from: Int): Int
Returns the first index for which the given predicate is satisfied after or at some given index.
Returns the first index for which the given predicate is satisfied after or at some given index.
- Definition Classes
- Chunk → SeqOps
- def indexWhere(p: (Double) => Boolean): Int
- Definition Classes
- SeqOps
- Annotations
- @deprecatedOverriding()
- def indices: Range
- Definition Classes
- SeqOps
- def init: Chunk[Double]
- Definition Classes
- IterableOps
- def inits: Iterator[Chunk[Double]]
- Definition Classes
- IterableOps
- def int(index: Int)(implicit ev: <:<[Double, Int]): Int
Get the element at the specified index.
Get the element at the specified index.
- Definition Classes
- Chunk
- def intersect[B >: Double](that: Seq[B]): Chunk[Double]
- Definition Classes
- StrictOptimizedSeqOps → SeqOps
- def isDefinedAt(idx: Int): Boolean
- Definition Classes
- SeqOps
- final def isEmpty: Boolean
Determines if the chunk is empty.
Determines if the chunk is empty.
- Definition Classes
- Chunk → SeqOps → IterableOnceOps
- final def isInstanceOf[T0]: Boolean
- Definition Classes
- Any
- def isTraversableAgain: Boolean
- Definition Classes
- IterableOps → IterableOnceOps
- val iterableFactory: SeqFactory[Chunk]
Returns a
SeqFactory
that can constructChunk
values.Returns a
SeqFactory
that can constructChunk
values. TheSeqFactory
exposes anewBuilder
method that is not referentially transparent because it allocates mutable state.- Definition Classes
- ChunkLike → IndexedSeq → IndexedSeq → Seq → Seq → Iterable → Iterable → IterableOps
- def iterator: Iterator[Double]
- Definition Classes
- Arr → IndexedSeqOps → IterableOnce
- def knownSize: Int
- Definition Classes
- IndexedSeqOps → IterableOnce
- def last: Double
- Definition Classes
- IndexedSeqOps → IterableOps
- def lastIndexOf[B >: Double](elem: B, end: Int): Int
- Definition Classes
- SeqOps
- def lastIndexOfSlice[B >: Double](that: Seq[B]): Int
- Definition Classes
- SeqOps
- Annotations
- @deprecatedOverriding()
- def lastIndexOfSlice[B >: Double](that: Seq[B], end: Int): Int
- Definition Classes
- SeqOps
- def lastIndexWhere(p: (Double) => Boolean): Int
- Definition Classes
- SeqOps
- Annotations
- @deprecatedOverriding()
- def lastIndexWhere(p: (Double) => Boolean, end: Int): Int
- Definition Classes
- SeqOps
- final def lastOption: Option[Double]
Returns the last element of this chunk if it exists.
Returns the last element of this chunk if it exists.
- Definition Classes
- Chunk → IterableOps
- def lazyZip[B](that: Iterable[B]): LazyZip2[Double, B, DoubleArray.this.type]
- Definition Classes
- Iterable
- def left: Chunk[Double]
- Attributes
- protected
- Definition Classes
- Chunk
- val length: Int
The length of the iterator.
The length of the iterator.
- Definition Classes
- DoubleArray → ChunkIterator → SeqOps
- final def lengthCompare(that: Iterable[_]): Int
- Definition Classes
- IndexedSeqOps → SeqOps
- final def lengthCompare(len: Int): Int
- Definition Classes
- IndexedSeqOps → SeqOps
- final def lengthIs: SizeCompareOps
- Definition Classes
- SeqOps
- Annotations
- @inline()
- def lift: (Int) => Option[Double]
- Definition Classes
- PartialFunction
- def long(index: Int)(implicit ev: <:<[Double, Long]): Long
Get the element at the specified index.
Get the element at the specified index.
- Definition Classes
- Chunk
- final def map[B](f: (Double) => B): Chunk[B]
Returns a chunk with the elements mapped by the specified function.
Returns a chunk with the elements mapped by the specified function.
- Definition Classes
- ChunkLike → StrictOptimizedIterableOps → IndexedSeqOps → IterableOps → IterableOnceOps
- final def mapAccum[S1, B](s1: S1)(f1: (S1, Double) => (S1, B)): (S1, Chunk[B])
Statefully maps over the chunk, producing new elements of type
B
.Statefully maps over the chunk, producing new elements of type
B
.- Definition Classes
- Chunk
- final def mapAccumZIO[R, E, S1, B](s1: S1)(f1: (S1, Double) => ZIO[R, E, (S1, B)])(implicit trace: Trace): ZIO[R, E, (S1, Chunk[B])]
Statefully and effectfully maps over the elements of this chunk to produce new elements.
Statefully and effectfully maps over the elements of this chunk to produce new elements.
- Definition Classes
- Chunk
- def mapChunk[B](f: (Double) => B): Chunk[B]
Returns a chunk with the elements mapped by the specified function.
Returns a chunk with the elements mapped by the specified function.
- Attributes
- protected
- Definition Classes
- DoubleArray → Arr → Chunk
- final def mapZIO[R, E, B](f: (Double) => ZIO[R, E, B])(implicit trace: Trace): ZIO[R, E, Chunk[B]]
Effectfully maps the elements of this chunk.
Effectfully maps the elements of this chunk.
- Definition Classes
- Chunk
- final def mapZIODiscard[R, E](f: (Double) => ZIO[R, E, Any])(implicit trace: Trace): ZIO[R, E, Unit]
Effectfully maps the elements of this chunk purely for the effects.
Effectfully maps the elements of this chunk purely for the effects.
- Definition Classes
- Chunk
- final def mapZIOPar[R, E, B](f: (Double) => ZIO[R, E, B])(implicit trace: Trace): ZIO[R, E, Chunk[B]]
Effectfully maps the elements of this chunk in parallel.
Effectfully maps the elements of this chunk in parallel.
- Definition Classes
- Chunk
- final def mapZIOParDiscard[R, E](f: (Double) => ZIO[R, E, Any])(implicit trace: Trace): ZIO[R, E, Unit]
Effectfully maps the elements of this chunk in parallel purely for the effects.
Effectfully maps the elements of this chunk in parallel purely for the effects.
- Definition Classes
- Chunk
- def materialize[A1 >: Double]: Chunk[A1]
Materializes a chunk into a chunk backed by an array.
Materializes a chunk into a chunk backed by an array. This method can improve the performance of bulk operations.
- Definition Classes
- Arr → Chunk
- def max[B >: Double](implicit ord: Ordering[B]): Double
- Definition Classes
- IterableOnceOps
- def maxBy[B](f: (Double) => B)(implicit ord: Ordering[B]): Double
- Definition Classes
- IterableOnceOps
- def maxByOption[B](f: (Double) => B)(implicit ord: Ordering[B]): Option[Double]
- Definition Classes
- IterableOnceOps
- def maxOption[B >: Double](implicit ord: Ordering[B]): Option[Double]
- Definition Classes
- IterableOnceOps
- def min[B >: Double](implicit ord: Ordering[B]): Double
- Definition Classes
- IterableOnceOps
- def minBy[B](f: (Double) => B)(implicit ord: Ordering[B]): Double
- Definition Classes
- IterableOnceOps
- def minByOption[B](f: (Double) => B)(implicit ord: Ordering[B]): Option[Double]
- Definition Classes
- IterableOnceOps
- def minOption[B >: Double](implicit ord: Ordering[B]): Option[Double]
- Definition Classes
- IterableOnceOps
- final def mkString: String
- Definition Classes
- IterableOnceOps
- Annotations
- @inline()
- final def mkString(sep: String): String
- Definition Classes
- IterableOnceOps
- Annotations
- @inline()
- final def mkString(start: String, sep: String, end: String): String
- Definition Classes
- IterableOnceOps
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def negate(implicit ev: <:<[Double, Boolean]): BitChunkByte
Returns the bitwise NOT of this chunk.
Returns the bitwise NOT of this chunk.
- Definition Classes
- Chunk
- def newSpecificBuilder: Builder[Double, Chunk[Double]]
- Attributes
- protected
- Definition Classes
- IterableFactoryDefaults → IterableOps
- def nextAt(index: Int): Double
Gets the next element from the chunk iterator.
Gets the next element from the chunk iterator.
- Definition Classes
- DoubleArray → ChunkIterator
- def nonEmpty: Boolean
- Definition Classes
- IterableOnceOps
- Annotations
- @deprecatedOverriding()
- def nonEmptyOrElse[B](ifEmpty: => B)(fn: (NonEmptyChunk[Double]) => B): B
Runs
fn
if achunk
is not empty or returns default valueRuns
fn
if achunk
is not empty or returns default value- Definition Classes
- Chunk
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
- def occCounts[B](sq: Seq[B]): Map[B, Int]
- Attributes
- protected[collection]
- Definition Classes
- SeqOps
- val offset: Int
- def orElse[A1 <: Int, B1 >: Double](that: PartialFunction[A1, B1]): PartialFunction[A1, B1]
- Definition Classes
- PartialFunction
- def padTo[B >: Double](len: Int, elem: B): Chunk[B]
- Definition Classes
- StrictOptimizedSeqOps → SeqOps
- def partition(p: (Double) => Boolean): (Chunk[Double], Chunk[Double])
- Definition Classes
- StrictOptimizedIterableOps → IterableOps
- final def partitionMap[B, C](f: (Double) => Either[B, C]): (Chunk[B], Chunk[C])
Partitions the elements of this chunk into two chunks using the specified function.
Partitions the elements of this chunk into two chunks using the specified function.
- Definition Classes
- Chunk → StrictOptimizedIterableOps → IterableOps
- def patch[B >: Double](from: Int, other: IterableOnce[B], replaced: Int): Chunk[B]
- Definition Classes
- StrictOptimizedSeqOps → SeqOps
- def permutations: Iterator[Chunk[Double]]
- Definition Classes
- SeqOps
- def prepend[A1 >: Double](a1: A1): Chunk[A1]
Prepends an element to the chunk.
Prepends an element to the chunk.
- Attributes
- protected
- Definition Classes
- Chunk
- final def prepended[A1 >: Double](a1: A1): Chunk[A1]
- Definition Classes
- ChunkLike → StrictOptimizedSeqOps → IndexedSeqOps → SeqOps
- def prependedAll[B >: Double](prefix: IterableOnce[B]): Chunk[B]
- Definition Classes
- StrictOptimizedSeqOps → SeqOps
- def product[B >: Double](implicit num: Numeric[B]): B
- Definition Classes
- IterableOnceOps
- def productElementNames: Iterator[String]
- Definition Classes
- Product
- def reduce[B >: Double](op: (B, B) => B): B
- Definition Classes
- IterableOnceOps
- def reduceLeft[B >: Double](op: (B, Double) => B): B
- Definition Classes
- IterableOnceOps
- def reduceLeftOption[B >: Double](op: (B, Double) => B): Option[B]
- Definition Classes
- IterableOnceOps
- def reduceOption[B >: Double](op: (B, B) => B): Option[B]
- Definition Classes
- IterableOnceOps
- def reduceRight[B >: Double](op: (Double, B) => B): B
- Definition Classes
- IterableOnceOps
- def reduceRightOption[B >: Double](op: (Double, B) => B): Option[B]
- Definition Classes
- IterableOnceOps
- def reverse: Chunk[Double]
- Definition Classes
- IndexedSeqOps → SeqOps
- def reverseIterator: Iterator[Double]
- Definition Classes
- IndexedSeqOps → SeqOps
- def reversed: Iterable[Double]
- Attributes
- protected
- Definition Classes
- IndexedSeqOps → IterableOnceOps
- def right: Chunk[Double]
- Attributes
- protected
- Definition Classes
- Chunk
- def runWith[U](action: (Double) => U): (Int) => Boolean
- Definition Classes
- PartialFunction
- def sameElements[B >: Double](o: IterableOnce[B]): Boolean
- Definition Classes
- IndexedSeq → SeqOps
- def scan[B >: Double](z: B)(op: (B, B) => B): Chunk[B]
- Definition Classes
- IterableOps
- def scanLeft[B](z: B)(op: (B, Double) => B): Chunk[B]
- Definition Classes
- StrictOptimizedIterableOps → IterableOps → IterableOnceOps
- def scanRight[B](z: B)(op: (Double, B) => B): Chunk[B]
- Definition Classes
- IterableOps
- def search[B >: Double](elem: B, from: Int, to: Int)(implicit ord: Ordering[B]): SearchResult
- Definition Classes
- IndexedSeqOps → SeqOps
- def search[B >: Double](elem: B)(implicit ord: Ordering[B]): SearchResult
- Definition Classes
- IndexedSeqOps → SeqOps
- def segmentLength(p: (Double) => Boolean, from: Int): Int
- Definition Classes
- SeqOps
- final def segmentLength(p: (Double) => Boolean): Int
- Definition Classes
- SeqOps
- def short(index: Int)(implicit ev: <:<[Double, Short]): Short
Get the element at the specified index.
Get the element at the specified index.
- Definition Classes
- Chunk
- final def size: Int
- Definition Classes
- SeqOps → IterableOnceOps
- final def sizeCompare(that: Iterable[_]): Int
- Definition Classes
- SeqOps → IterableOps
- final def sizeCompare(otherSize: Int): Int
- Definition Classes
- SeqOps → IterableOps
- final def sizeIs: SizeCompareOps
- Definition Classes
- IterableOps
- Annotations
- @inline()
- def slice(from: Int, until: Int): Chunk[Double]
- Definition Classes
- Chunk → IndexedSeqOps → IndexedSeqOps → IterableOps → IterableOnceOps
- def sliceIterator(offset: Int, length: Int): ChunkIterator[Double]
Returns a new iterator that is a slice of this iterator.
Returns a new iterator that is a slice of this iterator.
- Definition Classes
- DoubleArray → ChunkIterator
- def sliding(size: Int, step: Int): Iterator[Chunk[Double]]
- Definition Classes
- IterableOps
- def sliding(size: Int): Iterator[Chunk[Double]]
- Definition Classes
- IterableOps
- def sortBy[B](f: (Double) => B)(implicit ord: Ordering[B]): Chunk[Double]
- Definition Classes
- SeqOps
- def sortWith(lt: (Double, Double) => Boolean): Chunk[Double]
- Definition Classes
- SeqOps
- def sorted[A1 >: Double](implicit ord: Ordering[A1]): Chunk[Double]
- Definition Classes
- ChunkLike → StrictOptimizedSeqOps → SeqOps
- def span(f: (Double) => Boolean): (Chunk[Double], Chunk[Double])
- Definition Classes
- Chunk → StrictOptimizedIterableOps → IterableOps → IterableOnceOps
- final def split(n: Int): Chunk[Chunk[Double]]
Splits this chunk into
n
equally sized chunks.Splits this chunk into
n
equally sized chunks.- Definition Classes
- Chunk
- final def splitAt(n: Int): (Chunk[Double], Chunk[Double])
Returns two splits of this chunk at the specified index.
Returns two splits of this chunk at the specified index.
- Definition Classes
- Chunk → IterableOps → IterableOnceOps
- final def splitWhere(f: (Double) => Boolean): (Chunk[Double], Chunk[Double])
Splits this chunk on the first element that matches this predicate.
Splits this chunk on the first element that matches this predicate.
- Definition Classes
- Chunk
- def startsWith[B >: Double](that: IterableOnce[B], offset: Int): Boolean
- Definition Classes
- SeqOps
- def stepper[S <: Stepper[_]](implicit shape: StepperShape[Double, S]): S with EfficientSplit
- Definition Classes
- IndexedSeqOps → IterableOnce
- final def strictOptimizedCollect[B, C2](b: Builder[B, C2], pf: PartialFunction[Double, B]): C2
- Attributes
- protected[this]
- Definition Classes
- StrictOptimizedIterableOps
- Annotations
- @inline()
- final def strictOptimizedConcat[B >: Double, C2](that: IterableOnce[B], b: Builder[B, C2]): C2
- Attributes
- protected[this]
- Definition Classes
- StrictOptimizedIterableOps
- Annotations
- @inline()
- final def strictOptimizedFlatMap[B, C2](b: Builder[B, C2], f: (Double) => IterableOnce[B]): C2
- Attributes
- protected[this]
- Definition Classes
- StrictOptimizedIterableOps
- Annotations
- @inline()
- final def strictOptimizedFlatten[B, C2](b: Builder[B, C2])(implicit toIterableOnce: (Double) => IterableOnce[B]): C2
- Attributes
- protected[this]
- Definition Classes
- StrictOptimizedIterableOps
- Annotations
- @inline()
- final def strictOptimizedMap[B, C2](b: Builder[B, C2], f: (Double) => B): C2
- Attributes
- protected[this]
- Definition Classes
- StrictOptimizedIterableOps
- Annotations
- @inline()
- final def strictOptimizedZip[B, C2](that: IterableOnce[B], b: Builder[(Double, B), C2]): C2
- Attributes
- protected[this]
- Definition Classes
- StrictOptimizedIterableOps
- Annotations
- @inline()
- def stringPrefix: String
- Attributes
- protected[this]
- Definition Classes
- IndexedSeq → Seq → Iterable
- def sum[B >: Double](implicit num: Numeric[B]): B
- Definition Classes
- IterableOnceOps
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- def tail: Chunk[Double]
- Definition Classes
- IterableOps
- def tails: Iterator[Chunk[Double]]
- Definition Classes
- IterableOps
- def take(n: Int): Chunk[Double]
Takes the first
n
elements of the chunk.Takes the first
n
elements of the chunk.- Definition Classes
- Chunk → IndexedSeqOps → IterableOps → IterableOnceOps
- def takeRight(n: Int): Chunk[Double]
Takes the last
n
elements of the chunk.Takes the last
n
elements of the chunk.- Definition Classes
- Chunk → StrictOptimizedIterableOps → IndexedSeqOps → IterableOps
- def takeWhile(f: (Double) => Boolean): Chunk[Double]
Takes all elements so long as the predicate returns true.
Takes all elements so long as the predicate returns true.
- Definition Classes
- DoubleArray → Arr → Chunk → IterableOps → IterableOnceOps
- def takeWhileZIO[R, E](p: (Double) => ZIO[R, E, Boolean])(implicit trace: Trace): ZIO[R, E, Chunk[Double]]
Takes all elements so long as the effectual predicate returns true.
Takes all elements so long as the effectual predicate returns true.
- Definition Classes
- Chunk
- def tapEach[U](f: (Double) => U): Chunk[Double]
- Definition Classes
- StrictOptimizedIterableOps → IterableOps → IterableOnceOps
- def to[C1](factory: Factory[Double, C1]): C1
- Definition Classes
- IterableOnceOps
- def toArray[A1 >: Double](srcPos: Int, dest: Array[A1], destPos: Int, length: Int): Unit
- final def toArray[A1 >: Double](n: Int, dest: Array[A1]): Unit
- def toArray[A1 >: Double](implicit arg0: ClassTag[A1]): Array[A1]
Converts the chunk into an array.
Converts the chunk into an array.
- Definition Classes
- Chunk → IterableOnceOps
- final def toBinaryString(implicit ev: <:<[Double, Boolean]): String
Renders this chunk of bits as a binary string.
Renders this chunk of bits as a binary string.
- Definition Classes
- Chunk
- final def toBuffer[B >: Double]: Buffer[B]
- Definition Classes
- IterableOnceOps
- Annotations
- @inline()
- final def toIndexedSeq: IndexedSeq[Double]
- Definition Classes
- IndexedSeq → IterableOnceOps
- final def toList: List[Double]
- Definition Classes
- Chunk → IterableOnceOps
- def toMap[K, V](implicit ev: <:<[Double, (K, V)]): Map[K, V]
- Definition Classes
- IterableOnceOps
- def toPackedByte(implicit ev: <:<[Double, Boolean]): Chunk[Byte]
- Definition Classes
- Chunk
- def toPackedInt(endianness: Endianness)(implicit ev: <:<[Double, Boolean]): Chunk[Int]
- Definition Classes
- Chunk
- def toPackedLong(endianness: Endianness)(implicit ev: <:<[Double, Boolean]): Chunk[Long]
- Definition Classes
- Chunk
- final def toSeq: DoubleArray.this.type
- Definition Classes
- Seq → IterableOnceOps
- def toSet[B >: Double]: Set[B]
- Definition Classes
- IterableOnceOps
- final def toString(): String
- Definition Classes
- Chunk → Seq → Function1 → Iterable → AnyRef → Any
- final def toVector: Vector[Double]
- Definition Classes
- Chunk → IterableOnceOps
- def transpose[B](implicit asIterable: (Double) => Iterable[B]): Chunk[Chunk[B]]
- Definition Classes
- IterableOps
- def unapply(a: Int): Option[Double]
- Definition Classes
- PartialFunction
- def unzip[A1, A2](implicit asPair: (Double) => (A1, A2)): (Chunk[A1], Chunk[A2])
- Definition Classes
- StrictOptimizedIterableOps → IterableOps
- def unzip3[A1, A2, A3](implicit asTriple: (Double) => (A1, A2, A3)): (Chunk[A1], Chunk[A2], Chunk[A3])
- Definition Classes
- StrictOptimizedIterableOps → IterableOps
- def update[A1 >: Double](index: Int, a1: A1): Chunk[A1]
Updates an element at the specified index of the chunk.
Updates an element at the specified index of the chunk.
- Attributes
- protected
- Definition Classes
- Chunk
- final def updated[A1 >: Double](index: Int, elem: A1): Chunk[A1]
- Definition Classes
- ChunkLike → StrictOptimizedSeqOps → SeqOps
- def view: IndexedSeqView[Double]
- Definition Classes
- IndexedSeqOps → SeqOps → IterableOps
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()
- def withFilter(p: (Double) => Boolean): WithFilter[Double, [_]Chunk[_]]
- Definition Classes
- IterableOps
- final def zip[B](that: Chunk[B])(implicit zippable: Zippable[Double, B]): Chunk[Out]
Zips this chunk with the specified chunk to produce a new chunk with pairs of elements from each chunk.
Zips this chunk with the specified chunk to produce a new chunk with pairs of elements from each chunk. The returned chunk will have the length of the shorter chunk.
- Definition Classes
- Chunk
- def zip[B](that: IterableOnce[B]): Chunk[(Double, B)]
- Definition Classes
- StrictOptimizedIterableOps → IterableOps
- final def zipAll[B](that: Chunk[B]): Chunk[(Option[Double], Option[B])]
Zips this chunk with the specified chunk to produce a new chunk with pairs of elements from each chunk, filling in missing values from the shorter chunk with
None
.Zips this chunk with the specified chunk to produce a new chunk with pairs of elements from each chunk, filling in missing values from the shorter chunk with
None
. The returned chunk will have the length of the longer chunk.- Definition Classes
- Chunk
- def zipAll[A1 >: Double, B](that: Iterable[B], thisElem: A1, thatElem: B): Chunk[(A1, B)]
- Definition Classes
- IterableOps
- final def zipAllWith[B, C](that: Chunk[B])(left: (Double) => C, right: (B) => C)(both: (Double, B) => C): Chunk[C]
Zips with chunk with the specified chunk to produce a new chunk with pairs of elements from each chunk combined using the specified function
both
.Zips with chunk with the specified chunk to produce a new chunk with pairs of elements from each chunk combined using the specified function
both
. If one chunk is shorter than the other uses the specified functionleft
orright
to map the element that does exist to the result type.- Definition Classes
- Chunk
- final def zipWith[B, C](that: Chunk[B])(f: (Double, B) => C): Chunk[C]
Zips this chunk with the specified chunk using the specified combiner.
Zips this chunk with the specified chunk using the specified combiner.
- Definition Classes
- Chunk
- final def zipWithIndex: Chunk[(Double, Int)]
Zips this chunk with the index of every element.
Zips this chunk with the index of every element.
- Definition Classes
- ChunkLike → StrictOptimizedIterableOps → IterableOps → IterableOnceOps
- final def zipWithIndexFrom(indexOffset: Int): Chunk[(Double, Int)]
Zips this chunk with the index of every element, starting from the initial index value.
Zips this chunk with the index of every element, starting from the initial index value.
- Definition Classes
- Chunk
- def |(that: Chunk[Boolean])(implicit ev: <:<[Double, Boolean]): BitChunkByte
Returns the bitwise OR of this chunk and the specified chunk.
Returns the bitwise OR of this chunk and the specified chunk.
- Definition Classes
- Chunk
Deprecated Value Members
- final def /:[B](z: B)(op: (B, Double) => B): B
- Definition Classes
- IterableOnceOps
- Annotations
- @deprecated @inline()
- Deprecated
(Since version 2.13.0) Use foldLeft instead of /:
- final def :\[B](z: B)(op: (Double, B) => B): B
- Definition Classes
- IterableOnceOps
- Annotations
- @deprecated @inline()
- Deprecated
(Since version 2.13.0) Use foldRight instead of :\
- def aggregate[B](z: => B)(seqop: (B, Double) => B, combop: (B, B) => B): B
- Definition Classes
- IterableOnceOps
- Annotations
- @deprecated
- Deprecated
(Since version 2.13.0) For sequential collections, prefer
foldLeft(z)(seqop)
. For parallel collections, useParIterableLike#aggregate
.
- def companion: IterableFactory[[_]Chunk[_]]
- Definition Classes
- IterableOps
- Annotations
- @deprecated @deprecatedOverriding() @inline()
- Deprecated
(Since version 2.13.0) Use iterableFactory instead
- final def copyToBuffer[B >: Double](dest: Buffer[B]): Unit
- Definition Classes
- IterableOnceOps
- Annotations
- @deprecated @inline()
- Deprecated
(Since version 2.13.0) Use
dest ++= coll
instead
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable]) @Deprecated
- Deprecated
(Since version 9)
- def hasDefiniteSize: Boolean
- Definition Classes
- IterableOnceOps
- Annotations
- @deprecated
- Deprecated
(Since version 2.13.0) Check .knownSize instead of .hasDefiniteSize for more actionable information (see scaladoc for details)
- final def prefixLength(p: (Double) => Boolean): Int
- Definition Classes
- SeqOps
- Annotations
- @deprecated @inline()
- Deprecated
(Since version 2.13.0) Use segmentLength instead of prefixLength
- final def repr: Chunk[Double]
- Definition Classes
- IterableOps
- Annotations
- @deprecated
- Deprecated
(Since version 2.13.0) Use coll instead of repr in a collection implementation, use the collection value itself from the outside
- def reverseMap[B](f: (Double) => B): Chunk[B]
- Definition Classes
- SeqOps
- Annotations
- @deprecated
- Deprecated
(Since version 2.13.0) Use .reverseIterator.map(f).to(...) instead of .reverseMap(f)
- def seq: DoubleArray.this.type
- Definition Classes
- Iterable
- Annotations
- @deprecated
- Deprecated
(Since version 2.13.0) Iterable.seq always returns the iterable itself
- final def toIterable: DoubleArray.this.type
- Definition Classes
- Iterable → IterableOps
- Annotations
- @deprecated
- Deprecated
(Since version 2.13.7) toIterable is internal and will be made protected; its name is similar to
toList
ortoSeq
, but it doesn't copy non-immutable collections
- final def toIterator: Iterator[Double]
- Definition Classes
- IterableOnceOps
- Annotations
- @deprecated @inline()
- Deprecated
(Since version 2.13.0) Use .iterator instead of .toIterator
- final def toStream: Stream[Double]
- Definition Classes
- IterableOnceOps
- Annotations
- @deprecated @inline()
- Deprecated
(Since version 2.13.0) Use .to(LazyList) instead of .toStream
- final def toTraversable: Traversable[Double]
- Definition Classes
- IterableOps
- Annotations
- @deprecated
- Deprecated
(Since version 2.13.0) toTraversable is internal and will be made protected; its name is similar to
toList
ortoSeq
, but it doesn't copy non-immutable collections
- final def union[B >: Double](that: Seq[B]): Chunk[B]
- Definition Classes
- SeqOps
- Annotations
- @deprecated @inline()
- Deprecated
(Since version 2.13.0) Use
concat
instead
- def view(from: Int, until: Int): IndexedSeqView[Double]
- Definition Classes
- IndexedSeqOps → IterableOps
- Annotations
- @deprecated
- Deprecated
(Since version 2.13.0) Use .view.slice(from, until) instead of .view(from, until)