Package

org.apache.spark.sql

rf

Permalink

package rf

Module providing support for Spark SQL UDTs.

Since

3/30/17

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

Type Members

  1. implicit class CanBeColumn extends AnyRef

    Permalink
  2. class InternalRowTile extends ArrayTile

    Permalink

    Wrapper around a Tile encoded in a Catalyst InternalRow, for the purpose of providing compatible semantics over common operations.

    Wrapper around a Tile encoded in a Catalyst InternalRow, for the purpose of providing compatible semantics over common operations.

    Since

    11/29/17

  3. trait KryoBackedUDT[T >: Null] extends AnyRef

    Permalink

    Base class for UDTs who's contents is encoded using kryo

    Base class for UDTs who's contents is encoded using kryo

    Since

    4/18/17

  4. implicit class WithDecoder[T] extends AnyRef

    Permalink

Value Members

  1. object FilterTranslator

    Permalink

    This is a copy of org.apache.spark.sql.execution.datasources.DataSourceStrategy.translateFilter, modified to add our spatial predicates.

    This is a copy of org.apache.spark.sql.execution.datasources.DataSourceStrategy.translateFilter, modified to add our spatial predicates.

    Since

    1/11/18

  2. object InternalRowTile extends Serializable

    Permalink
  3. object VersionShims

    Permalink

    Collection of Spark version compatibility adapters.

    Collection of Spark version compatibility adapters.

    Since

    2/13/18

  4. def analyzer(sqlContext: SQLContext): Analyzer

    Permalink
  5. def projectStructExpression(dataType: StructType, input: Expression): MultiAlias

    Permalink

    Creates a Catalyst expression for flattening the fields in a struct into columns.

  6. def register(sqlContext: SQLContext): Unit

    Permalink
  7. def registry(sqlContext: SQLContext): FunctionRegistry

    Permalink
  8. def udtOf[T >: Null](implicit arg0: scala.reflect.api.JavaUniverse.TypeTag[T]): UserDefinedType[T]

    Permalink

    Lookup the registered Catalyst UDT for the given Scala type.

Inherited from AnyRef

Inherited from Any

Ungrouped