Class

org.apache.spark.util.collection

ExternalAppendOnlyMap

Related Doc: package collection

Permalink

class ExternalAppendOnlyMap[K, V, C] extends Spillable[SizeTracker] with Serializable with Logging with Iterable[(K, C)]

:: DeveloperApi :: An append-only map that spills sorted content to disk when there is insufficient space for it to grow.

This map takes two passes over the data:

(1) Values are merged into combiners, which are sorted and spilled to disk as necessary (2) Combiners are read from disk and merged together

The setting of the spill threshold faces the following trade-off: If the spill threshold is too high, the in-memory map may occupy more memory than is available, resulting in OOM. However, if the spill threshold is too low, we spill frequently and incur unnecessary disk writes. This may lead to a performance regression compared to the normal case of using the non-spilling AppendOnlyMap.

Annotations
@DeveloperApi()
Linear Supertypes
Iterable[(K, C)], IterableLike[(K, C), Iterable[(K, C)]], Equals, GenIterable[(K, C)], GenIterableLike[(K, C), Iterable[(K, C)]], Traversable[(K, C)], GenTraversable[(K, C)], GenericTraversableTemplate[(K, C), Iterable], TraversableLike[(K, C), Iterable[(K, C)]], GenTraversableLike[(K, C), Iterable[(K, C)]], Parallelizable[(K, C), ParIterable[(K, C)]], TraversableOnce[(K, C)], GenTraversableOnce[(K, C)], FilterMonadic[(K, C), Iterable[(K, C)]], HasNewBuilder[(K, C), Iterable[(K, C)] @scala.annotation.unchecked.uncheckedVariance], Serializable, Spillable[SizeTracker], Logging, MemoryConsumer, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. ExternalAppendOnlyMap
  2. Iterable
  3. IterableLike
  4. Equals
  5. GenIterable
  6. GenIterableLike
  7. Traversable
  8. GenTraversable
  9. GenericTraversableTemplate
  10. TraversableLike
  11. GenTraversableLike
  12. Parallelizable
  13. TraversableOnce
  14. GenTraversableOnce
  15. FilterMonadic
  16. HasNewBuilder
  17. Serializable
  18. Spillable
  19. Logging
  20. MemoryConsumer
  21. AnyRef
  22. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ExternalAppendOnlyMap(createCombiner: (V) ⇒ C, mergeValue: (C, V) ⇒ C, mergeCombiners: (C, C) ⇒ C, serializer: Serializer, blockManager: BlockManager)

    Permalink
  2. new ExternalAppendOnlyMap(createCombiner: (V) ⇒ C, mergeValue: (C, V) ⇒ C, mergeCombiners: (C, C) ⇒ C, serializer: Serializer = SparkEnv.get.serializer, blockManager: BlockManager = SparkEnv.get.blockManager, context: TaskContext = TaskContext.get(), serializerManager: SerializerManager = SparkEnv.get.serializerManager)

    Permalink

Type Members

  1. type Self = Iterable[(K, C)]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    TraversableLike
  2. class WithFilter extends FilterMonadic[A, Repr]

    Permalink
    Definition Classes
    TraversableLike

