Package

org.apache.spark.sql

collection

Permalink

package collection

Visibility
  1. Public
  2. All

Type Members

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

    Permalink
  2. trait ChangeValue[K, V] extends AnyRef

    Permalink
  3. class ExecutorLocalPartition extends Partition

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

    Permalink
  5. class FixedPartitionRDD[T] extends RDD[T]

    Permalink
  6. final class GenerateFlatIterator[A, U] extends Iterator[A]

    Permalink

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

    An iterator that will keep generating iterators by invoking a given function and return a flattened iterator. Typically useful to generate an iterator on top of an arbitrary source where source size or structure is not pre-determined (e.g. source may not have flatMap/fold or such methods).

    Use the GenerateFlatIterator.TERMINATE token to indicate end of iteration.

  7. final class MultiBucketExecutorPartition extends Partition with KryoSerializable

    Permalink
  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

    Permalink

    A fast hash map implementation for nullable keys.

    A fast hash map implementation for nullable keys. This hash map supports insertions and updates, but not deletions. This map is about as fast as any other hashmap, while using much less space overhead.

    Under the hood, it uses the MultiColumnOpenHashSet implementation.

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

    Permalink

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

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

    The underlying implementation uses Scala compiler's specialization to generate optimized storage for two primitive types (Long and Int). It is much faster than Java's standard HashSet while incurring much less memory overhead. This can serve as building blocks for higher level data structures such as an optimized HashMap.

    This MultiColumnOpenHashSet is designed to serve as building blocks for higher level data structures such as an optimized hash map. Compared with standard hash set implementations, this class provides its various callbacks interfaces (e.g. allocateFunc, moveFunc) and interfaces to retrieve the position of a key in the underlying array.

    It uses quadratic probing with a power-of-2 hash table size, which is guaranteed to explore all spaces for each key (see http://en.wikipedia.org/wiki/Quadratic_probing).

  10. final class QCSSQLColumnHandler extends ColumnHandler

    Permalink
  11. class ReusableRow extends Row with Serializable

    Permalink

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

  12. trait SegmentMap[K, V] extends ReentrantReadWriteLock

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

    Permalink
  14. final class SmartExecutorBucketPartition extends Partition with KryoSerializable

    Permalink
  15. final class WrappedInternalRow extends Row

    Permalink

    Wraps an InternalRow to expose a Row

Value Members

  1. object GenerateFlatIterator

    Permalink
  2. object InternalRowToRow extends Row

    Permalink
  3. object OrderlessHashPartitioningExtract

    Permalink
  4. object QCSSQLColumnHandler extends Serializable

    Permalink
  5. object RowToInternalRow extends InternalRow with BaseGenericInternalRow

    Permalink
  6. object SegmentMap extends Serializable

    Permalink
  7. object ToolsCallbackInit extends Logging

    Permalink
  8. object Utils

    Permalink

Ungrouped