Packages

object AgnosticEncoders

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

Type Members

  1. case class ArrayEncoder[E](element: AgnosticEncoder[E], containsNull: Boolean) extends AgnosticEncoder[Array[E]] with Product with Serializable
  2. abstract class BaseRowEncoder extends StructEncoder[Row]
  3. abstract class BoxedLeafEncoder[E, P] extends LeafEncoder[E]
  4. case class DateEncoder(lenientSerialization: Boolean) extends LeafEncoder[Date] with Product with Serializable
  5. case class EncoderField(name: String, enc: AgnosticEncoder[_], nullable: Boolean, metadata: Metadata, readMethod: Option[String] = None, writeMethod: Option[String] = None) extends Product with Serializable
  6. abstract class EnumEncoder[E] extends AgnosticEncoder[E]
    Attributes
    protected
  7. case class InstantEncoder(lenientSerialization: Boolean) extends LeafEncoder[Instant] with Product with Serializable
  8. case class IterableEncoder[C, E](clsTag: ClassTag[C], element: AgnosticEncoder[E], containsNull: Boolean, lenientSerialization: Boolean) extends AgnosticEncoder[C] with Product with Serializable

    Encoder for collections.

    Encoder for collections.

    This encoder can be lenient for Row encoders. In that case we allow Seq, primitive array (if any), and generic arrays as input.

  9. case class JavaBeanEncoder[K](clsTag: ClassTag[K], fields: Seq[EncoderField]) extends StructEncoder[K] with Product with Serializable
  10. case class JavaDecimalEncoder(dt: DecimalType, lenientSerialization: Boolean) extends LeafEncoder[BigDecimal] with Product with Serializable
  11. case class JavaEnumEncoder[E](clsTag: ClassTag[E]) extends EnumEncoder[E] with Product with Serializable
  12. abstract class LeafEncoder[E] extends AgnosticEncoder[E]
    Attributes
    protected
  13. case class LocalDateEncoder(lenientSerialization: Boolean) extends LeafEncoder[LocalDate] with Product with Serializable
  14. case class MapEncoder[C, K, V](clsTag: ClassTag[C], keyEncoder: AgnosticEncoder[K], valueEncoder: AgnosticEncoder[V], valueContainsNull: Boolean) extends AgnosticEncoder[C] with Product with Serializable
  15. case class OptionEncoder[E](elementEncoder: AgnosticEncoder[E]) extends AgnosticEncoder[Option[E]] with Product with Serializable
  16. abstract class PrimitiveLeafEncoder[E] extends LeafEncoder[E]
  17. case class ProductEncoder[K](clsTag: ClassTag[K], fields: Seq[EncoderField], outerPointerGetter: Option[() => AnyRef]) extends StructEncoder[K] with Product with Serializable
  18. case class RowEncoder(fields: Seq[EncoderField]) extends BaseRowEncoder with Product with Serializable
  19. case class ScalaDecimalEncoder(dt: DecimalType) extends LeafEncoder[BigDecimal] with Product with Serializable
  20. case class ScalaEnumEncoder[T, E](parent: Class[T], clsTag: ClassTag[E]) extends EnumEncoder[E] with Product with Serializable
  21. case class SparkDecimalEncoder(dt: DecimalType) extends LeafEncoder[Decimal] with Product with Serializable
  22. trait StructEncoder[K] extends AgnosticEncoder[K]
  23. case class TimestampEncoder(lenientSerialization: Boolean) extends LeafEncoder[Timestamp] with Product with Serializable
  24. case class TransformingEncoder[I, O](clsTag: ClassTag[I], transformed: AgnosticEncoder[O], codecProvider: () => Codec[_ >: I, O]) extends AgnosticEncoder[I] with Product with Serializable

    Encoder that transforms external data into a representation that can be further processed by another encoder.

    Encoder that transforms external data into a representation that can be further processed by another encoder. This is fallback for scenarios where objects can't be represented using standard encoders, an example of this is where we use a different (opaque) serialization format (i.e. java serialization, kryo serialization, or protobuf).

  25. case class UDTEncoder[E >: Null](udt: UserDefinedType[E], udtClass: Class[_ <: UserDefinedType[_]]) extends AgnosticEncoder[E] with Product with Serializable

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. val DEFAULT_JAVA_DECIMAL_ENCODER: JavaDecimalEncoder
  5. val DEFAULT_SCALA_DECIMAL_ENCODER: ScalaDecimalEncoder
  6. val DEFAULT_SPARK_DECIMAL_ENCODER: SparkDecimalEncoder
  7. val LENIENT_DATE_ENCODER: DateEncoder
  8. val LENIENT_INSTANT_ENCODER: InstantEncoder
  9. val LENIENT_LOCAL_DATE_ENCODER: LocalDateEncoder
  10. val LENIENT_TIMESTAMP_ENCODER: TimestampEncoder
  11. val STRICT_DATE_ENCODER: DateEncoder
  12. val STRICT_INSTANT_ENCODER: InstantEncoder
  13. val STRICT_LOCAL_DATE_ENCODER: LocalDateEncoder
  14. val STRICT_TIMESTAMP_ENCODER: TimestampEncoder
  15. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  16. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
  17. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  18. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  19. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  20. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @IntrinsicCandidate() @native()
  21. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  22. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  23. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  24. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @IntrinsicCandidate() @native()
  25. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  26. def toString(): String
    Definition Classes
    AnyRef → Any
  27. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  28. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  29. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  30. case object BinaryEncoder extends LeafEncoder[Array[Byte]] with Product with Serializable
  31. case object BoxedBooleanEncoder extends BoxedLeafEncoder[Boolean, Boolean] with Product with Serializable
  32. case object BoxedByteEncoder extends BoxedLeafEncoder[Byte, Byte] with Product with Serializable
  33. case object BoxedDoubleEncoder extends BoxedLeafEncoder[Double, Double] with Product with Serializable
  34. case object BoxedFloatEncoder extends BoxedLeafEncoder[Float, Float] with Product with Serializable
  35. case object BoxedIntEncoder extends BoxedLeafEncoder[Integer, Int] with Product with Serializable
  36. case object BoxedLongEncoder extends BoxedLeafEncoder[Long, Long] with Product with Serializable
  37. case object BoxedShortEncoder extends BoxedLeafEncoder[Short, Short] with Product with Serializable
  38. case object CalendarIntervalEncoder extends LeafEncoder[CalendarInterval] with Product with Serializable
  39. case object DayTimeIntervalEncoder extends LeafEncoder[Duration] with Product with Serializable
  40. case object JavaBigIntEncoder extends LeafEncoder[BigInteger] with Product with Serializable
  41. case object LocalDateTimeEncoder extends LeafEncoder[LocalDateTime] with Product with Serializable
  42. case object NullEncoder extends LeafEncoder[Void] with Product with Serializable
  43. case object PrimitiveBooleanEncoder extends PrimitiveLeafEncoder[Boolean] with Product with Serializable
  44. case object PrimitiveByteEncoder extends PrimitiveLeafEncoder[Byte] with Product with Serializable
  45. case object PrimitiveDoubleEncoder extends PrimitiveLeafEncoder[Double] with Product with Serializable
  46. case object PrimitiveFloatEncoder extends PrimitiveLeafEncoder[Float] with Product with Serializable
  47. case object PrimitiveIntEncoder extends PrimitiveLeafEncoder[Int] with Product with Serializable
  48. case object PrimitiveLongEncoder extends PrimitiveLeafEncoder[Long] with Product with Serializable
  49. case object PrimitiveShortEncoder extends PrimitiveLeafEncoder[Short] with Product with Serializable
  50. object ProductEncoder extends Serializable
  51. case object ScalaBigIntEncoder extends LeafEncoder[BigInt] with Product with Serializable
  52. case object StringEncoder extends LeafEncoder[String] with Product with Serializable
  53. object UnboundRowEncoder extends BaseRowEncoder
  54. case object VariantEncoder extends LeafEncoder[VariantVal] with Product with Serializable
  55. case object YearMonthIntervalEncoder extends LeafEncoder[Period] with Product with Serializable

Deprecated Value Members

  1. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable]) @Deprecated
    Deprecated

    (Since version 9)

Inherited from AnyRef

Inherited from Any

Ungrouped