org.apache.spark.sql.collection

MultiColumnOpenHashMap

final class MultiColumnOpenHashMap[V] extends ReentrantReadWriteLock with SegmentMap[Row, V] with Map[Row, V] with MapLike[Row, V, MultiColumnOpenHashMap[V]] with Iterable[(Row, V)] with IterableLike[(Row, V), MultiColumnOpenHashMap[V]] with Builder[(Row, V), MultiColumnOpenHashMap[V]] with Serializable

A fast hash map implementation for nullable keys. This hash map supports insertions and updates, but not deletions. This map is about 5X faster than java.util.HashMap, while using much less space overhead.

Under the hood, it uses our MultiColumnOpenHashSet implementation.

Self Type
MultiColumnOpenHashMap[V]
Linear Supertypes
Serializable, Map[Row, V], MapLike[Row, V, MultiColumnOpenHashMap[V]], Cloneable[MultiColumnOpenHashMap[V]], Cloneable, Cloneable, Shrinkable[Row], Builder[(Row, V), MultiColumnOpenHashMap[V]], Growable[(Row, V)], Clearable, Map[Row, V], MapLike[Row, V, MultiColumnOpenHashMap[V]], Subtractable[Row, MultiColumnOpenHashMap[V]], PartialFunction[Row, V], (Row) ⇒ V, GenMap[Row, V], GenMapLike[Row, V, MultiColumnOpenHashMap[V]], Iterable[(Row, V)], Iterable[(Row, V)], IterableLike[(Row, V), MultiColumnOpenHashMap[V]], Equals, GenIterable[(Row, V)], GenIterableLike[(Row, V), MultiColumnOpenHashMap[V]], Traversable[(Row, V)], Mutable, Traversable[(Row, V)], GenTraversable[(Row, V)], GenericTraversableTemplate[(Row, V), Iterable], TraversableLike[(Row, V), MultiColumnOpenHashMap[V]], GenTraversableLike[(Row, V), MultiColumnOpenHashMap[V]], Parallelizable[(Row, V), ParMap[Row, V]], TraversableOnce[(Row, V)], GenTraversableOnce[(Row, V)], FilterMonadic[(Row, V), MultiColumnOpenHashMap[V]], HasNewBuilder[(Row, V), MultiColumnOpenHashMap[V]], SegmentMap[Row, V], ReentrantReadWriteLock, Serializable, ReadWriteLock, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. MultiColumnOpenHashMap
  2. Serializable
  3. Map
  4. MapLike
  5. Cloneable
  6. Cloneable
  7. Cloneable
  8. Shrinkable
  9. Builder
  10. Growable
  11. Clearable
  12. Map
  13. MapLike
  14. Subtractable
  15. PartialFunction
  16. Function1
  17. GenMap
  18. GenMapLike
  19. Iterable
  20. Iterable
  21. IterableLike
  22. Equals
  23. GenIterable
  24. GenIterableLike
  25. Traversable
  26. Mutable
  27. Traversable
  28. GenTraversable
  29. GenericTraversableTemplate
  30. TraversableLike
  31. GenTraversableLike
  32. Parallelizable
  33. TraversableOnce
  34. GenTraversableOnce
  35. FilterMonadic
  36. HasNewBuilder
  37. SegmentMap
  38. ReentrantReadWriteLock
  39. Serializable
  40. ReadWriteLock
  41. AnyRef
  42. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new MultiColumnOpenHashMap(columns: Array[Int], types: Array[DataType])(implicit arg0: ClassTag[V])

  2. new MultiColumnOpenHashMap(columns: Array[Int], types: Array[DataType], initialCapacity: Int)(implicit arg0: ClassTag[V])

  3. new MultiColumnOpenHashMap(_columns: Array[Int], _types: Array[DataType], _numColumns: Int, _initialCapacity: Int, _loadFactor: Double)(implicit arg0: ClassTag[V])

Type Members

  1. class DefaultKeySet extends AbstractSet[A] with Set[A] with Serializable

    Attributes
    protected
    Definition Classes
    MapLike
  2. class DefaultValuesIterable extends AbstractIterable[B] with Iterable[B] with Serializable

    Attributes
    protected
    Definition Classes
    MapLike
  3. class FilteredKeys extends AbstractMap[A, B] with DefaultMap[A, B]

    Attributes
    protected
    Definition Classes
    MapLike
  4. class MappedValues[C] extends AbstractMap[A, C] with DefaultMap[A, C]

    Attributes
    protected
    Definition Classes
    MapLike
  5. type Self = MultiColumnOpenHashMap[V]

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

    Definition Classes
    TraversableLike

