abstract class ByteIterator extends BufferedIterator[Byte]
An iterator over a ByteString.
- Source
- ByteIterator.scala
- Alphabetic
- By Inheritance
- ByteIterator
- BufferedIterator
- Iterator
- IterableOnceOps
- IterableOnce
- AnyRef
- Any
- by iterableOnceExtensionMethods
- by any2stringadd
- by StringFormat
- by Ensuring
- by ArrowAssoc
- Hide All
- Show All
- Public
- Protected
Instance Constructors
-  new ByteIterator()
Type Members
-    class GroupedIterator[B >: A] extends AbstractIterator[Seq[B]]- Definition Classes
- Iterator
 
Abstract Value Members
-   abstract  def asInputStream: InputStreamDirectly wraps this ByteIterator in an InputStream without copying. Directly wraps this ByteIterator in an InputStream without copying. Read and skip operations on the stream will advance the iterator accordingly. 
-   abstract  def clear(): Unit- Attributes
- protected
 
-   abstract  def copyToBuffer(buffer: ByteBuffer): IntFor performance sensitive code, call take() directly on ByteString (it's optimised there) 
-   abstract  def getBytes(xs: Array[Byte], offset: Int, n: Int): ByteIterator.this.typeGet a specific number of Bytes from this iterator. Get a specific number of Bytes from this iterator. In contrast to copyToArray, this method will fail if length < n or if (xs.length - offset) < n. 
-   abstract  def getDoubles(xs: Array[Double], offset: Int, n: Int)(implicit byteOrder: ByteOrder): ByteIterator.this.typeGet a number of Doubles from this iterator. 
-   abstract  def getFloats(xs: Array[Float], offset: Int, n: Int)(implicit byteOrder: ByteOrder): ByteIterator.this.typeGet a number of Floats from this iterator. 
-   abstract  def getInts(xs: Array[Int], offset: Int, n: Int)(implicit byteOrder: ByteOrder): ByteIterator.this.typeGet a number of Ints from this iterator. 
-   abstract  def getLongs(xs: Array[Long], offset: Int, n: Int)(implicit byteOrder: ByteOrder): ByteIterator.this.typeGet a number of Longs from this iterator. 
-   abstract  def getShorts(xs: Array[Short], offset: Int, n: Int)(implicit byteOrder: ByteOrder): ByteIterator.this.typeGet a number of Shorts from this iterator. 
-   abstract  def hasNext: Boolean- Definition Classes
- Iterator
 
-   abstract  def head: Byte- Definition Classes
- ByteIterator → BufferedIterator
 
-  abstract def len: Int
-   abstract  def next(): Byte- Definition Classes
- ByteIterator → Iterator
 
-  abstract def toByteString: ByteString
Concrete Value Members
-   final  def !=(arg0: Any): Boolean- Definition Classes
- AnyRef → Any
 
-   final  def ##: Int- Definition Classes
- AnyRef → Any
 
-    def +(other: String): String- Implicit
- This member is added by an implicit conversion from ByteIterator toany2stringadd[ByteIterator] performed by method any2stringadd in scala.Predef.
- Definition Classes
- any2stringadd
 
-  def ++(that: IterableOnce[Byte]): ByteIterator
-   final  def ++[B >: Byte](xs: => IterableOnce[B]): Iterator[B]- Definition Classes
- Iterator
- Annotations
- @inline()
 
-    def ->[B](y: B): (ByteIterator, B)- Implicit
- This member is added by an implicit conversion from ByteIterator toArrowAssoc[ByteIterator] performed by method ArrowAssoc in scala.Predef.
- Definition Classes
- ArrowAssoc
- Annotations
- @inline()
 
-   final  def ==(arg0: Any): Boolean- Definition Classes
- AnyRef → Any
 
-   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
 
-   final  def asInstanceOf[T0]: T0- Definition Classes
- Any
 
-    def buffered: ByteIterator.this.type- Definition Classes
- BufferedIterator → Iterator
 
-    def clone(): ByteIterator- Definition Classes
- ByteIterator → AnyRef
 
-    def collect[B](pf: PartialFunction[Byte, B]): Iterator[B]- Definition Classes
- Iterator → IterableOnceOps
 
-    def collectFirst[B](pf: PartialFunction[Byte, B]): Option[B]- Definition Classes
- IterableOnceOps
 
-    def concat[B >: Byte](xs: => IterableOnce[B]): Iterator[B]- Definition Classes
- Iterator
 
-    def contains(elem: Any): Boolean- Definition Classes
- Iterator
 
-    def copyToArray[B >: Byte](xs: Array[B], start: Int, len: Int): Int- Definition Classes
- IterableOnceOps
 
-    def copyToArray[B >: Byte](xs: Array[B], start: Int): Int- Definition Classes
- IterableOnceOps
- Annotations
- @deprecatedOverriding()
 
-    def copyToArray[B >: Byte](xs: Array[B]): Int- Definition Classes
- IterableOnceOps
- Annotations
- @deprecatedOverriding()
 
-    def corresponds[B](that: IterableOnce[B])(p: (Byte, B) => Boolean): Boolean- Definition Classes
- IterableOnceOps
 
-    def count(p: (Byte) => Boolean): Int- Definition Classes
- IterableOnceOps
 
-    def distinct: Iterator[Byte]- Definition Classes
- Iterator
 
-    def distinctBy[B](f: (Byte) => B): Iterator[Byte]- Definition Classes
- Iterator
 
-    def drop(n: Int): ByteIterator.this.type- Definition Classes
- ByteIterator → Iterator → IterableOnceOps
 
-    def dropWhile(p: (Byte) => Boolean): ByteIterator.this.type- Definition Classes
- ByteIterator → Iterator → IterableOnceOps
 
-    def duplicate: (ByteIterator, ByteIterator)- Definition Classes
- ByteIterator → Iterator
 
-    def ensuring(cond: (ByteIterator) => Boolean, msg: => Any): ByteIterator- Implicit
- This member is added by an implicit conversion from ByteIterator toEnsuring[ByteIterator] performed by method Ensuring in scala.Predef.
- Definition Classes
- Ensuring
 
-    def ensuring(cond: (ByteIterator) => Boolean): ByteIterator- Implicit
- This member is added by an implicit conversion from ByteIterator toEnsuring[ByteIterator] performed by method Ensuring in scala.Predef.
- Definition Classes
- Ensuring
 
-    def ensuring(cond: Boolean, msg: => Any): ByteIterator- Implicit
- This member is added by an implicit conversion from ByteIterator toEnsuring[ByteIterator] performed by method Ensuring in scala.Predef.
- Definition Classes
- Ensuring
 
-    def ensuring(cond: Boolean): ByteIterator- Implicit
- This member is added by an implicit conversion from ByteIterator toEnsuring[ByteIterator] performed by method Ensuring in scala.Predef.
- Definition Classes
- Ensuring
 
-   final  def eq(arg0: AnyRef): Boolean- Definition Classes
- AnyRef
 
-    def equals(arg0: AnyRef): Boolean- Definition Classes
- AnyRef → Any
 
-    def exists(p: (Byte) => Boolean): Boolean- Definition Classes
- IterableOnceOps
 
-    def filter(p: (Byte) => Boolean): Iterator[Byte]- Definition Classes
- Iterator → IterableOnceOps
 
-    def filterNot(p: (Byte) => Boolean): Iterator[Byte]- Definition Classes
- Iterator → IterableOnceOps
 
-    def find(p: (Byte) => Boolean): Option[Byte]- Definition Classes
- IterableOnceOps
 
-    def flatMap[B](f: (Byte) => IterableOnce[B]): Iterator[B]- Definition Classes
- Iterator → IterableOnceOps
 
-    def flatten[B](implicit ev: (Byte) => IterableOnce[B]): Iterator[B]- Definition Classes
- Iterator → IterableOnceOps
 
-    def fold[A1 >: Byte](z: A1)(op: (A1, A1) => A1): A1- Definition Classes
- IterableOnceOps
 
-    def foldLeft[B](z: B)(op: (B, Byte) => B): B- Definition Classes
- ByteIterator → IterableOnceOps
 
-    def foldRight[B](z: B)(op: (Byte, B) => B): B- Definition Classes
- IterableOnceOps
 
-    def forall(p: (Byte) => Boolean): Boolean- Definition Classes
- IterableOnceOps
 
-    def foreach[U](f: (Byte) => U): Unit- Definition Classes
- ByteIterator → IterableOnceOps
 
-    def getByte: ByteGet a single Byte from this iterator. Get a single Byte from this iterator. Identical to next(). 
-    def getByteString(n: Int): ByteStringGet a ByteString with specific number of Bytes from this iterator. Get a ByteString with specific number of Bytes from this iterator. In contrast to copyToArray, this method will fail if this.len < n. 
-    def getBytes(n: Int): Array[Byte]Get a specific number of Bytes from this iterator. Get a specific number of Bytes from this iterator. In contrast to copyToArray, this method will fail if this.len < n. 
-    def getBytes(xs: Array[Byte]): ByteIterator.this.typeGet a specific number of Bytes from this iterator. Get a specific number of Bytes from this iterator. In contrast to copyToArray, this method will fail if this.len < xs.length. 
-   final  def getClass(): Class[_ <: AnyRef]- Definition Classes
- AnyRef → Any
- Annotations
- @HotSpotIntrinsicCandidate() @native()
 
-  def getDouble(implicit byteOrder: ByteOrder): Double
-    def getDoubles(xs: Array[Double])(implicit byteOrder: ByteOrder): ByteIterator.this.typeGet a number of Doubles from this iterator. 
-  def getFloat(implicit byteOrder: ByteOrder): Float
-    def getFloats(xs: Array[Float])(implicit byteOrder: ByteOrder): ByteIterator.this.typeGet a number of Floats from this iterator. 
-    def getInt(implicit byteOrder: ByteOrder): IntGet a single Int from this iterator. 
-    def getInts(xs: Array[Int])(implicit byteOrder: ByteOrder): ByteIterator.this.typeGet a number of Ints from this iterator. 
-    def getLong(implicit byteOrder: ByteOrder): LongGet a single Long from this iterator. 
-    def getLongPart(n: Int)(implicit byteOrder: ByteOrder): LongGet a Long from this iterator where only the least significant nbytes were encoded.
-    def getLongs(xs: Array[Long])(implicit byteOrder: ByteOrder): ByteIterator.this.typeGet a number of Longs from this iterator. 
-    def getShort(implicit byteOrder: ByteOrder): ShortGet a single Short from this iterator. 
-    def getShorts(xs: Array[Short])(implicit byteOrder: ByteOrder): ByteIterator.this.typeGet a number of Shorts from this iterator. 
-    def grouped[B >: Byte](size: Int): GroupedIterator[B]- Definition Classes
- Iterator
 
-    def hashCode(): Int- Definition Classes
- AnyRef → Any
- Annotations
- @HotSpotIntrinsicCandidate() @native()
 
-    def headOption: Option[Byte]- Definition Classes
- BufferedIterator
 
-    def indexOf[B >: Byte](elem: B, from: Int): Int- Definition Classes
- ByteIterator → Iterator
 
-    def indexOf[B >: Byte](elem: B): Int- Definition Classes
- ByteIterator → Iterator
 
-  def indexOf(elem: Byte, from: Int): Int
-  def indexOf(elem: Byte): Int
-    def indexWhere(p: (Byte) => Boolean, from: Int = 0): Int- Definition Classes
- ByteIterator → Iterator
 
-    def isEmpty: Boolean- Definition Classes
- Iterator → IterableOnceOps
- Annotations
- @deprecatedOverriding()
 
-   final  def isInstanceOf[T0]: Boolean- Definition Classes
- Any
 
-    def isTraversableAgain: Boolean- Definition Classes
- IterableOnceOps
 
-   final  def iterator: Iterator[Byte]- Definition Classes
- Iterator → IterableOnce
- Annotations
- @inline()
 
-    def knownSize: Int- Definition Classes
- IterableOnce
 
-   final  def length: Int- Definition Classes
- Iterator
- Annotations
- @inline()
 
-    def map[B](f: (Byte) => B): Iterator[B]- Definition Classes
- Iterator → IterableOnceOps
 
-    def max[B >: Byte](implicit ord: Ordering[B]): Byte- Definition Classes
- IterableOnceOps
 
-    def maxBy[B](f: (Byte) => B)(implicit ord: Ordering[B]): Byte- Definition Classes
- IterableOnceOps
 
-    def maxByOption[B](f: (Byte) => B)(implicit ord: Ordering[B]): Option[Byte]- Definition Classes
- IterableOnceOps
 
-    def maxOption[B >: Byte](implicit ord: Ordering[B]): Option[Byte]- Definition Classes
- IterableOnceOps
 
-    def min[B >: Byte](implicit ord: Ordering[B]): Byte- Definition Classes
- IterableOnceOps
 
-    def minBy[B](f: (Byte) => B)(implicit ord: Ordering[B]): Byte- Definition Classes
- IterableOnceOps
 
-    def minByOption[B](f: (Byte) => B)(implicit ord: Ordering[B]): Option[Byte]- Definition Classes
- IterableOnceOps
 
-    def minOption[B >: Byte](implicit ord: Ordering[B]): Option[Byte]- 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 nextOption(): Option[Byte]- Definition Classes
- Iterator
 
-    def nonEmpty: Boolean- Definition Classes
- IterableOnceOps
- Annotations
- @deprecatedOverriding()
 
-   final  def notify(): Unit- Definition Classes
- AnyRef
- Annotations
- @HotSpotIntrinsicCandidate() @native()
 
-   final  def notifyAll(): Unit- Definition Classes
- AnyRef
- Annotations
- @HotSpotIntrinsicCandidate() @native()
 
-    def padTo[B >: Byte](len: Int, elem: B): Iterator[B]- Definition Classes
- Iterator
 
-    def partition(p: (Byte) => Boolean): (Iterator[Byte], Iterator[Byte])- Definition Classes
- Iterator
 
-    def patch[B >: Byte](from: Int, patchElems: Iterator[B], replaced: Int): Iterator[B]- Definition Classes
- Iterator
 
-    def product[B >: Byte](implicit num: Numeric[B]): B- Definition Classes
- IterableOnceOps
 
-    def reduce[B >: Byte](op: (B, B) => B): B- Definition Classes
- IterableOnceOps
 
-    def reduceLeft[B >: Byte](op: (B, Byte) => B): B- Definition Classes
- IterableOnceOps
 
-    def reduceLeftOption[B >: Byte](op: (B, Byte) => B): Option[B]- Definition Classes
- IterableOnceOps
 
-    def reduceOption[B >: Byte](op: (B, B) => B): Option[B]- Definition Classes
- IterableOnceOps
 
-    def reduceRight[B >: Byte](op: (Byte, B) => B): B- Definition Classes
- IterableOnceOps
 
-    def reduceRightOption[B >: Byte](op: (Byte, B) => B): Option[B]- Definition Classes
- IterableOnceOps
 
-    def reversed: Iterable[Byte]- Attributes
- protected
- Definition Classes
- IterableOnceOps
 
-    def sameElements[B >: Byte](that: IterableOnce[B]): Boolean- Definition Classes
- Iterator
 
-    def scanLeft[B](z: B)(op: (B, Byte) => B): Iterator[B]- Definition Classes
- Iterator → IterableOnceOps
 
-    def size: Int- Definition Classes
- IterableOnceOps
 
-    def slice(from: Int, until: Int): ByteIterator.this.type- Definition Classes
- ByteIterator → Iterator → IterableOnceOps
 
-    def sliceIterator(from: Int, until: Int): Iterator[Byte]- Attributes
- protected
- Definition Classes
- Iterator
 
-    def sliding[B >: Byte](size: Int, step: Int): GroupedIterator[B]- Definition Classes
- Iterator
 
-    def span(p: (Byte) => Boolean): (ByteIterator, ByteIterator)- Definition Classes
- ByteIterator → Iterator → IterableOnceOps
 
-    def splitAt(n: Int): (Iterator[Byte], Iterator[Byte])- Definition Classes
- IterableOnceOps
 
-    def stepper[S <: Stepper[_]](implicit shape: StepperShape[Byte, S]): S- Definition Classes
- IterableOnce
 
-    def sum[B >: Byte](implicit num: Numeric[B]): B- Definition Classes
- IterableOnceOps
 
-   final  def synchronized[T0](arg0: => T0): T0- Definition Classes
- AnyRef
 
-    def take(n: Int): ByteIterator.this.type- Definition Classes
- ByteIterator → Iterator → IterableOnceOps
 
-    def takeWhile(p: (Byte) => Boolean): ByteIterator.this.type- Definition Classes
- ByteIterator → Iterator → IterableOnceOps
 
-    def tapEach[U](f: (Byte) => U): Iterator[Byte]- Definition Classes
- Iterator → IterableOnceOps
 
-    def to[C1](factory: Factory[Byte, C1]): C1- Definition Classes
- IterableOnceOps
 
-    def toArray[B >: Byte](implicit arg0: ClassTag[B]): Array[B]- Definition Classes
- ByteIterator → IterableOnceOps
 
-   final  def toBuffer[B >: Byte]: Buffer[B]- Definition Classes
- IterableOnceOps
- Annotations
- @inline()
 
-    def toIndexedSeq: IndexedSeq[Byte]- Definition Classes
- IterableOnceOps
 
-    def toList: List[Byte]- Definition Classes
- IterableOnceOps
 
-    def toMap[K, V](implicit ev: <:<[Byte, (K, V)]): Map[K, V]- Definition Classes
- IterableOnceOps
 
-    def toSeq: ByteString- Definition Classes
- ByteIterator → IterableOnceOps
 
-    def toSet[B >: Byte]: Set[B]- Definition Classes
- IterableOnceOps
 
-    def toString(): String- Definition Classes
- Iterator → AnyRef → Any
 
-    def toVector: Vector[Byte]- Definition Classes
- IterableOnceOps
 
-   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()
 
-   final  def wait(): Unit- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
 
-    def withFilter(p: (Byte) => Boolean): Iterator[Byte]- Definition Classes
- Iterator
 
-    def zip[B](that: IterableOnce[B]): Iterator[(Byte, B)]- Definition Classes
- Iterator
 
-    def zipAll[A1 >: Byte, B](that: IterableOnce[B], thisElem: A1, thatElem: B): Iterator[(A1, B)]- Definition Classes
- Iterator
 
-    def zipWithIndex: Iterator[(Byte, Int)]- Definition Classes
- Iterator → IterableOnceOps
 
Deprecated Value Members
-    def /:[B](z: B)(op: (B, Byte) => B): B- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte])./:(z)(op) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator.foldLeft instead 
 
