Class/Object

com.fulcrumgenomics.commons.async

AsyncIterator

Related Docs: object AsyncIterator | package async

Permalink

class AsyncIterator[T] extends Iterator[T] with AsyncRunnable

An asynchronous wrapper for an Iterator. A separate thread will be created to consume the source iterator. Will buffer up to bufferSize elements before the blocking when consuming the source.

T

the type of object to consume

Linear Supertypes
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. AsyncIterator
  2. AsyncRunnable
  3. Runnable
  4. Iterator
  5. TraversableOnce
  6. GenTraversableOnce
  7. AnyRef
  8. Any
Implicitly
  1. by MonadOps
  2. by any2stringadd
  3. by StringFormat
  4. by Ensuring
  5. by ArrowAssoc
  6. by alternateImplicit
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new AsyncIterator(source: Iterator[T], bufferSize: Option[Int] = None)

    Permalink

    source

    the source iterator to consume

    bufferSize

    the maximum number of elements to buffer before the blocking when consuming the source, or None if unbounded.

Type Members

  1. class GroupedIterator[B >: A] extends AbstractIterator[Seq[B]] with Iterator[Seq[B]]

    Permalink
    Definition Classes
    Iterator

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. def +(other: String): String

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to any2stringadd[AsyncIterator[T]] performed by method any2stringadd in scala.Predef.
    Definition Classes
    any2stringadd
  4. def ++[B >: T](that: ⇒ GenTraversableOnce[B]): Iterator[B]

    Permalink
    Definition Classes
    Iterator
  5. def ->[B](y: B): (AsyncIterator[T], B)

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to ArrowAssoc[AsyncIterator[T]] performed by method ArrowAssoc in scala.Predef.
    Definition Classes
    ArrowAssoc
    Annotations
    @inline()
  6. def /:[B](z: B)(op: (B, T) ⇒ B): B

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  7. def :\[B](z: B)(op: (T, B) ⇒ B): B

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  8. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  9. def addString(b: StringBuilder): StringBuilder

    Permalink
    Definition Classes
    TraversableOnce
  10. def addString(b: StringBuilder, sep: String): StringBuilder

    Permalink
    Definition Classes
    TraversableOnce
  11. def addString(b: StringBuilder, start: String, sep: String, end: String): StringBuilder

    Permalink
    Definition Classes
    TraversableOnce
  12. def aggregate[B](z: ⇒ B)(seqop: (B, T) ⇒ B, combop: (B, B) ⇒ B): B

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  13. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  14. def awaitDone(): Unit

    Permalink

    Waits for the run() method to complete.

    Waits for the run() method to complete.

    Definition Classes
    AsyncRunnable
  15. def awaitStart(): Unit

    Permalink

    Waits for the run() method to start.

    Waits for the run() method to start.

    Definition Classes
    AsyncRunnable
  16. def buffered: BufferedIterator[T]

    Permalink
    Definition Classes
    Iterator
  17. final def checkAndRaise(): Unit

    Permalink

    Checks to see if an exception has been raised by an asynchronous thread and if so rethrows it.

    Checks to see if an exception has been raised by an asynchronous thread and if so rethrows it. Use this method before code that assumes the threads have not encountered an exception.

    Attributes
    protected
    Definition Classes
    AsyncRunnable
  18. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  19. def collect[B](pf: PartialFunction[T, B]): Iterator[B]

    Permalink
    Definition Classes
    Iterator
    Annotations
    @migration
    Migration

    (Changed in version 2.8.0) collect has changed. The previous behavior can be reproduced with toSeq.

  20. def collectFirst[B](pf: PartialFunction[T, B]): Option[B]

    Permalink
    Definition Classes
    TraversableOnce
  21. def contains(elem: Any): Boolean

    Permalink
    Definition Classes
    Iterator
  22. def copyToArray[B >: T](xs: Array[B], start: Int, len: Int): Unit

    Permalink
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  23. def copyToArray[B >: T](xs: Array[B]): Unit

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  24. def copyToArray[B >: T](xs: Array[B], start: Int): Unit

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  25. def copyToBuffer[B >: T](dest: Buffer[B]): Unit

    Permalink
    Definition Classes
    TraversableOnce
  26. def corresponds[B](that: GenTraversableOnce[B])(p: (T, B) ⇒ Boolean): Boolean

    Permalink
    Definition Classes
    Iterator
  27. def count(p: (T) ⇒ Boolean): Int

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  28. def done: Boolean

    Permalink

    Returns true if the run() method has completed, false otherwise.

    Returns true if the run() method has completed, false otherwise.

    Definition Classes
    AsyncRunnable
  29. def drop(n: Int): Iterator[T]

    Permalink
    Definition Classes
    Iterator
  30. def dropWhile(p: (T) ⇒ Boolean): Iterator[T]

    Permalink
    Definition Classes
    Iterator
  31. def duplicate: (Iterator[T], Iterator[T])

    Permalink
    Definition Classes
    Iterator
  32. def ensuring(cond: (AsyncIterator[T]) ⇒ Boolean, msg: ⇒ Any): AsyncIterator[T]

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to Ensuring[AsyncIterator[T]] performed by method Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  33. def ensuring(cond: (AsyncIterator[T]) ⇒ Boolean): AsyncIterator[T]

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to Ensuring[AsyncIterator[T]] performed by method Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  34. def ensuring(cond: Boolean, msg: ⇒ Any): AsyncIterator[T]

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to Ensuring[AsyncIterator[T]] performed by method Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  35. def ensuring(cond: Boolean): AsyncIterator[T]

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to Ensuring[AsyncIterator[T]] performed by method Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  36. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  37. def equals(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  38. def execute(): Unit

    Permalink

    The method that does the asynchronous work.

    The method that does the asynchronous work.

    Attributes
    protected
    Definition Classes
    AsyncIteratorAsyncRunnable
  39. def exists(p: (T) ⇒ Boolean): Boolean

    Permalink
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  40. def filter(p: (T) ⇒ Boolean): Iterator[T]

    Permalink
    Definition Classes
    Iterator
  41. def filterNot(p: (T) ⇒ Boolean): Iterator[T]

    Permalink
    Definition Classes
    Iterator
  42. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  43. def find(p: (T) ⇒ Boolean): Option[T]

    Permalink
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  44. def flatMap[B](f: (T) ⇒ GenTraversableOnce[B]): Iterator[B]

    Permalink
    Definition Classes
    Iterator
  45. def fold[A1 >: T](z: A1)(op: (A1, A1) ⇒ A1): A1

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  46. def foldLeft[B](z: B)(op: (B, T) ⇒ B): B

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  47. def foldRight[B](z: B)(op: (T, B) ⇒ B): B

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  48. def forall(p: (T) ⇒ Boolean): Boolean

    Permalink
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  49. def foreach[U](f: (T) ⇒ U): Unit

    Permalink
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  50. def formatted(fmtstr: String): String

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to StringFormat[AsyncIterator[T]] performed by method StringFormat in scala.Predef.
    Definition Classes
    StringFormat
    Annotations
    @inline()
  51. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  52. def grouped[B >: T](size: Int): GroupedIterator[B]

    Permalink
    Definition Classes
    Iterator
  53. def hasDefiniteSize: Boolean

    Permalink
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  54. def hasNext(): Boolean

    Permalink

    Returns true if there exists more elements, false otherwise

    Returns true if there exists more elements, false otherwise

    Definition Classes
    AsyncIterator → Iterator
  55. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  56. def indexOf[B >: T](elem: B): Int

    Permalink
    Definition Classes
    Iterator
  57. def indexWhere(p: (T) ⇒ Boolean): Int

    Permalink
    Definition Classes
    Iterator
  58. def isEmpty: Boolean

    Permalink
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  59. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  60. def isTraversableAgain: Boolean

    Permalink
    Definition Classes
    Iterator → GenTraversableOnce
  61. def length: Int

    Permalink
    Definition Classes
    Iterator
  62. def map[B](f: (T) ⇒ B): Iterator[B]

    Permalink
    Definition Classes
    Iterator
  63. def max[B >: T](implicit cmp: Ordering[B]): T

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  64. def maxBy[B](f: (T) ⇒ B)(implicit cmp: Ordering[B]): T

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  65. def min[B >: T](implicit cmp: Ordering[B]): T

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  66. def minBy[B](f: (T) ⇒ B)(implicit cmp: Ordering[B]): T

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  67. def mkString: String

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  68. def mkString(sep: String): String

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  69. def mkString(start: String, sep: String, end: String): String

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  70. val name: String

    Permalink

    The name of this runnable.

    The name of this runnable. This is used as the name of the thread in thread() as well. The name is created based on the class name and the number of AsyncRunnables already created.

    Definition Classes
    AsyncRunnable
  71. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  72. def next(): T

    Permalink

    Gets the next item.

    Gets the next item.

    Definition Classes
    AsyncIterator → Iterator
  73. def nonEmpty: Boolean

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  74. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  75. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  76. def padTo[A1 >: T](len: Int, elem: A1): Iterator[A1]

    Permalink
    Definition Classes
    Iterator
  77. def partition(p: (T) ⇒ Boolean): (Iterator[T], Iterator[T])

    Permalink
    Definition Classes
    Iterator
  78. def patch[B >: T](from: Int, patchElems: Iterator[B], replaced: Int): Iterator[B]

    Permalink
    Definition Classes
    Iterator
  79. def product[B >: T](implicit num: Numeric[B]): B

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  80. def reduce[A1 >: T](op: (A1, A1) ⇒ A1): A1

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  81. def reduceLeft[B >: T](op: (B, T) ⇒ B): B

    Permalink
    Definition Classes
    TraversableOnce
  82. def reduceLeftOption[B >: T](op: (B, T) ⇒ B): Option[B]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  83. def reduceOption[A1 >: T](op: (A1, A1) ⇒ A1): Option[A1]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  84. def reduceRight[B >: T](op: (T, B) ⇒ B): B

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  85. def reduceRightOption[B >: T](op: (T, B) ⇒ B): Option[B]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  86. def reversed: List[T]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    TraversableOnce
  87. final def run(): Unit

    Permalink
    Definition Classes
    AsyncRunnable → Runnable
  88. def sameElements(that: Iterator[_]): Boolean

    Permalink
    Definition Classes
    Iterator
  89. def scanLeft[B](z: B)(op: (B, T) ⇒ B): Iterator[B]

    Permalink
    Definition Classes
    Iterator
  90. def scanRight[B](z: B)(op: (T, B) ⇒ B): Iterator[B]

    Permalink
    Definition Classes
    Iterator
  91. def seq: Iterator[T]

    Permalink
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  92. def size: Int

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  93. def slice(from: Int, until: Int): Iterator[T]

    Permalink
    Definition Classes
    Iterator
  94. def sliding[B >: T](size: Int, step: Int): GroupedIterator[B]

    Permalink
    Definition Classes
    Iterator
  95. def span(p: (T) ⇒ Boolean): (Iterator[T], Iterator[T])

    Permalink
    Definition Classes
    Iterator
  96. final def start(name: Option[String] = None, daemon: Boolean = true): AsyncIterator.this.type

    Permalink

    Starts this Runnable in a daemon thread.

    Starts this Runnable in a daemon thread.

    name

    optionally the name of the thread, otherwise a name is created based on the class name and the number of threads already created.

    Definition Classes
    AsyncRunnable
  97. def started: Boolean

    Permalink

    Returns true if the run() method has started, false otherwise.

    Returns true if the run() method has started, false otherwise.

    Definition Classes
    AsyncRunnable
  98. def sum[B >: T](implicit num: Numeric[B]): B

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  99. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  100. def take(n: Int): Iterator[T]

    Permalink
    Definition Classes
    Iterator
  101. def takeWhile(p: (T) ⇒ Boolean): Iterator[T]

    Permalink
    Definition Classes
    Iterator
  102. final def thread(): Thread

    Permalink

    Creates a new thread wrapping this runnable; the thread is not started.

    Creates a new thread wrapping this runnable; the thread is not started.

    Definition Classes
    AsyncRunnable
  103. def throwable: Option[Throwable]

    Permalink

    Returns a throwable if an exception occurred in the run() method, None otherwise.

    Returns a throwable if an exception occurred in the run() method, None otherwise.

    Definition Classes
    AsyncRunnable
  104. def to[Col[_]](implicit cbf: CanBuildFrom[Nothing, T, Col[T]]): Col[T]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  105. def toArray[B >: T](implicit arg0: ClassTag[B]): Array[B]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  106. def toBuffer[B >: T]: Buffer[B]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  107. def toIndexedSeq: IndexedSeq[T]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  108. def toIterable: Iterable[T]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  109. def toIterator: Iterator[T]

    Permalink
    Definition Classes
    Iterator → GenTraversableOnce
  110. def toList: List[T]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  111. def toMap[T, U](implicit ev: <:<[T, (T, U)]): Map[T, U]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  112. def toSeq: Seq[T]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  113. def toSet[B >: T]: Set[B]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  114. def toStream: Stream[T]

    Permalink
    Definition Classes
    Iterator → GenTraversableOnce
  115. def toString(): String

    Permalink
    Definition Classes
    Iterator → AnyRef → Any
  116. def toTraversable: Traversable[T]

    Permalink
    Definition Classes
    Iterator → TraversableOnce → GenTraversableOnce
  117. def toVector: Vector[T]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  118. def tryAndModifyInterruptedException[T](message: String)(f: ⇒ T): T

    Permalink

    Executes the given block of code.

    Executes the given block of code. If an InterruptedException is thrown, throws a RuntimeException with the given message. Use this method for blocking code that when interrupted should not be recoverable.

    message

    the message to use if an InterruptedException is thrown by the block of code

    f

    the block of code to execute

    Attributes
    protected
    Definition Classes
    AsyncRunnable
  119. def uponDone()(implicit ec: ExecutionContext): Awaitable[Option[Throwable]]

    Permalink

    Returns an Awaitable that completes when the run() method has completed.

    Returns an Awaitable that completes when the run() method has completed. Returns the throwable if an exception was encountered, None otherwise.

    Definition Classes
    AsyncRunnable
  120. def uponException(): Unit

    Permalink

    The method to execute if an exception occurs in the asynchronous thread.

    The method to execute if an exception occurs in the asynchronous thread. This should not block.

    Attributes
    protected
    Definition Classes
    AsyncRunnable
  121. def uponFinally(): Unit

    Permalink

    The method to execute upon successfully execution of the run method or an exception occurs.

    The method to execute upon successfully execution of the run method or an exception occurs. This should not block.

    Attributes
    protected
    Definition Classes
    AsyncRunnable
  122. def uponStart()(implicit ec: ExecutionContext): Awaitable[Unit]

    Permalink

    Returns an Awaitable that completes when the run() method has started.

    Returns an Awaitable that completes when the run() method has started. Returns the throwable if an exception was encountered, None otherwise.

    Definition Classes
    AsyncRunnable
  123. final def wait(): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  124. final def wait(arg0: Long, arg1: Int): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  125. final def wait(arg0: Long): Unit

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  126. def withFilter(p: (T) ⇒ Boolean): Iterator[T]

    Permalink
    Definition Classes
    Iterator
  127. def zip[B](that: Iterator[B]): Iterator[(T, B)]

    Permalink
    Definition Classes
    Iterator
  128. def zipAll[B, A1 >: T, B1 >: B](that: Iterator[B], thisElem: A1, thatElem: B1): Iterator[(A1, B1)]

    Permalink
    Definition Classes
    Iterator
  129. def zipWithIndex: Iterator[(T, Int)]

    Permalink
    Definition Classes
    Iterator
  130. def [B](y: B): (AsyncIterator[T], B)

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to ArrowAssoc[AsyncIterator[T]] performed by method ArrowAssoc in scala.Predef.
    Definition Classes
    ArrowAssoc

Shadowed Implicit Value Members

  1. def filter(p: (T) ⇒ Boolean): TraversableOnce[T]

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to MonadOps[T] performed by method MonadOps in scala.collection.TraversableOnce.
    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:
    (asyncIterator: MonadOps[T]).filter(p)
    Definition Classes
    MonadOps
  2. def flatMap[B](f: (T) ⇒ GenTraversableOnce[B]): TraversableOnce[B]

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to MonadOps[T] performed by method MonadOps in scala.collection.TraversableOnce.
    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:
    (asyncIterator: MonadOps[T]).flatMap(f)
    Definition Classes
    MonadOps
  3. def map[B](f: (T) ⇒ B): TraversableOnce[B]

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to MonadOps[T] performed by method MonadOps in scala.collection.TraversableOnce.
    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:
    (asyncIterator: MonadOps[T]).map(f)
    Definition Classes
    MonadOps
  4. def withFilter(p: (T) ⇒ Boolean): Iterator[T]

    Permalink
    Implicit information
    This member is added by an implicit conversion from AsyncIterator[T] to MonadOps[T] performed by method MonadOps in scala.collection.TraversableOnce.
    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:
    (asyncIterator: MonadOps[T]).withFilter(p)
    Definition Classes
    MonadOps

Inherited from AsyncRunnable

Inherited from Runnable

Inherited from Iterator[T]

Inherited from TraversableOnce[T]

Inherited from GenTraversableOnce[T]

Inherited from AnyRef

Inherited from Any

Inherited by implicit conversion MonadOps from AsyncIterator[T] to MonadOps[T]

Inherited by implicit conversion any2stringadd from AsyncIterator[T] to any2stringadd[AsyncIterator[T]]

Inherited by implicit conversion StringFormat from AsyncIterator[T] to StringFormat[AsyncIterator[T]]

Inherited by implicit conversion Ensuring from AsyncIterator[T] to Ensuring[AsyncIterator[T]]

Inherited by implicit conversion ArrowAssoc from AsyncIterator[T] to ArrowAssoc[AsyncIterator[T]]

Inherited by implicit conversion alternateImplicit from AsyncIterator[T] to ForceImplicitAmbiguity

Ungrouped