Value Members

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

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. def +[B1 >: V](elem1: (Row, B1), elem2: (Row, B1), elems: (Row, B1)*): Map[Row, B1]

    Definition Classes
    MapLike → MapLike
    Annotations
    @migration
    Migration

    (Changed in version 2.8.0) + creates a new map. Use += to add an element to this map and return that map itself.

  5. def +[B1 >: V](kv: (Row, B1)): Map[Row, B1]

    Definition Classes
    MapLike → MapLike → GenMapLike
    Annotations
    @migration
    Migration

    (Changed in version 2.8.0) + creates a new map. Use += to add an element to this map and return that map itself.

  6. def ++[B1 >: V](xs: GenTraversableOnce[(Row, B1)]): Map[Row, B1]

    Definition Classes
    MapLike → MapLike
    Annotations
    @migration
    Migration

    (Changed in version 2.8.0) ++ creates a new map. Use ++= to add an element to this map and return that map itself.

  7. def ++[B >: (Row, V), That](that: GenTraversableOnce[B])(implicit bf: CanBuildFrom[MultiColumnOpenHashMap[V], B, That]): That

    Definition Classes
    TraversableLike → GenTraversableLike
  8. def ++:[B >: (Row, V), That](that: Traversable[B])(implicit bf: CanBuildFrom[MultiColumnOpenHashMap[V], B, That]): That

    Definition Classes
    TraversableLike
  9. def ++:[B >: (Row, V), That](that: TraversableOnce[B])(implicit bf: CanBuildFrom[MultiColumnOpenHashMap[V], B, That]): That

    Definition Classes
    TraversableLike
  10. def ++=(xs: TraversableOnce[(Row, V)]): MultiColumnOpenHashMap.this.type

    Definition Classes
    Growable
  11. def +=(elem: (Row, V)): MultiColumnOpenHashMap.this.type

    Definition Classes
    MultiColumnOpenHashMap → MapLike → Builder → Growable
  12. def +=(elem1: (Row, V), elem2: (Row, V), elems: (Row, V)*): MultiColumnOpenHashMap.this.type

    Definition Classes
    Growable
  13. def -(elem1: Row, elem2: Row, elems: Row*): MultiColumnOpenHashMap[V]

    Definition Classes
    MapLike → Subtractable
    Annotations
    @migration
    Migration

    (Changed in version 2.8.0) - creates a new map. Use -= to remove an element from this map and return that map itself.

  14. def -(key: Row): MultiColumnOpenHashMap[V]

    Definition Classes
    MapLike → MapLike → Subtractable → GenMapLike
    Annotations
    @migration
    Migration

    (Changed in version 2.8.0) - creates a new map. Use -= to remove an element from this map and return that map itself.

  15. def --(xs: GenTraversableOnce[Row]): MultiColumnOpenHashMap[V]

    Definition Classes
    MapLike → Subtractable
    Annotations
    @migration
    Migration

    (Changed in version 2.8.0) -- creates a new map. Use --= to remove an element from this map and return that map itself.

  16. def --=(xs: TraversableOnce[Row]): MultiColumnOpenHashMap.this.type

    Definition Classes
    Shrinkable
  17. def -=(row: Row): Nothing

    Definition Classes
    MultiColumnOpenHashMap → MapLike → Shrinkable
  18. def -=(elem1: Row, elem2: Row, elems: Row*): MultiColumnOpenHashMap.this.type

    Definition Classes
    Shrinkable
  19. def /:[B](z: B)(op: (B, (Row, V)) ⇒ B): B

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

    Definition Classes
    TraversableOnce → GenTraversableOnce
  21. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  22. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  23. def addString(b: StringBuilder, start: String, sep: String, end: String): StringBuilder

    Definition Classes
    MapLike → TraversableOnce
  24. def addString(b: StringBuilder): StringBuilder

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

    Definition Classes
    TraversableOnce
  26. def aggregate[B](z: B)(seqop: (B, (Row, V)) ⇒ B, combop: (B, B) ⇒ B): B

    Definition Classes
    TraversableOnce → GenTraversableOnce
  27. def andThen[C](k: (V) ⇒ C): PartialFunction[Row, C]

    Definition Classes
    PartialFunction → Function1
  28. def apply(r: Row, hash: Int): V

    Get the value for a given row

    Get the value for a given row

    Definition Classes
    MultiColumnOpenHashMapSegmentMap
  29. def apply(r: WrappedInternalRow): V

    Get the value for a given row

  30. def apply(r: Row): V

    Get the value for a given row

    Get the value for a given row

    Definition Classes
    MultiColumnOpenHashMap → MapLike → Function1 → GenMapLike
  31. def applyOrElse[A1 <: Row, B1 >: V](x: A1, default: (A1) ⇒ B1): B1

    Definition Classes
    PartialFunction
  32. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  33. implicit def canBuildFrom[B](implicit arg0: ClassTag[B]): CanBuildFrom[MultiColumnOpenHashMap[V], (Row, B), MultiColumnOpenHashMap[B]] { ... /* 2 definitions in type refinement */ }

  34. def canEqual(that: Any): Boolean

    Definition Classes
    IterableLike → Equals
  35. def changeValue(r: WrappedInternalRow, hash: Int, change: ChangeValue[Row, V]): Boolean

    If the row doesn't exist yet in the hash map, set its value to defaultValue; otherwise, set its value to mergeValue(oldValue).

    If the row doesn't exist yet in the hash map, set its value to defaultValue; otherwise, set its value to mergeValue(oldValue).

    returns

    true if new value was added, false if it was merged and null if the default/merge calls returned null and nothing was done

  36. def changeValue(r: Row, hash: Int, change: ChangeValue[Row, V]): Boolean

    If the row doesn't exist yet in the hash map, set its value to defaultValue; otherwise, set its value to mergeValue(oldValue).

    If the row doesn't exist yet in the hash map, set its value to defaultValue; otherwise, set its value to mergeValue(oldValue).

    returns

    true if new value was added, false if it was merged and null if the default/merge calls returned null and nothing was done

    Definition Classes
    MultiColumnOpenHashMapSegmentMap
  37. def changeValue(r: Row, change: ChangeValue[Row, V]): Boolean

    If the row doesn't exist yet in the hash map, set its value to defaultValue; otherwise, set its value to mergeValue(oldValue).

    If the row doesn't exist yet in the hash map, set its value to defaultValue; otherwise, set its value to mergeValue(oldValue).

    returns

    the newly updated value.

  38. def clear(): Unit

    Definition Classes
    MultiColumnOpenHashMap → MapLike → Builder → Growable → Clearable
  39. def clone(): MultiColumnOpenHashMap[V]

    Definition Classes
    MapLike → Cloneable → AnyRef
  40. def collect[B, That](pf: PartialFunction[(Row, V), B])(implicit bf: CanBuildFrom[MultiColumnOpenHashMap[V], B, That]): That

    Definition Classes
    TraversableLike → GenTraversableLike
  41. def collectFirst[B](pf: PartialFunction[(Row, V), B]): Option[B]

    Definition Classes
    TraversableOnce
  42. def companion: GenericCompanion[Iterable]

    Definition Classes
    Iterable → Iterable → GenIterable → Traversable → Traversable → GenTraversable → GenericTraversableTemplate
  43. def compose[A](g: (A) ⇒ Row): (A) ⇒ V

    Definition Classes
    Function1
    Annotations
    @unspecialized()
  44. def contains(r: Row, hash: Int): Boolean

    Tests whether this map contains a binding for a row.

    Tests whether this map contains a binding for a row.

    Definition Classes
    MultiColumnOpenHashMapSegmentMap
  45. def contains(r: WrappedInternalRow): Boolean

    Tests whether this map contains a binding for a projected row.

  46. def contains(r: Row): Boolean

    Tests whether this map contains a binding for a row.

    Tests whether this map contains a binding for a row.

    Definition Classes
    MultiColumnOpenHashMap → MapLike → GenMapLike
  47. def copyToArray[B >: (Row, V)](xs: Array[B], start: Int, len: Int): Unit

    Definition Classes
    IterableLike → TraversableLike → TraversableOnce → GenTraversableOnce
  48. def copyToArray[B >: (Row, V)](xs: Array[B]): Unit

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

    Definition Classes
    TraversableOnce → GenTraversableOnce
  50. def copyToBuffer[B >: (Row, V)](dest: Buffer[B]): Unit

    Definition Classes
    TraversableOnce
  51. def count(p: ((Row, V)) ⇒ Boolean): Int

    Definition Classes
    TraversableOnce → GenTraversableOnce
  52. def default(key: Row): V

    Definition Classes
    MapLike → GenMapLike
  53. def drop(n: Int): MultiColumnOpenHashMap[V]

    Definition Classes
    IterableLike → TraversableLike → GenTraversableLike
  54. def dropRight(n: Int): MultiColumnOpenHashMap[V]

    Definition Classes
    IterableLike
  55. def dropWhile(p: ((Row, V)) ⇒ Boolean): MultiColumnOpenHashMap[V]

    Definition Classes
    TraversableLike → GenTraversableLike
  56. def empty: MultiColumnOpenHashMap[V]

    Definition Classes
    MultiColumnOpenHashMap → Map → Map → MapLike
  57. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  58. def equals(that: Any): Boolean

    Definition Classes
    GenMapLike → Equals → AnyRef → Any
  59. def exists(p: ((Row, V)) ⇒ Boolean): Boolean

    Definition Classes
    IterableLike → TraversableLike → TraversableOnce → GenTraversableOnce
  60. def filter(p: ((Row, V)) ⇒ Boolean): MultiColumnOpenHashMap[V]

    Definition Classes
    TraversableLike → GenTraversableLike
  61. def filterKeys(p: (Row) ⇒ Boolean): Map[Row, V]

    Definition Classes
    MapLike → GenMapLike
  62. def filterNot(p: ((Row, V)) ⇒ Boolean): MultiColumnOpenHashMap[V]

    Definition Classes
    MapLike → TraversableLike → GenTraversableLike
  63. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  64. def find(p: ((Row, V)) ⇒ Boolean): Option[(Row, V)]

    Definition Classes
    IterableLike → TraversableLike → TraversableOnce → GenTraversableOnce
  65. def flatMap[B, That](f: ((Row, V)) ⇒ GenTraversableOnce[B])(implicit bf: CanBuildFrom[MultiColumnOpenHashMap[V], B, That]): That

    Definition Classes
    TraversableLike → GenTraversableLike → FilterMonadic
  66. def flatten[B](implicit asTraversable: ((Row, V)) ⇒ GenTraversableOnce[B]): Iterable[B]

    Definition Classes
    GenericTraversableTemplate
  67. def fold[A1 >: (Row, V)](z: A1)(op: (A1, A1) ⇒ A1): A1

    Definition Classes
    TraversableOnce → GenTraversableOnce
  68. def foldEntries[U](init: U, copyIfRequired: Boolean, f: (Row, V, U) ⇒ U): U

    Definition Classes
    MultiColumnOpenHashMapSegmentMap
  69. def foldLeft[B](z: B)(op: (B, (Row, V)) ⇒ B): B

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

    Definition Classes
    IterableLike → TraversableOnce → GenTraversableOnce
  71. def foldValues[U](init: U, f: (V, U) ⇒ U): U

    Definition Classes
    MultiColumnOpenHashMapSegmentMap
  72. def forall(p: ((Row, V)) ⇒ Boolean): Boolean

    Definition Classes
    IterableLike → TraversableLike → TraversableOnce → GenTraversableOnce
  73. def foreach[U](f: ((Row, V)) ⇒ U): Unit

    Definition Classes
    MultiColumnOpenHashMap → IterableLike → GenericTraversableTemplate → TraversableLike → GenTraversableLike → TraversableOnce → GenTraversableOnce → FilterMonadic
  74. def genericBuilder[B]: Builder[B, Iterable[B]]

    Definition Classes
    GenericTraversableTemplate
  75. def get(r: WrappedInternalRow): Option[V]

    Optionally get the value for a given row

  76. def get(r: Row): Option[V]

    Optionally get the value for a given row

    Optionally get the value for a given row

    Definition Classes
    MultiColumnOpenHashMap → MapLike → GenMapLike
  77. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  78. def getOrElse[B1 >: V](key: Row, default: ⇒ B1): B1

    Definition Classes
    MapLike → GenMapLike
  79. def getOrElseUpdate(key: Row, op: ⇒ V): V

    Definition Classes
    MapLike
  80. def getOwner(): Thread

    Attributes
    protected[java.util.concurrent.locks]
    Definition Classes
    ReentrantReadWriteLock
  81. final def getQueueLength(): Int

    Definition Classes
    ReentrantReadWriteLock
  82. def getQueuedReaderThreads(): Collection[Thread]

    Attributes
    protected[java.util.concurrent.locks]
    Definition Classes
    ReentrantReadWriteLock
  83. def getQueuedThreads(): Collection[Thread]

    Attributes
    protected[java.util.concurrent.locks]
    Definition Classes
    ReentrantReadWriteLock
  84. def getQueuedWriterThreads(): Collection[Thread]

    Attributes
    protected[java.util.concurrent.locks]
    Definition Classes
    ReentrantReadWriteLock
  85. def getReadHoldCount(): Int

    Definition Classes
    ReentrantReadWriteLock
  86. def getReadLockCount(): Int

    Definition Classes
    ReentrantReadWriteLock
  87. def getWaitQueueLength(arg0: Condition): Int

    Definition Classes
    ReentrantReadWriteLock
  88. def getWaitingThreads(arg0: Condition): Collection[Thread]

    Attributes
    protected[java.util.concurrent.locks]
    Definition Classes
    ReentrantReadWriteLock
  89. def getWriteHoldCount(): Int

    Definition Classes
    ReentrantReadWriteLock
  90. def groupBy[K](groupOp: (Row, V) ⇒ Row, combineOp: (V, V) ⇒ V): MultiColumnOpenHashMap[V]

  91. def groupBy[K](f: ((Row, V)) ⇒ K): Map[K, MultiColumnOpenHashMap[V]]

    Definition Classes
    TraversableLike → GenTraversableLike
  92. def grouped(size: Int): Iterator[MultiColumnOpenHashMap[V]]

    Definition Classes
    IterableLike
  93. var grow: (Int) ⇒ Unit

    Attributes
    protected
  94. def hasDefiniteSize: Boolean

    Definition Classes
    TraversableLike → TraversableOnce → GenTraversableOnce
  95. final def hasQueuedThread(arg0: Thread): Boolean

    Definition Classes
    ReentrantReadWriteLock
  96. final def hasQueuedThreads(): Boolean

    Definition Classes
    ReentrantReadWriteLock
  97. def hasWaiters(arg0: Condition): Boolean

    Definition Classes
    ReentrantReadWriteLock
  98. def hashCode(): Int

    Definition Classes
    GenMapLike → AnyRef → Any
  99. def head: (Row, V)

    Definition Classes
    IterableLike → TraversableLike → GenTraversableLike
  100. def headOption: Option[(Row, V)]

    Definition Classes
    TraversableLike → GenTraversableLike
  101. def init: MultiColumnOpenHashMap[V]

    Definition Classes
    TraversableLike → GenTraversableLike
  102. def inits: Iterator[MultiColumnOpenHashMap[V]]

    Definition Classes
    TraversableLike
  103. def isDefinedAt(key: Row): Boolean

    Definition Classes
    MapLike → GenMapLike → PartialFunction
  104. def isEmpty: Boolean

    Definition Classes
    MultiColumnOpenHashMap → MapLike → IterableLike → GenericTraversableTemplate → TraversableLike → TraversableOnce → GenTraversableOnce → SegmentMap
  105. final def isFair(): Boolean

    Definition Classes
    ReentrantReadWriteLock
  106. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  107. final def isTraversableAgain: Boolean

    Definition Classes
    TraversableLike → GenTraversableLike → GenTraversableOnce
  108. def isWriteLocked(): Boolean

    Definition Classes
    ReentrantReadWriteLock
  109. def isWriteLockedByCurrentThread(): Boolean

    Definition Classes
    ReentrantReadWriteLock
  110. def iterator: Iterator[(Row, V)]

    Definition Classes
    MultiColumnOpenHashMap → MapLike → IterableLike → GenIterableLike → SegmentMap
  111. def iteratorRowReuse: Iterator[(ReusableRow, V)]

  112. def keySet: Set[Row]

    Definition Classes
    MapLike → GenMapLike
  113. def keys: Iterable[Row]

    Definition Classes
    MapLike → GenMapLike
    Annotations
    @migration
    Migration

    (Changed in version 2.8.0) keys returns Iterable[A] rather than Iterator[A].

  114. def keysIterator: Iterator[Row]

    Definition Classes
    MultiColumnOpenHashMap → MapLike → GenMapLike
  115. def keysIteratorRowReuse: Iterator[ReusableRow]

  116. def last: (Row, V)

    Definition Classes
    TraversableLike → GenTraversableLike
  117. def lastOption: Option[(Row, V)]

    Definition Classes
    TraversableLike → GenTraversableLike
  118. def lift: (Row) ⇒ Option[V]

    Definition Classes
    PartialFunction
  119. def map[B, That](f: ((Row, V)) ⇒ B)(implicit bf: CanBuildFrom[MultiColumnOpenHashMap[V], B, That]): That

    Definition Classes
    TraversableLike → GenTraversableLike → FilterMonadic
  120. def mapResult[NewTo](f: (MultiColumnOpenHashMap[V]) ⇒ NewTo): Builder[(Row, V), NewTo]

    Definition Classes
    Builder
  121. def mapValues[C](f: (V) ⇒ C): Map[Row, C]

    Definition Classes
    MapLike → GenMapLike
  122. def max[B >: (Row, V)](implicit cmp: Ordering[B]): (Row, V)

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

    Definition Classes
    TraversableOnce → GenTraversableOnce
  124. def min[B >: (Row, V)](implicit cmp: Ordering[B]): (Row, V)

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

    Definition Classes
    TraversableOnce → GenTraversableOnce
  126. def mkString: String

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

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

    Definition Classes
    TraversableOnce → GenTraversableOnce
  129. var move: (Int, Int) ⇒ Unit

    Attributes
    protected
  130. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  131. def newBuilder: MultiColumnOpenHashMap[V]

    Attributes
    protected[this]
    Definition Classes
    MultiColumnOpenHashMap → MapLike → MapLike → GenericTraversableTemplate → TraversableLike → HasNewBuilder
  132. def nonEmpty: Boolean

    Definition Classes
    MultiColumnOpenHashMap → TraversableOnce → GenTraversableOnce
  133. final def notify(): Unit

    Definition Classes
    AnyRef
  134. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  135. def orElse[A1 <: Row, B1 >: V](that: PartialFunction[A1, B1]): PartialFunction[A1, B1]

    Definition Classes
    PartialFunction
  136. def par: ParMap[Row, V]

    Definition Classes
    Parallelizable
  137. def parCombiner: Combiner[(Row, V), ParMap[Row, V]]

    Attributes
    protected[this]
    Definition Classes
    MapLike → MapLike → TraversableLike → Parallelizable
  138. def partition(p: ((Row, V)) ⇒ Boolean): (MultiColumnOpenHashMap[V], MultiColumnOpenHashMap[V])

    Definition Classes
    TraversableLike → GenTraversableLike
  139. def product[B >: (Row, V)](implicit num: Numeric[B]): B

    Definition Classes
    TraversableOnce → GenTraversableOnce
  140. def put(r: Row, v: V): Option[V]

    Set the value for a row

    Set the value for a row

    Definition Classes
    MultiColumnOpenHashMap → MapLike
  141. def readLock(): ReadLock

    Definition Classes
    ReentrantReadWriteLock → ReadWriteLock
  142. def reduce[A1 >: (Row, V)](op: (A1, A1) ⇒ A1): A1

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

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

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

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

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

    Definition Classes
    TraversableOnce → GenTraversableOnce
  148. def remove(row: Row): Nothing

    Definition Classes
    MultiColumnOpenHashMap → MapLike
  149. def repr: MultiColumnOpenHashMap[V]

    Definition Classes
    TraversableLike → GenTraversableLike
  150. def result(): MultiColumnOpenHashMap[V]

    Definition Classes
    MultiColumnOpenHashMap → MapLike → Builder
  151. def retain(p: (Row, V) ⇒ Boolean): MultiColumnOpenHashMap.this.type

    Definition Classes
    MapLike
  152. def reversed: List[(Row, V)]

    Attributes
    protected[this]
    Definition Classes
    TraversableOnce
  153. def runWith[U](action: (V) ⇒ U): (Row) ⇒ Boolean

    Definition Classes
    PartialFunction
  154. def sameElements[B >: (Row, V)](that: GenIterable[B]): Boolean

    Definition Classes
    IterableLike → GenIterableLike
  155. def scan[B >: (Row, V), That](z: B)(op: (B, B) ⇒ B)(implicit cbf: CanBuildFrom[MultiColumnOpenHashMap[V], B, That]): That

    Definition Classes
    TraversableLike → GenTraversableLike
  156. def scanLeft[B, That](z: B)(op: (B, (Row, V)) ⇒ B)(implicit bf: CanBuildFrom[MultiColumnOpenHashMap[V], B, That]): That

    Definition Classes
    TraversableLike → GenTraversableLike
  157. def scanRight[B, That](z: B)(op: ((Row, V), B) ⇒ B)(implicit bf: CanBuildFrom[MultiColumnOpenHashMap[V], B, That]): That

    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.

  158. def seq: Map[Row, V]

    Definition Classes
    Map → Map → GenMap → GenMapLike → Iterable → Iterable → GenIterable → Traversable → Traversable → GenTraversable → Parallelizable → TraversableOnce → GenTraversableOnce
  159. def size: Int

    Definition Classes
    MultiColumnOpenHashMap → GenTraversableLike → TraversableOnce → GenTraversableOnce → SegmentMap
  160. def sizeHint(coll: TraversableLike[_, _], delta: Int): Unit

    Definition Classes
    Builder
  161. def sizeHint(coll: TraversableLike[_, _]): Unit

    Definition Classes
    Builder
  162. def sizeHint(size: Int): Unit

    Definition Classes
    Builder
  163. def sizeHintBounded(size: Int, boundingColl: TraversableLike[_, _]): Unit

    Definition Classes
    Builder
  164. def slice(from: Int, until: Int): MultiColumnOpenHashMap[V]

    Definition Classes
    IterableLike → TraversableLike → GenTraversableLike
  165. def sliding(size: Int, step: Int): Iterator[MultiColumnOpenHashMap[V]]

    Definition Classes
    IterableLike
  166. def sliding(size: Int): Iterator[MultiColumnOpenHashMap[V]]

    Definition Classes
    IterableLike
  167. def span(p: ((Row, V)) ⇒ Boolean): (MultiColumnOpenHashMap[V], MultiColumnOpenHashMap[V])

    Definition Classes
    TraversableLike → GenTraversableLike
  168. def splitAt(n: Int): (MultiColumnOpenHashMap[V], MultiColumnOpenHashMap[V])

    Definition Classes
    TraversableLike → GenTraversableLike
  169. def stringPrefix: String

    Definition Classes
    MapLike → TraversableLike → GenTraversableLike
  170. def sum[B >: (Row, V)](implicit num: Numeric[B]): B

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

    Definition Classes
    AnyRef
  172. def tail: MultiColumnOpenHashMap[V]

    Definition Classes
    TraversableLike → GenTraversableLike
  173. def tails: Iterator[MultiColumnOpenHashMap[V]]

    Definition Classes
    TraversableLike
  174. def take(n: Int): MultiColumnOpenHashMap[V]

    Definition Classes
    IterableLike → TraversableLike → GenTraversableLike
  175. def takeRight(n: Int): MultiColumnOpenHashMap[V]

    Definition Classes
    IterableLike
  176. def takeWhile(p: ((Row, V)) ⇒ Boolean): MultiColumnOpenHashMap[V]

    Definition Classes
    IterableLike → TraversableLike → GenTraversableLike
  177. def thisCollection: Iterable[(Row, V)]

    Attributes
    protected[this]
    Definition Classes
    IterableLike → TraversableLike
  178. def to[Col[_]](implicit cbf: CanBuildFrom[Nothing, (Row, V), Col[(Row, V)]]): Col[(Row, V)]

    Definition Classes
    TraversableLike → TraversableOnce → GenTraversableOnce
  179. def toArray[B >: (Row, V)](implicit arg0: ClassTag[B]): Array[B]

    Definition Classes
    TraversableOnce → GenTraversableOnce
  180. def toBuffer[C >: (Row, V)]: Buffer[C]

    Definition Classes
    MapLike → TraversableOnce → GenTraversableOnce
  181. def toCollection(repr: MultiColumnOpenHashMap[V]): Iterable[(Row, V)]

    Attributes
    protected[this]
    Definition Classes
    IterableLike → TraversableLike
  182. def toIndexedSeq: IndexedSeq[(Row, V)]

    Definition Classes
    TraversableOnce → GenTraversableOnce
  183. def toIterable: Iterable[(Row, V)]

    Definition Classes
    IterableLike → TraversableOnce → GenTraversableOnce
  184. def toIterator: Iterator[(Row, V)]

    Definition Classes
    IterableLike → TraversableLike → GenTraversableOnce
  185. def toList: List[(Row, V)]

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

    Definition Classes
    TraversableOnce → GenTraversableOnce
  187. def toSeq: Seq[(Row, V)]

    Definition Classes
    MapLike → TraversableOnce → GenTraversableOnce
  188. def toSet[B >: (Row, V)]: Set[B]

    Definition Classes
    TraversableOnce → GenTraversableOnce
  189. def toStream: Stream[(Row, V)]

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

    Definition Classes
    MapLike → TraversableLike → Function1 → AnyRef → Any
  191. def toTraversable: Traversable[(Row, V)]

    Definition Classes
    TraversableLike → TraversableOnce → GenTraversableOnce
  192. def toVector: Vector[(Row, V)]

    Definition Classes
    TraversableOnce → GenTraversableOnce
  193. def transform(f: (Row, V) ⇒ V): MultiColumnOpenHashMap.this.type

    Definition Classes
    MapLike
  194. def transpose[B](implicit asTraversable: ((Row, V)) ⇒ GenTraversableOnce[B]): Iterable[Iterable[B]]

    Definition Classes
    GenericTraversableTemplate
    Annotations
    @migration
    Migration

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

  195. def unzip[A1, A2](implicit asPair: ((Row, V)) ⇒ (A1, A2)): (Iterable[A1], Iterable[A2])

    Definition Classes
    GenericTraversableTemplate
  196. def unzip3[A1, A2, A3](implicit asTriple: ((Row, V)) ⇒ (A1, A2, A3)): (Iterable[A1], Iterable[A2], Iterable[A3])

    Definition Classes
    GenericTraversableTemplate
  197. def update(r: Row, hash: Int, v: V): Boolean

    Set the value for a row given pre-computed hash

    Set the value for a row given pre-computed hash

    Definition Classes
    MultiColumnOpenHashMapSegmentMap
  198. def update(r: WrappedInternalRow, v: V): Unit

    Set the value for a row

  199. def update(r: Row, v: V): Unit

    Set the value for a row

    Set the value for a row

    Definition Classes
    MultiColumnOpenHashMap → MapLike
  200. def updated[B1 >: V](key: Row, value: B1): Map[Row, B1]

    Definition Classes
    MapLike → MapLike
  201. def values: Iterable[V]

    Definition Classes
    MapLike → GenMapLike
    Annotations
    @migration
    Migration

    (Changed in version 2.8.0) values returns Iterable[B] rather than Iterator[B].

  202. def valuesIterator: Iterator[V]

    Definition Classes
    MultiColumnOpenHashMap → MapLike → GenMapLike → SegmentMap
  203. def view(from: Int, until: Int): IterableView[(Row, V), MultiColumnOpenHashMap[V]]

    Definition Classes
    IterableLike → TraversableLike
  204. def view: IterableView[(Row, V), MultiColumnOpenHashMap[V]]

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

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  208. def withDefault(d: (Row) ⇒ V): Map[Row, V]

    Definition Classes
    Map
  209. def withDefaultValue(d: V): Map[Row, V]

    Definition Classes
    Map
  210. def withFilter(p: ((Row, V)) ⇒ Boolean): FilterMonadic[(Row, V), MultiColumnOpenHashMap[V]]

    Definition Classes
    TraversableLike → FilterMonadic
  211. def writeLock(): WriteLock

    Definition Classes
    ReentrantReadWriteLock → ReadWriteLock
  212. def zip[A1 >: (Row, V), B, That](that: GenIterable[B])(implicit bf: CanBuildFrom[MultiColumnOpenHashMap[V], (A1, B), That]): That

    Definition Classes
    IterableLike → GenIterableLike
  213. def zipAll[B, A1 >: (Row, V), That](that: GenIterable[B], thisElem: A1, thatElem: B)(implicit bf: CanBuildFrom[MultiColumnOpenHashMap[V], (A1, B), That]): That

    Definition Classes
    IterableLike → GenIterableLike
  214. def zipWithIndex[A1 >: (Row, V), That](implicit bf: CanBuildFrom[MultiColumnOpenHashMap[V], (A1, Int), That]): That

    Definition Classes
    IterableLike → GenIterableLike