-   final  def /:[B](z: B)(op: (B, Byte) => B): B- Definition Classes
- IterableOnceOps
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use foldLeft instead of /: 
 
-    def :\[B](z: B)(op: (Byte, B) => B): B- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).:\(z)(op) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator.foldRight instead 
 
-   final  def :\[B](z: B)(op: (Byte, 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, Byte) => 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, use- ParIterableLike#aggregate.
 
-    def collectFirst[B](f: PartialFunction[Byte, B]): Option[B]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).collectFirst(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.collectFirst(...) instead 
 
-    def copyToBuffer(dest: Buffer[Byte]): Unit- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).copyToBuffer(dest) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.copyToBuffer(...) instead 
 
-   final  def copyToBuffer[B >: Byte](dest: Buffer[B]): Unit- Definition Classes
- IterableOnceOps
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use - dest ++= collinstead
 
-    def count(f: (Byte) => Boolean): Int- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).count(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.count(...) instead 
 
-    def exists(f: (Byte) => Boolean): Boolean- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).exists(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.exists(...) instead 
 
-    def filter(f: (Byte) => Boolean): Iterator[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).filter(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.filter(...) instead 
 
-    def finalize(): Unit- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable]) @Deprecated
- Deprecated
- (Since version 9) 
 
-    def find(p: (Byte) => Boolean): Option[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).find(p) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.find instead 
 
