Class

fm.lazyseq.SortedLazySeqBuilder

ReadSortedRecords

Related Doc: package SortedLazySeqBuilder

Permalink

final class ReadSortedRecords extends LazySeq[V] with Closeable

A reusable reader that performs a merge sort on the sorted files

Note: We use RandomAccessFile to hold onto the FileDescriptor of the temp file and open FileInputStreams based on the FileDescriptor. This allows us to delete the unlink the temp file from the file system while retaining a reference to it here so we can still read it. Then when the FileDescriptor gets garbage collected OR the JVM shuts down the file will be automatically deleted.

Linear Supertypes
Closeable, AutoCloseable, LazySeq[V], FilterMonadic[V, LazySeq[V]], TraversableOnce[V], GenTraversableOnce[V], AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ReadSortedRecords
  2. Closeable
  3. AutoCloseable
  4. LazySeq
  5. FilterMonadic
  6. TraversableOnce
  7. GenTraversableOnce
  8. AnyRef
  9. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ReadSortedRecords(files: Vector[Vector[MappedByteBuffer]])

    Permalink

Value Members

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ++[B >: V](rest: LazySeq[B]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  4. def /:[B](z: B)(op: (B, V) ⇒ B): B

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

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

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

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

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

    Permalink
    Definition Classes
    TraversableOnce
  10. final def after[U](f: (V) ⇒ U): LazySeq[V]

    Permalink

    Run this function on each item after the foreach function

    Run this function on each item after the foreach function

    This is basically a foreach but without forcing evaluation of this LazySeq.

    Definition Classes
    LazySeq
  11. final def afterWithResource[R, U](resource: Resource[R])(f: (V, R) ⇒ U): LazySeq[V]

    Permalink

    Same as after() but takes a Resource (i.e.

    Same as after() but takes a Resource (i.e. can use it for something like logging)

    Definition Classes
    LazySeq
  12. def aggregate[B](z: ⇒ B)(seqop: (B, V) ⇒ B, combop: (B, B) ⇒ B): B

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

    Permalink
    Definition Classes
    Any
  14. final def assertSorted[B >: V](implicit ord: Ordering[B]): LazySeq[B]

    Permalink

    Assert that this reader is in sorted order

    Assert that this reader is in sorted order

    Definition Classes
    LazySeq
  15. final def assertSortedAndUnique[B >: V](implicit ord: Ordering[B]): LazySeq[B]

    Permalink

    Assert that this reader is in sorted order AND unique

    Assert that this reader is in sorted order AND unique

    Definition Classes
    LazySeq
  16. final def assertSortedAndUniqueBy[K](key: (V) ⇒ K)(implicit ord: Ordering[K]): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  17. final def assertSortedBy[K](key: (V) ⇒ K)(implicit ord: Ordering[K]): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  18. final def before[U](f: (V) ⇒ U): LazySeq[V]

    Permalink

    Run this function on each item before the foreach function

    Run this function on each item before the foreach function

    This is basically a foreach but without forcing evaluation of this LazySeq.

    Definition Classes
    LazySeq
  19. final def beforeWithResource[R, U](resource: Resource[R])(f: (V, R) ⇒ U): LazySeq[V]

    Permalink

    Same as before() but takes a Resource (i.e.

    Same as before() but takes a Resource (i.e. can use it for something like logging)

    Definition Classes
    LazySeq
  20. final def bucketize[B >: V](num: Int)(implicit serializer: Serializer[B]): Vector[LazySeq[B]]

    Permalink

    Split the LazySeq into num buckets of equal size using a round-robin algorithm

    Split the LazySeq into num buckets of equal size using a round-robin algorithm

    Definition Classes
    LazySeq
  21. final def buffered(size: Int = 0): LazySeq[V]

    Permalink

    Creates an asynchronous buffer that spins up a producer thread which feeds data into a BlockingQueue that is read using the resulting LazySeq.

    Creates an asynchronous buffer that spins up a producer thread which feeds data into a BlockingQueue that is read using the resulting LazySeq.

    Definition Classes
    LazySeq
  22. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  23. def close(): Unit

    Permalink
    Definition Classes
    ReadSortedRecords → Closeable → AutoCloseable
  24. final def collapseBy[B >: V, K](key: (B) ⇒ K)(op: (B, B) ⇒ B)(implicit ord: Ordering[K]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  25. final def collect[B](pf: PartialFunction[V, B]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  26. def collectFirst[B](pf: PartialFunction[V, B]): Option[B]

    Permalink
    Definition Classes
    TraversableOnce
  27. final def copyToArray[B >: V](xs: Array[B], start: Int, len: Int): Unit

    Permalink
    Definition Classes
    LazySeq → TraversableOnce → GenTraversableOnce
  28. def copyToArray[B >: V](xs: Array[B]): Unit

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

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

    Permalink
    Definition Classes
    TraversableOnce
  31. def count(p: (V) ⇒ Boolean): Int

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  32. final def drop(n: Int): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  33. final def dropRight(n: Int): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  34. final def dropWhile(p: (V) ⇒ Boolean): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  35. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  37. final def exists(p: (V) ⇒ Boolean): Boolean

    Permalink
    Definition Classes
    LazySeq → TraversableOnce → GenTraversableOnce
  38. final def filter(p: (V) ⇒ Boolean): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  39. final def filterNot(p: (V) ⇒ Boolean): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  40. def finalize(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    ReadSortedRecords → AnyRef
  41. final def find(p: (V) ⇒ Boolean): Option[V]

    Permalink
    Definition Classes
    LazySeq → TraversableOnce → GenTraversableOnce
  42. final def flatMap[B, That](f: (V) ⇒ GenTraversableOnce[B])(implicit bf: CanBuildFrom[LazySeq[V], B, That]): That

    Permalink
    Definition Classes
    LazySeq → FilterMonadic
  43. final def flatten[B](implicit asTraversable: (V) ⇒ GenTraversableOnce[B]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  44. def fold[A1 >: V](z: A1)(op: (A1, A1) ⇒ A1): A1

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

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

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  47. final def forall(p: (V) ⇒ Boolean): Boolean

    Permalink
    Definition Classes
    LazySeq → TraversableOnce → GenTraversableOnce
  48. def foreach[U](f: (V) ⇒ U): Unit

    Permalink

    This is the method that sub-classes must implement

    This is the method that sub-classes must implement

    Definition Classes
    ReadSortedRecordsLazySeq → FilterMonadic → TraversableOnce → GenTraversableOnce
  49. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  50. final def groupBy[B >: V, K](f: (V) ⇒ K)(implicit serializer: Serializer[B]): Map[K, LazySeq[B]]

    Permalink
    Definition Classes
    LazySeq
  51. final def groupBy[B >: V, K](serializer: Serializer[B])(f: (V) ⇒ K): Map[K, LazySeq[B]]

    Permalink

    Mostly standard group by implementation that uses tmp files to store the values of the HashMap

    Mostly standard group by implementation that uses tmp files to store the values of the HashMap

    Definition Classes
    LazySeq
  52. final def grouped[B >: V](size: Int, additionalIncrement: (B) ⇒ Int): LazySeq[IndexedSeq[B]]

    Permalink
    Definition Classes
    LazySeq
  53. final def grouped[B >: V](size: Int): LazySeq[IndexedSeq[B]]

    Permalink
    Definition Classes
    LazySeq
  54. final def groupedBy[K](by: (V) ⇒ K): LazySeq[(K, IndexedSeq[V])]

    Permalink

    A cross between grouped and groupBy that allows you to specify a key to be used (like in groupBy) instead of a fixed count (like in grouped).

    A cross between grouped and groupBy that allows you to specify a key to be used (like in groupBy) instead of a fixed count (like in grouped). All elements next to each other with the same key get returned in each group.

    e.g. LazySeq.wrap(Seq(1,1,1,2,2,1)).groupedBy{ a => a }.toIndexedSeq => Vector((1,Vector(1, 1, 1)), (2,Vector(2, 2)), (1,Vector(1)))

    Definition Classes
    LazySeq
  55. def hasDefiniteSize: Boolean

    Permalink
    Definition Classes
    LazySeq → TraversableOnce → GenTraversableOnce
  56. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  57. def head: V

    Permalink
    Definition Classes
    LazySeq
  58. def headOption: Option[V]

    Permalink
    Definition Classes
    LazySeq
  59. def isEmpty: Boolean

    Permalink
    Definition Classes
    LazySeq → TraversableOnce → GenTraversableOnce
  60. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  61. def isTraversableAgain: Boolean

    Permalink
    Definition Classes
    LazySeq → GenTraversableOnce
  62. final def map[B, That](f: (V) ⇒ B)(implicit bf: CanBuildFrom[LazySeq[V], B, That]): That

    Permalink
    Definition Classes
    LazySeq → FilterMonadic
  63. def max[B >: V](implicit cmp: Ordering[B]): V

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

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  65. final def mergeCorresponding[B >: V](that: LazySeq[B])(implicit ord: Ordering[B]): LazySeq[EitherOrBoth[B, B]]

    Permalink
    Definition Classes
    LazySeq
  66. final def mergeCorrespondingByKey[R, K](that: LazySeq[R], thisKey: (V) ⇒ K, thatKey: (R) ⇒ K)(implicit ord: Ordering[K]): LazySeq[EitherOrBoth[V, R]]

    Permalink

    Merge corresponding records from this sorted read with that sorted reader given a method to get a common key that can be compared.

    Merge corresponding records from this sorted read with that sorted reader given a method to get a common key that can be compared.

    Definition Classes
    LazySeq
  67. def min[B >: V](implicit cmp: Ordering[B]): V

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

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

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

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

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  72. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  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. final def onFirst[U](f: (V) ⇒ U): LazySeq[V]

    Permalink

    Execute the method on the first element of the LazySeq whenever it is evaluated.

    Execute the method on the first element of the LazySeq whenever it is evaluated.

    Note: The first element is still call via foreach

    Definition Classes
    LazySeq
  77. final def onLast[U](f: (V) ⇒ U): LazySeq[V]

    Permalink

    Same as onFirst except for the last element whenever it is evaluated

    Same as onFirst except for the last element whenever it is evaluated

    Definition Classes
    LazySeq
  78. final def parFlatMap[B](threads: Int = LazySeq.defaultThreadCount, inputBuffer: Int = LazySeq.defaultThreadCount, resultBuffer: Int = LazySeq.defaultThreadCount * 4)(f: (V) ⇒ GenTraversableOnce[B]): LazySeq[B]

    Permalink

    Performs a parallel flat map maintaining ordered output

    Performs a parallel flat map maintaining ordered output

    Definition Classes
    LazySeq
  79. final def parFlatMap[B](f: (V) ⇒ GenTraversableOnce[B]): LazySeq[B]

    Permalink

    Performs a parallel flat map maintaining ordered output

    Performs a parallel flat map maintaining ordered output

    Definition Classes
    LazySeq
  80. final def parForeach[U](threads: Int = LazySeq.defaultThreadCount, inputBuffer: Int = LazySeq.defaultThreadCount)(f: (V) ⇒ U): Unit

    Permalink

    A Parallel foreach

    A Parallel foreach

    Definition Classes
    LazySeq
  81. final def parForeach[U](f: (V) ⇒ U): Unit

    Permalink

    A Parallel foreach

    A Parallel foreach

    Definition Classes
    LazySeq
  82. final def parMap[B](threads: Int = LazySeq.defaultThreadCount, inputBuffer: Int = LazySeq.defaultThreadCount, resultBuffer: Int = LazySeq.defaultThreadCount * 4)(f: (V) ⇒ B): LazySeq[B]

    Permalink

    Performs a parallel map maintaining ordered output

    Performs a parallel map maintaining ordered output

    Definition Classes
    LazySeq
  83. final def parMap[B](f: (V) ⇒ B): LazySeq[B]

    Permalink

    Performs a parallel map maintaining ordered output

    Performs a parallel map maintaining ordered output

    Definition Classes
    LazySeq
  84. final def partition[B >: V](p: (V) ⇒ Boolean)(implicit serializer: Serializer[B]): (LazySeq[B], LazySeq[B])

    Permalink

    Standard partition implementation using LazySeqs

    Standard partition implementation using LazySeqs

    Definition Classes
    LazySeq
  85. def product[B >: V](implicit num: Numeric[B]): B

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

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

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

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

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

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

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  92. def reversed: List[V]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    TraversableOnce
  93. def seq: LazySeq[V]

    Permalink
    Definition Classes
    LazySeq → TraversableOnce → GenTraversableOnce
  94. final def shuffle[B >: V](implicit serializer: Serializer[B]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  95. final def shuffle[B >: V](seed: Long)(implicit serializer: Serializer[B]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  96. final def shuffle[B >: V](random: Random)(implicit serializer: Serializer[B]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  97. def size: Int

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  98. final def slice(from: Int, until: Int): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  99. final def sortAndCollapseBy[B >: V, K](bufferSizeLimitMB: Int, bufferRecordLimit: Int)(key: (B) ⇒ K)(op: (B, B) ⇒ B)(implicit serializer: Serializer[B], ord: Ordering[K]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  100. final def sortAndCollapseBy[B >: V, K](serializer: Serializer[B], bufferSizeLimitMB: Int, bufferRecordLimit: Int)(key: (B) ⇒ K)(op: (B, B) ⇒ B)(implicit ord: Ordering[K]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  101. final def sortAndCollapseBy[B >: V, K](key: (B) ⇒ K)(op: (B, B) ⇒ B)(implicit serializer: Serializer[B], ord: Ordering[K]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  102. final def sortAndCollapseBy[B >: V, K](serializer: Serializer[B])(key: (B) ⇒ K)(op: (B, B) ⇒ B)(implicit ord: Ordering[K]): LazySeq[B]

    Permalink

    Collapse elements with the same key by applying a binary operator.

    Collapse elements with the same key by applying a binary operator.

    Should be similar to doing something like: reader.groupBy(key).values.flatMap{ _.reduce(op) }

    Definition Classes
    LazySeq
  103. final def sortBy[B >: V, K](bufferSizeLimitMB: Int, bufferRecordLimit: Int)(f: (B) ⇒ K)(implicit serializer: Serializer[B], ord: Ordering[K]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  104. final def sortBy[B >: V, K](serializer: Serializer[B], bufferSizeLimitMB: Int, bufferRecordLimit: Int)(f: (B) ⇒ K)(implicit ord: Ordering[K]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  105. final def sortBy[B >: V, K](f: (B) ⇒ K)(implicit serializer: Serializer[B], ord: Ordering[K]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  106. final def sortBy[B >: V, K](serializer: Serializer[B])(f: (B) ⇒ K)(implicit ord: Ordering[K]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  107. final def sorted[B >: V](bufferSizeLimitMB: Int, bufferRecordLimit: Int)(implicit serializer: Serializer[B], ord: Ordering[B]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  108. final def sorted[B >: V](implicit serializer: Serializer[B], ord: Ordering[B]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  109. def sum[B >: V](implicit num: Numeric[B]): B

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

    Permalink
    Definition Classes
    AnyRef
  111. final def take(n: Int): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  112. final def takeWhile(p: (V) ⇒ Boolean): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  113. def to[Col[_]](implicit cbf: CanBuildFrom[Nothing, V, Col[V]]): Col[V]

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

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  115. def toBuffer[B >: V]: Buffer[B]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  116. def toIndexedSeq: IndexedSeq[V]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  117. def toIterable: Iterable[V]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  118. def toIterator(batchSize: Int = 32, bufferSize: Int = 0): LazySeqIterator[V]

    Permalink
    Definition Classes
    LazySeq
  119. def toIterator: LazySeqIterator[V]

    Permalink
    Definition Classes
    LazySeq → GenTraversableOnce
  120. def toList: List[V]

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

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  122. def toSeq: Seq[V]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  123. def toSet[B >: V]: Set[B]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  124. def toStream: Stream[V]

    Permalink
    Definition Classes
    LazySeq → GenTraversableOnce
  125. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  126. def toTraversable: Traversable[V]

    Permalink
    Definition Classes
    LazySeq → TraversableOnce → GenTraversableOnce
  127. def toVector: Vector[V]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  128. final def unique: LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  129. final def uniqueSortBy[B >: V, K](f: (B) ⇒ K)(implicit serializer: Serializer[B], ord: Ordering[K]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  130. final def uniqueSortBy[B >: V, K](serializer: Serializer[B])(f: (B) ⇒ K)(implicit ord: Ordering[K]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  131. final def uniqueSorted[B >: V](implicit serializer: Serializer[B], ord: Ordering[B]): LazySeq[B]

    Permalink
    Definition Classes
    LazySeq
  132. final def uniqueUsing[K](f: (V) ⇒ K): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq
  133. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  136. final def withFilter(p: (V) ⇒ Boolean): LazySeq[V]

    Permalink
    Definition Classes
    LazySeq → FilterMonadic
  137. final def zipWithIndex: LazySeq[(V, Int)]

    Permalink
    Definition Classes
    LazySeq

Inherited from Closeable

Inherited from AutoCloseable

Inherited from LazySeq[V]

Inherited from FilterMonadic[V, LazySeq[V]]

Inherited from TraversableOnce[V]

Inherited from GenTraversableOnce[V]

Inherited from AnyRef

Inherited from Any

Ungrouped