Deprecated Value Members

  1. def /:\[A1 >: (Row, V)](z: A1)(op: (A1, A1) ⇒ A1): A1

    Definition Classes
    GenTraversableOnce
    Annotations
    @deprecated
    Deprecated

    (Since version 2.10.0) use fold instead

Inherited from Serializable

Inherited from Map[Row, V]

Inherited from MapLike[Row, V, MultiColumnOpenHashMap[V]]

Inherited from Cloneable[MultiColumnOpenHashMap[V]]

Inherited from Cloneable

Inherited from Cloneable

Inherited from Shrinkable[Row]

Inherited from Builder[(Row, V), MultiColumnOpenHashMap[V]]

Inherited from Growable[(Row, V)]

Inherited from Clearable

Inherited from Map[Row, V]

Inherited from MapLike[Row, V, MultiColumnOpenHashMap[V]]

Inherited from Subtractable[Row, MultiColumnOpenHashMap[V]]

Inherited from PartialFunction[Row, V]

Inherited from (Row) ⇒ V

Inherited from GenMap[Row, V]

Inherited from GenMapLike[Row, V, MultiColumnOpenHashMap[V]]

Inherited from Iterable[(Row, V)]

Inherited from Iterable[(Row, V)]

Inherited from IterableLike[(Row, V), MultiColumnOpenHashMap[V]]

Inherited from Equals

Inherited from GenIterable[(Row, V)]

Inherited from GenIterableLike[(Row, V), MultiColumnOpenHashMap[V]]

Inherited from Traversable[(Row, V)]

Inherited from Mutable

Inherited from Traversable[(Row, V)]

Inherited from GenTraversable[(Row, V)]

Inherited from GenericTraversableTemplate[(Row, V), Iterable]

Inherited from TraversableLike[(Row, V), MultiColumnOpenHashMap[V]]

Inherited from GenTraversableLike[(Row, V), MultiColumnOpenHashMap[V]]

Inherited from Parallelizable[(Row, V), ParMap[Row, V]]

Inherited from TraversableOnce[(Row, V)]

Inherited from GenTraversableOnce[(Row, V)]

Inherited from FilterMonadic[(Row, V), MultiColumnOpenHashMap[V]]

Inherited from HasNewBuilder[(Row, V), MultiColumnOpenHashMap[V]]

Inherited from SegmentMap[Row, V]

Inherited from ReentrantReadWriteLock

Inherited from Serializable

Inherited from ReadWriteLock

Inherited from AnyRef

Inherited from Any

Ungrouped