-    def flatMap[B](f: (Byte) => IterableOnce[B]): IterableOnce[B]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).flatMap(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.flatMap instead or consider requiring an Iterable 
 
-    def fold[A1 >: A](z: A1)(op: (A1, A1) => A1): A1- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).fold(z)(op) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.fold instead 
 
-    def foldLeft[B](z: B)(op: (B, Byte) => B): B- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).foldLeft(z)(op) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator.foldLeft instead 
 
-    def foldRight[B](z: B)(op: (Byte, B) => B): B- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).foldRight(z)(op) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator.foldRight instead 
 
-    def forall(f: (Byte) => Boolean): Boolean- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).forall(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.forall(...) instead 
 
-    def foreach[U](f: (Byte) => U): Unit- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).foreach(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator.foreach(...) instead 
 
-    def formatted(fmtstr: String): String- Implicit
- This member is added by an implicit conversion from ByteIterator toStringFormat[ByteIterator] performed by method StringFormat in scala.Predef.
- Definition Classes
- StringFormat
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.12.16) Use - formatString.format(value)instead of- value.formatted(formatString), or use the- f""string interpolator. In Java 15 and later,- formattedresolves to the new method in String which has reversed parameters.
 
-   final  def hasDefiniteSize: Boolean- Definition Classes
- Iterator → IterableOnceOps
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) hasDefiniteSize on Iterator is the same as isEmpty 
 
