Class/Object

org.apache.spark.sql.catalyst.encoders

ExpressionEncoder

Related Docs: object ExpressionEncoder | package encoders

Permalink

case class ExpressionEncoder[T](schema: StructType, flat: Boolean, toRowExpressions: Seq[Expression], fromRowExpression: Expression, clsTag: ClassTag[T]) extends Encoder[T] with Product with Serializable

A generic encoder for JVM objects.

schema

The schema after converting T to a Spark SQL row.

toRowExpressions

A set of expressions, one for each top-level field that can be used to extract the values from a raw object into an InternalRow.

fromRowExpression

An expression that will construct an object given an InternalRow.

clsTag

A classtag for T.

Linear Supertypes
Product, Equals, Encoder[T], Serializable, Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. ExpressionEncoder
  2. Product
  3. Equals
  4. Encoder
  5. Serializable
  6. Serializable
  7. AnyRef
  8. Any
  1. Hide All
  2. Show all
Visibility
  1. Public
  2. All

Instance Constructors

  1. new ExpressionEncoder(schema: StructType, flat: Boolean, toRowExpressions: Seq[Expression], fromRowExpression: Expression, clsTag: ClassTag[T])

    Permalink

    schema

    The schema after converting T to a Spark SQL row.

    toRowExpressions

    A set of expressions, one for each top-level field that can be used to extract the values from a raw object into an InternalRow.

    fromRowExpression

    An expression that will construct an object given an InternalRow.

    clsTag

    A classtag for T.

Value Members

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

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  5. def assertUnresolved(): Unit

    Permalink

    The process of resolution to a given schema throws away information about where a given field is being bound by ordinal instead of by name.

    The process of resolution to a given schema throws away information about where a given field is being bound by ordinal instead of by name. This method checks to make sure this process has not been done already in places where we plan to do later composition of encoders.

  6. val attrs: Seq[String]

    Permalink
    Attributes
    protected
  7. def bind(schema: Seq[Attribute]): ExpressionEncoder[T]

    Permalink

    Returns a copy of this encoder where the expressions used to construct an object from an input row have been bound to the ordinals of the given schema.

    Returns a copy of this encoder where the expressions used to construct an object from an input row have been bound to the ordinals of the given schema. Note that you need to first call resolve before bind.

  8. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  9. val clsTag: ClassTag[T]

    Permalink

    A classtag for T.

    A classtag for T.

    Definition Classes
    ExpressionEncoderEncoder
  10. def defaultBinding: ExpressionEncoder[T]

    Permalink

    Returns this encoder where it has been bound to its own output (i.e.

    Returns this encoder where it has been bound to its own output (i.e. no remaping of columns is performed).

  11. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  12. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  13. val flat: Boolean

    Permalink
  14. def fromRow(row: InternalRow): T

    Permalink

    Returns an object of type T, extracting the required values from the provided row.

    Returns an object of type T, extracting the required values from the provided row. Note that you must resolve and bind an encoder to a specific schema before you can call this function.

  15. val fromRowExpression: Expression

    Permalink

    An expression that will construct an object given an InternalRow.

  16. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  17. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  18. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  19. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  20. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  21. def resolve(schema: Seq[Attribute], outerScopes: ConcurrentMap[String, AnyRef]): ExpressionEncoder[T]

    Permalink

    Returns a new copy of this encoder, where the expressions used by fromRow are resolved to the given schema.

  22. val schema: StructType

    Permalink

    The schema after converting T to a Spark SQL row.

    The schema after converting T to a Spark SQL row.

    Definition Classes
    ExpressionEncoderEncoder
  23. val schemaString: String

    Permalink
    Attributes
    protected
  24. def shift(delta: Int): ExpressionEncoder[T]

    Permalink

    Returns a new encoder with input columns shifted by delta ordinals

  25. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  26. def toRow(t: T): InternalRow

    Permalink

    Returns an encoded version of t as a Spark SQL row.

    Returns an encoded version of t as a Spark SQL row. Note that multiple calls to toRow are allowed to return the same actual InternalRow object. Thus, the caller should copy the result before making another call if required.

  27. val toRowExpressions: Seq[Expression]

    Permalink

    A set of expressions, one for each top-level field that can be used to extract the values from a raw object into an InternalRow.

  28. def toString(): String

    Permalink
    Definition Classes
    ExpressionEncoder → AnyRef → Any
  29. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from Product

Inherited from Equals

Inherited from Encoder[T]

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped