Package

org.apache.spark.sql.catalyst

util

Permalink

package util

Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. util
  2. AnyRef
  3. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. class AbstractScalaRowIterator[T] extends Iterator[T]

    Permalink

    Shim to allow us to implement scala.Iterator in Java.

    Shim to allow us to implement scala.Iterator in Java. Scala 2.11+ has an AbstractIterator class for this, but that class is private[scala] in 2.10. We need to explicitly fix this to Row in order to work around a spurious IntelliJ compiler error. This cannot be an abstract class because that leads to compilation errors under Scala 2.11.

  2. class ArrayBasedMapData extends MapData

    Permalink
  3. abstract class ArrayData extends SpecializedGetters with Serializable

    Permalink
  4. case class BadRecordException(record: () ⇒ UTF8String, partialResult: () ⇒ Option[InternalRow], cause: Throwable) extends Exception with Product with Serializable

    Permalink

    Exception thrown when the underlying parser meet a bad record and can't parse it.

    Exception thrown when the underlying parser meet a bad record and can't parse it.

    record

    a function to return the record that cause the parser to fail

    partialResult

    a function that returns an optional row, which is the partial result of parsing this bad record.

    cause

    the actual exception about why the record is bad and can't be parsed.

  5. class CaseInsensitiveMap[T] extends Map[String, T] with Serializable

    Permalink

    Builds a map in which keys are case insensitive.

    Builds a map in which keys are case insensitive. Input map can be accessed for cases where case-sensitive information is required. The primary constructor is marked private to avoid nested case-insensitive map creation, otherwise the keys in the original map will become case-insensitive in this scenario.

  6. class GenericArrayData extends ArrayData

    Permalink
  7. abstract class MapData extends Serializable

    Permalink

    This is an internal data representation for map type in Spark SQL.

    This is an internal data representation for map type in Spark SQL. This should not implement equals and hashCode because the type cannot be used as join keys, grouping keys, or in equality tests. See SPARK-9415 and PR#13847 for the discussions.

  8. sealed trait ParseMode extends AnyRef

    Permalink
  9. class QuantileSummaries extends Serializable

    Permalink

    Helper class to compute approximate quantile summary.

    Helper class to compute approximate quantile summary. This implementation is based on the algorithm proposed in the paper: "Space-efficient Online Computation of Quantile Summaries" by Greenwald, Michael and Khanna, Sanjeev. (http://dx.doi.org/10.1145/375663.375670)

    In order to optimize for speed, it maintains an internal buffer of the last seen samples, and only inserts them after crossing a certain size threshold. This guarantees a near-constant runtime complexity compared to the original algorithm.

  10. class StringKeyHashMap[T] extends AnyRef

    Permalink

Value Members

  1. object ArrayBasedMapData extends Serializable

    Permalink
  2. object ArrayData extends Serializable

    Permalink
  3. object CaseInsensitiveMap extends Serializable

    Permalink
  4. object CompressionCodecs

    Permalink
  5. object DateTimeUtils

    Permalink

    Helper functions for converting between internal and external date and time representations.

    Helper functions for converting between internal and external date and time representations. Dates are exposed externally as java.sql.Date and are represented internally as the number of dates since the Unix epoch (1970-01-01). Timestamps are exposed externally as java.sql.Timestamp and are stored internally as longs, which are capable of storing timestamps with microsecond precision.

  6. object DropMalformedMode extends ParseMode with Product with Serializable

    Permalink

    This mode ignores the whole corrupted records.

  7. object FailFastMode extends ParseMode with Product with Serializable

    Permalink

    This mode throws an exception when it meets corrupted records.

  8. object NumberConverter

    Permalink
  9. object ParseMode extends Logging

    Permalink
  10. object PermissiveMode extends ParseMode with Product with Serializable

    Permalink

    This mode permissively parses the records.

  11. object QuantileSummaries extends Serializable

    Permalink
  12. object StringKeyHashMap

    Permalink

    Build a map with String type of key, and it also supports either key case sensitive or insensitive.

  13. object StringUtils

    Permalink
  14. object TypeUtils

    Permalink

    Helper functions to check for valid data types.

  15. def benchmark[A](f: ⇒ A): A

    Permalink
  16. def fileToString(file: File, encoding: String = "UTF-8"): String

    Permalink
  17. def quietly[A](f: ⇒ A): A

    Permalink

    Silences output to stderr or stdout for the duration of f

  18. def quoteIdentifier(name: String): String

    Permalink
  19. def resourceToBytes(resource: String, classLoader: ClassLoader = Utils.getSparkClassLoader): Array[Byte]

    Permalink
  20. def resourceToString(resource: String, encoding: String = "UTF-8", classLoader: ClassLoader = Utils.getSparkClassLoader): String

    Permalink
  21. def sideBySide(left: Seq[String], right: Seq[String]): Seq[String]

    Permalink
  22. def sideBySide(left: String, right: String): Seq[String]

    Permalink
  23. def stackTraceToString(t: Throwable): String

    Permalink
  24. def stringOrNull(a: AnyRef): String

    Permalink
  25. def stringToFile(file: File, str: String): File

    Permalink
  26. def toPrettySQL(e: Expression): String

    Permalink
  27. def usePrettyExpression(e: Expression): Expression

    Permalink

Inherited from AnyRef

Inherited from Any

Ungrouped