-    def isEmpty: Boolean- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).isEmpty 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.isEmpty instead 
 
-    def map[B](f: (Byte) => B): IterableOnce[B]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).map(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.map instead or consider requiring an Iterable 
 
-    def max(implicit ord: Ordering[Byte]): Byte- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).max(ord) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.max instead 
 
-    def maxBy[B](f: (Byte) => B)(implicit cmp: Ordering[B]): Byte- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).maxBy(f)(cmp) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.maxBy(...) instead 
 
-    def min(implicit ord: Ordering[Byte]): Byte- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).min(ord) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.min instead 
 
-    def minBy[B](f: (Byte) => B)(implicit cmp: Ordering[B]): Byte- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).minBy(f)(cmp) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.minBy(...) instead 
 
-    def mkString: String- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).mkString 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.mkString instead 
 
-    def mkString(sep: String): String- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).mkString(sep) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.mkString instead 
 
-    def mkString(start: String, sep: String, end: String): String- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).mkString(start, sep, end) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.mkString instead 
 
-    def nonEmpty: Boolean- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).nonEmpty 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.nonEmpty instead 
 
-    def product(implicit num: Numeric[Byte]): Byte- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).product(num) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.product instead 
 
-    def reduce(f: (Byte, Byte) => Byte): Byte- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).reduce(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.reduce(...) instead 
 
-    def reduceLeft(f: (Byte, Byte) => Byte): Byte- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).reduceLeft(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.reduceLeft(...) instead 
 
-    def reduceLeftOption(f: (Byte, Byte) => Byte): Option[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).reduceLeftOption(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.reduceLeftOption(...) instead 
 
-    def reduceOption(f: (Byte, Byte) => Byte): Option[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).reduceOption(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.reduceOption(...) instead 
 
-    def reduceRight(f: (Byte, Byte) => Byte): Byte- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).reduceRight(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.reduceRight(...) instead 
 
-    def reduceRightOption(f: (Byte, Byte) => Byte): Option[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).reduceRightOption(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.reduceRightOption(...) instead 
 
-    def sameElements[B >: A](that: IterableOnce[B]): Boolean- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).sameElements(that) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.sameElements instead 
 
-    def scanRight[B](z: B)(op: (Byte, B) => B): Iterator[B]- Definition Classes
- Iterator
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Call scanRight on an Iterable instead. 
 
-    def seq: ByteIterator.this.type- Definition Classes
- Iterator
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Iterator.seq always returns the iterator itself 
 
-    def size: Int- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).size 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.size instead 
 
-    def sum(implicit num: Numeric[Byte]): Byte- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).sum(num) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.sum instead 
 
-    def to[C1](factory: Factory[Byte, C1]): C1- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).to(factory) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.to(factory) instead 
 
-    def toArray[B >: A](implicit arg0: ClassTag[B]): Array[B]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).toArray(arg0) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.toArray 
 
-    def toBuffer[B >: A]: Buffer[B]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).toBuffer 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.to(ArrayBuffer) instead 
 
-    def toIndexedSeq: IndexedSeq[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).toIndexedSeq 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.toIndexedSeq instead 
 
-   final  def toIterable: Iterable[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator.to(Iterable) instead 
 
-    def toIterator: Iterator[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).toIterator 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator instead 
 
-   final  def toIterator: Iterator[Byte]- Definition Classes
- IterableOnceOps
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator instead of .toIterator 
 
-    def toList: List[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).toList 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.to(List) instead 
 
-    def toMap[K, V](implicit ev: <:<[Byte, (K, V)]): Map[K, V]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).toMap(ev) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.to(Map) instead 
 
-    def toSeq: Seq[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).toSeq 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator.to(Seq) instead 
 
-    def toSet[B >: A]: Set[B]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).toSet 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator.to(Set) instead 
 
-    def toStream: Stream[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).toStream 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator.to(LazyList) instead 
 
-   final  def toStream: Stream[Byte]- Definition Classes
- IterableOnceOps
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .to(LazyList) instead of .toStream 
 
-   final  def toTraversable: Traversable[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator.to(Iterable) instead 
 
-    def toVector: Vector[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).toVector 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated @inline()
- Deprecated
- (Since version 2.13.0) Use .iterator.to(Vector) instead 
 
-    def withFilter(f: (Byte) => Boolean): Iterator[Byte]- Implicit
- This member is added by an implicit conversion from ByteIterator toIterableOnceExtensionMethods[Byte] performed by method iterableOnceExtensionMethods in scala.collection.IterableOnce.
- Shadowing
- This implicitly inherited member is shadowed by one or more members in this class.
 To access this member you can use a type ascription:(byteIterator: IterableOnceExtensionMethods[Byte]).withFilter(f) 
- Definition Classes
- IterableOnceExtensionMethods
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use .iterator.withFilter(...) instead 
 
-    def →[B](y: B): (ByteIterator, B)- Implicit
- This member is added by an implicit conversion from ByteIterator toArrowAssoc[ByteIterator] performed by method ArrowAssoc in scala.Predef.
- Definition Classes
- ArrowAssoc
- Annotations
- @deprecated
- Deprecated
- (Since version 2.13.0) Use - ->instead. If you still wish to display it as one character, consider using a font with programming ligatures such as Fira Code.