Value Members

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  3. def ++[B >: (K, C), That](that: GenTraversableOnce[B])(implicit bf: CanBuildFrom[Iterable[(K, C)], B, That]): That

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  4. def ++:[B >: (K, C), That](that: Traversable[B])(implicit bf: CanBuildFrom[Iterable[(K, C)], B, That]): That

    Permalink
    Definition Classes
    TraversableLike
  5. def ++:[B >: (K, C), That](that: TraversableOnce[B])(implicit bf: CanBuildFrom[Iterable[(K, C)], B, That]): That

    Permalink
    Definition Classes
    TraversableLike
  6. def /:[B](z: B)(op: (B, (K, C)) ⇒ B): B

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  9. def acquireMemory(size: Long): Long

    Permalink
    Definition Classes
    MemoryConsumer
  10. def addElementsRead(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Spillable
  11. def addString(b: StringBuilder): StringBuilder

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

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

    Permalink
    Definition Classes
    TraversableOnce
  14. def aggregate[B](z: ⇒ B)(seqop: (B, (K, C)) ⇒ B, combop: (B, B) ⇒ B): B

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  15. def allocateArray(size: Long): LongArray

    Permalink
    Definition Classes
    MemoryConsumer
  16. def allocatePage(required: Long): MemoryBlock

    Permalink
    Attributes
    protected[org.apache.spark.memory]
    Definition Classes
    MemoryConsumer
  17. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  18. def canEqual(that: Any): Boolean

    Permalink
    Definition Classes
    IterableLike → Equals
  19. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  20. def collect[B, That](pf: PartialFunction[(K, C), B])(implicit bf: CanBuildFrom[Iterable[(K, C)], B, That]): That

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  21. def collectFirst[B](pf: PartialFunction[(K, C), B]): Option[B]

    Permalink
    Definition Classes
    TraversableOnce
  22. def companion: GenericCompanion[Iterable]

    Permalink
    Definition Classes
    Iterable → GenIterable → Traversable → GenTraversable → GenericTraversableTemplate
  23. def copyToArray[B >: (K, C)](xs: Array[B], start: Int, len: Int): Unit

    Permalink
    Definition Classes
    IterableLike → TraversableLike → TraversableOnce → GenTraversableOnce
  24. def copyToArray[B >: (K, C)](xs: Array[B]): Unit

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

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  26. def copyToBuffer[B >: (K, C)](dest: Buffer[B]): Unit

    Permalink
    Definition Classes
    TraversableOnce
  27. def count(p: ((K, C)) ⇒ Boolean): Int

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  28. def destructiveIterator(inMemoryIterator: Iterator[(K, C)]): Iterator[(K, C)]

    Permalink

    Returns a destructive iterator for iterating over the entries of this map.

    Returns a destructive iterator for iterating over the entries of this map. If this iterator is forced spill to disk to release memory when there is not enough memory, it returns pairs from an on-disk map.

  29. def diskBytesSpilled: Long

    Permalink
  30. def drop(n: Int): Iterable[(K, C)]

    Permalink
    Definition Classes
    IterableLike → TraversableLike → GenTraversableLike
  31. def dropRight(n: Int): Iterable[(K, C)]

    Permalink
    Definition Classes
    IterableLike
  32. def dropWhile(p: ((K, C)) ⇒ Boolean): Iterable[(K, C)]

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  33. def elementsRead: Long

    Permalink
    Attributes
    protected
    Definition Classes
    Spillable
  34. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  36. def exists(p: ((K, C)) ⇒ Boolean): Boolean

    Permalink
    Definition Classes
    IterableLike → TraversableLike → TraversableOnce → GenTraversableOnce
  37. def filter(p: ((K, C)) ⇒ Boolean): Iterable[(K, C)]

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  38. def filterNot(p: ((K, C)) ⇒ Boolean): Iterable[(K, C)]

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  39. def finalize(): Unit

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

    Permalink
    Definition Classes
    IterableLike → TraversableLike → TraversableOnce → GenTraversableOnce
  41. def flatMap[B, That](f: ((K, C)) ⇒ GenTraversableOnce[B])(implicit bf: CanBuildFrom[Iterable[(K, C)], B, That]): That

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike → FilterMonadic
  42. def flatten[B](implicit asTraversable: ((K, C)) ⇒ GenTraversableOnce[B]): Iterable[B]

    Permalink
    Definition Classes
    GenericTraversableTemplate
  43. def fold[A1 >: (K, C)](z: A1)(op: (A1, A1) ⇒ A1): A1

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  44. def foldLeft[B](z: B)(op: (B, (K, C)) ⇒ B): B

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  45. def foldRight[B](z: B)(op: ((K, C), B) ⇒ B): B

    Permalink
    Definition Classes
    IterableLike → TraversableOnce → GenTraversableOnce
  46. def forall(p: ((K, C)) ⇒ Boolean): Boolean

    Permalink
    Definition Classes
    IterableLike → TraversableLike → TraversableOnce → GenTraversableOnce
  47. def forceSpill(): Boolean

    Permalink

    Force to spilling the current in-memory collection to disk to release memory, It will be called by TaskMemoryManager when there is not enough memory for the task.

    Force to spilling the current in-memory collection to disk to release memory, It will be called by TaskMemoryManager when there is not enough memory for the task.

    Attributes
    protected[this]
    Definition Classes
    ExternalAppendOnlyMap → Spillable
  48. def foreach[U](f: ((K, C)) ⇒ U): Unit

    Permalink
    Definition Classes
    IterableLike → TraversableLike → GenTraversableLike → TraversableOnce → GenTraversableOnce → FilterMonadic
  49. def freeArray(array: LongArray): Unit

    Permalink
    Definition Classes
    MemoryConsumer
  50. def freeMemory(size: Long): Unit

    Permalink
    Definition Classes
    MemoryConsumer
  51. def freePage(page: MemoryBlock): Unit

    Permalink
    Attributes
    protected[org.apache.spark.memory]
    Definition Classes
    MemoryConsumer
  52. def genericBuilder[B]: Builder[B, Iterable[B]]

    Permalink
    Definition Classes
    GenericTraversableTemplate
  53. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  54. def getMode(): MemoryMode

    Permalink
    Definition Classes
    MemoryConsumer
  55. def getUsed(): Long

    Permalink
    Attributes
    protected[org.apache.spark.memory]
    Definition Classes
    MemoryConsumer
  56. def groupBy[K](f: ((K, C)) ⇒ K): Map[K, Iterable[(K, C)]]

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  57. def grouped(size: Int): Iterator[Iterable[(K, C)]]

    Permalink
    Definition Classes
    IterableLike
  58. def hasDefiniteSize: Boolean

    Permalink
    Definition Classes
    TraversableLike → TraversableOnce → GenTraversableOnce
  59. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  60. def head: (K, C)

    Permalink
    Definition Classes
    IterableLike → TraversableLike → GenTraversableLike
  61. def headOption: Option[(K, C)]

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  62. def init: Iterable[(K, C)]

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  63. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  64. def inits: Iterator[Iterable[(K, C)]]

    Permalink
    Definition Classes
    TraversableLike
  65. def insert(key: K, value: V): Unit

    Permalink

    Insert the given key and value into the map.

  66. def insertAll(entries: Iterable[Product2[K, V]]): Unit

    Permalink

    Insert the given iterable of keys and values into the map.

    Insert the given iterable of keys and values into the map.

    When the underlying map needs to grow, check if the global pool of shuffle memory has enough room for this to happen. If so, allocate the memory required to grow the map; otherwise, spill the in-memory map to disk.

    The shuffle memory usage of the first trackMemoryThreshold entries is not tracked.

  67. def insertAll(entries: Iterator[Product2[K, V]]): Unit

    Permalink

    Insert the given iterator of keys and values into the map.

    Insert the given iterator of keys and values into the map.

    When the underlying map needs to grow, check if the global pool of shuffle memory has enough room for this to happen. If so, allocate the memory required to grow the map; otherwise, spill the in-memory map to disk.

    The shuffle memory usage of the first trackMemoryThreshold entries is not tracked.

  68. def isEmpty: Boolean

    Permalink
    Definition Classes
    IterableLike → TraversableLike → TraversableOnce → GenTraversableOnce
  69. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  70. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  71. final def isTraversableAgain: Boolean

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike → GenTraversableOnce
  72. def iterator: Iterator[(K, C)]

    Permalink

    Return a destructive iterator that merges the in-memory map with the spilled maps.

    Return a destructive iterator that merges the in-memory map with the spilled maps. If no spill has occurred, simply return the in-memory map's iterator.

    Definition Classes
    ExternalAppendOnlyMap → IterableLike → GenIterableLike
  73. def last: (K, C)

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  74. def lastOption: Option[(K, C)]

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  75. def log: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  76. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  77. def logDebug(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  78. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  79. def logError(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  80. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  81. def logInfo(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  82. def logName: String

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  83. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  84. def logTrace(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  85. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  86. def logWarning(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  87. def map[B, That](f: ((K, C)) ⇒ B)(implicit bf: CanBuildFrom[Iterable[(K, C)], B, That]): That

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike → FilterMonadic
  88. def max[B >: (K, C)](implicit cmp: Ordering[B]): (K, C)

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  89. def maxBy[B](f: ((K, C)) ⇒ B)(implicit cmp: Ordering[B]): (K, C)

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  90. def maybeSpill(collection: SizeTracker, currentMemory: Long): Boolean

    Permalink

    Spills the current in-memory collection to disk if needed.

    Spills the current in-memory collection to disk if needed. Attempts to acquire more memory before spilling.

    collection

    collection to spill to disk

    currentMemory

    estimated size of the collection in bytes

    returns

    true if collection was spilled to disk; false otherwise

    Attributes
    protected
    Definition Classes
    Spillable
  91. def memoryBytesSpilled: Long

    Permalink

    returns

    number of bytes spilled in total

    Definition Classes
    Spillable
  92. def min[B >: (K, C)](implicit cmp: Ordering[B]): (K, C)

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  93. def minBy[B](f: ((K, C)) ⇒ B)(implicit cmp: Ordering[B]): (K, C)

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

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

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

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

    Permalink
    Definition Classes
    AnyRef
  98. def newBuilder: Builder[(K, C), Iterable[(K, C)]]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    GenericTraversableTemplate → HasNewBuilder
  99. def nonEmpty: Boolean

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

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

    Permalink
    Definition Classes
    AnyRef
  102. def par: ParIterable[(K, C)]

    Permalink
    Definition Classes
    Parallelizable
  103. def parCombiner: Combiner[(K, C), ParIterable[(K, C)]]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    TraversableLike → Parallelizable
  104. def partition(p: ((K, C)) ⇒ Boolean): (Iterable[(K, C)], Iterable[(K, C)])

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  105. def peakMemoryUsedBytes: Long

    Permalink
  106. def product[B >: (K, C)](implicit num: Numeric[B]): B

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  107. def reduce[A1 >: (K, C)](op: (A1, A1) ⇒ A1): A1

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  108. def reduceLeft[B >: (K, C)](op: (B, (K, C)) ⇒ B): B

    Permalink
    Definition Classes
    TraversableOnce
  109. def reduceLeftOption[B >: (K, C)](op: (B, (K, C)) ⇒ B): Option[B]

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

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  111. def reduceRight[B >: (K, C)](op: ((K, C), B) ⇒ B): B

    Permalink
    Definition Classes
    IterableLike → TraversableOnce → GenTraversableOnce
  112. def reduceRightOption[B >: (K, C)](op: ((K, C), B) ⇒ B): Option[B]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  113. def releaseMemory(): Unit

    Permalink

    Release our memory back to the execution pool so that other tasks can grab it.

    Release our memory back to the execution pool so that other tasks can grab it.

    Definition Classes
    Spillable
  114. def repr: Iterable[(K, C)]

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  115. def reversed: List[(K, C)]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    TraversableOnce
  116. def sameElements[B >: (K, C)](that: GenIterable[B]): Boolean

    Permalink
    Definition Classes
    IterableLike → GenIterableLike
  117. def scan[B >: (K, C), That](z: B)(op: (B, B) ⇒ B)(implicit cbf: CanBuildFrom[Iterable[(K, C)], B, That]): That

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  118. def scanLeft[B, That](z: B)(op: (B, (K, C)) ⇒ B)(implicit bf: CanBuildFrom[Iterable[(K, C)], B, That]): That

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  119. def scanRight[B, That](z: B)(op: ((K, C), B) ⇒ B)(implicit bf: CanBuildFrom[Iterable[(K, C)], B, That]): That

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
    Annotations
    @migration
    Migration

    (Changed in version 2.9.0) The behavior of scanRight has changed. The previous behavior can be reproduced with scanRight.reverse.

  120. def seq: Iterable[(K, C)]

    Permalink
    Definition Classes
    Iterable → GenIterable → Traversable → GenTraversable → Parallelizable → TraversableOnce → GenTraversableOnce
  121. def size: Int

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  122. def slice(from: Int, until: Int): Iterable[(K, C)]

    Permalink
    Definition Classes
    IterableLike → TraversableLike → GenTraversableLike
  123. def sliding(size: Int, step: Int): Iterator[Iterable[(K, C)]]

    Permalink
    Definition Classes
    IterableLike
  124. def sliding(size: Int): Iterator[Iterable[(K, C)]]

    Permalink
    Definition Classes
    IterableLike
  125. def span(p: ((K, C)) ⇒ Boolean): (Iterable[(K, C)], Iterable[(K, C)])

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  126. def spill(collection: SizeTracker): Unit

    Permalink

    Sort the existing contents of the in-memory map and spill them to a temporary file on disk.

    Sort the existing contents of the in-memory map and spill them to a temporary file on disk.

    collection

    collection to spill to disk

    Attributes
    protected[this]
    Definition Classes
    ExternalAppendOnlyMap → Spillable
  127. def spill(size: Long, trigger: MemoryConsumer): Long

    Permalink

    Spill some data to disk to release memory, which will be called by TaskMemoryManager when there is not enough memory for the task.

    Spill some data to disk to release memory, which will be called by TaskMemoryManager when there is not enough memory for the task.

    Definition Classes
    Spillable → MemoryConsumer
  128. def spill(): Unit

    Permalink
    Definition Classes
    MemoryConsumer
  129. def splitAt(n: Int): (Iterable[(K, C)], Iterable[(K, C)])

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  130. def stringPrefix: String

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  131. def sum[B >: (K, C)](implicit num: Numeric[B]): B

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

    Permalink
    Definition Classes
    AnyRef
  133. def tail: Iterable[(K, C)]

    Permalink
    Definition Classes
    TraversableLike → GenTraversableLike
  134. def tails: Iterator[Iterable[(K, C)]]

    Permalink
    Definition Classes
    TraversableLike
  135. def take(n: Int): Iterable[(K, C)]

    Permalink
    Definition Classes
    IterableLike → TraversableLike → GenTraversableLike
  136. def takeRight(n: Int): Iterable[(K, C)]

    Permalink
    Definition Classes
    IterableLike
  137. def takeWhile(p: ((K, C)) ⇒ Boolean): Iterable[(K, C)]

    Permalink
    Definition Classes
    IterableLike → TraversableLike → GenTraversableLike
  138. def thisCollection: Iterable[(K, C)]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    IterableLike → TraversableLike
  139. def to[Col[_]](implicit cbf: CanBuildFrom[Nothing, (K, C), Col[(K, C)]]): Col[(K, C)]

    Permalink
    Definition Classes
    TraversableLike → TraversableOnce → GenTraversableOnce
  140. def toArray[B >: (K, C)](implicit arg0: ClassTag[B]): Array[B]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  141. def toBuffer[B >: (K, C)]: Buffer[B]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  142. def toCollection(repr: Iterable[(K, C)]): Iterable[(K, C)]

    Permalink
    Attributes
    protected[this]
    Definition Classes
    IterableLike → TraversableLike
  143. def toIndexedSeq: IndexedSeq[(K, C)]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  144. def toIterable: Iterable[(K, C)]

    Permalink
    Definition Classes
    IterableLike → TraversableOnce → GenTraversableOnce
  145. def toIterator: Iterator[(K, C)]

    Permalink
    Definition Classes
    IterableLike → TraversableLike → GenTraversableOnce
    Annotations
    @deprecatedOverriding( ... , "2.11.0" )
  146. def toList: List[(K, C)]

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

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  148. def toSeq: Seq[(K, C)]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  149. def toSet[B >: (K, C)]: Set[B]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  150. def toStream: Stream[(K, C)]

    Permalink
    Definition Classes
    IterableLike → TraversableLike → GenTraversableOnce
  151. def toString(): String

    Permalink
    Definition Classes
    ExternalAppendOnlyMap → TraversableLike → AnyRef → Any
  152. def toTraversable: Traversable[(K, C)]

    Permalink
    Definition Classes
    TraversableLike → TraversableOnce → GenTraversableOnce
    Annotations
    @deprecatedOverriding( ... , "2.11.0" )
  153. def toVector: Vector[(K, C)]

    Permalink
    Definition Classes
    TraversableOnce → GenTraversableOnce
  154. def transpose[B](implicit asTraversable: ((K, C)) ⇒ GenTraversableOnce[B]): Iterable[Iterable[B]]

    Permalink
    Definition Classes
    GenericTraversableTemplate
    Annotations
    @migration
    Migration

    (Changed in version 2.9.0) transpose throws an IllegalArgumentException if collections are not uniformly sized.

  155. def unzip[A1, A2](implicit asPair: ((K, C)) ⇒ (A1, A2)): (Iterable[A1], Iterable[A2])

    Permalink
    Definition Classes
    GenericTraversableTemplate
  156. def unzip3[A1, A2, A3](implicit asTriple: ((K, C)) ⇒ (A1, A2, A3)): (Iterable[A1], Iterable[A2], Iterable[A3])

    Permalink
    Definition Classes
    GenericTraversableTemplate
  157. def view(from: Int, until: Int): IterableView[(K, C), Iterable[(K, C)]]

    Permalink
    Definition Classes
    IterableLike → TraversableLike
  158. def view: IterableView[(K, C), Iterable[(K, C)]]

    Permalink
    Definition Classes
    IterableLike → TraversableLike
  159. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  162. def withFilter(p: ((K, C)) ⇒ Boolean): FilterMonadic[(K, C), Iterable[(K, C)]]

    Permalink
    Definition Classes
    TraversableLike → FilterMonadic
  163. def zip[A1 >: (K, C), B, That](that: GenIterable[B])(implicit bf: CanBuildFrom[Iterable[(K, C)], (A1, B), That]): That

    Permalink
    Definition Classes
    IterableLike → GenIterableLike
  164. def zipAll[B, A1 >: (K, C), That](that: GenIterable[B], thisElem: A1, thatElem: B)(implicit bf: CanBuildFrom[Iterable[(K, C)], (A1, B), That]): That

    Permalink
    Definition Classes
    IterableLike → GenIterableLike
  165. def zipWithIndex[A1 >: (K, C), That](implicit bf: CanBuildFrom[Iterable[(K, C)], (A1, Int), That]): That

    Permalink
    Definition Classes
    IterableLike → GenIterableLike

Inherited from Iterable[(K, C)]

Inherited from IterableLike[(K, C), Iterable[(K, C)]]

Inherited from Equals

Inherited from GenIterable[(K, C)]

Inherited from GenIterableLike[(K, C), Iterable[(K, C)]]

Inherited from Traversable[(K, C)]

Inherited from GenTraversable[(K, C)]

Inherited from GenericTraversableTemplate[(K, C), Iterable]

Inherited from TraversableLike[(K, C), Iterable[(K, C)]]

Inherited from GenTraversableLike[(K, C), Iterable[(K, C)]]

Inherited from Parallelizable[(K, C), ParIterable[(K, C)]]

Inherited from TraversableOnce[(K, C)]

Inherited from GenTraversableOnce[(K, C)]

Inherited from FilterMonadic[(K, C), Iterable[(K, C)]]

Inherited from HasNewBuilder[(K, C), Iterable[(K, C)] @scala.annotation.unchecked.uncheckedVariance]

Inherited from Serializable

Inherited from Spillable[SizeTracker]

Inherited from Logging

Inherited from MemoryConsumer

Inherited from AnyRef

Inherited from Any

Ungrouped