org.apache.spark.sql

collection

package collection

Visibility
  1. Public
  2. All

Type Members

  1. class BoundedSortedSet[K, V <: Comparable[V]] extends TreeSet[(K, V)]

  2. trait ChangeValue[K, V] extends AnyRef

  3. class ExecutorLocalPartition extends Partition

  4. class ExecutorLocalRDD[T] extends RDD[T]

  5. class ExecutorLocalShellPartition extends Partition

  6. class FixedPartitionRDD[T] extends RDD[T]

  7. final class GenerateFlatIterator[A, U] extends Iterator[A]

    An iterator that will keep generating iterators by invoking a given function and return a flattened iterator.

  8. 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.

  9. final class MultiColumnOpenHashSet extends Iterable[ReusableRow] with IterableLike[ReusableRow, MultiColumnOpenHashSet] with Growable[Row] with Builder[Row, MultiColumnOpenHashSet] with Serializable

    A simple, fast hash set optimized for non-null insertion-only use case, where keys are never removed.

  10. class MultiExecutorLocalPartition extends Partition

  11. class ReusableRow extends Row with Serializable

    A Row implementation that can be reused (much like SpecificMutableRow for InternalRow)

  12. trait SegmentMap[K, V] extends ReentrantReadWriteLock

  13. final class SlicedIterator[A] extends Iterator[A]

  14. final class UUIDRegionKey extends Serializable with Comparable[UUIDRegionKey]

  15. final class WrappedInternalRow extends Row

    Wraps an InternalRow to expose a Row

  16. final class WrappedRow extends InternalRow with BaseGenericInternalRow

    Wraps a Row to expose an InternalRow

Value Members

  1. object GenerateFlatIterator

  2. object SegmentMap extends Serializable

  3. object ToolsCallbackInit extends Logging

  4. object Utils

Ungrouped