object AgnosticEncoders
Linear Supertypes
Ordering
- Alphabetic
- By Inheritance
Inherited
- AgnosticEncoders
- AnyRef
- Any
- Hide All
- Show All
Visibility
- Public
- Protected
Type Members
- case class ArrayEncoder[E](element: AgnosticEncoder[E], containsNull: Boolean) extends AgnosticEncoder[Array[E]] with Product with Serializable
- abstract class BaseRowEncoder extends StructEncoder[Row]
- abstract class BoxedLeafEncoder[E, P] extends LeafEncoder[E]
- case class DateEncoder(lenientSerialization: Boolean) extends LeafEncoder[Date] with Product with Serializable
- case class EncoderField(name: String, enc: AgnosticEncoder[_], nullable: Boolean, metadata: Metadata, readMethod: Option[String] = None, writeMethod: Option[String] = None) extends Product with Serializable
- abstract class EnumEncoder[E] extends AgnosticEncoder[E]
- Attributes
- protected
- case class InstantEncoder(lenientSerialization: Boolean) extends LeafEncoder[Instant] with Product with Serializable
- 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.
- case class JavaBeanEncoder[K](clsTag: ClassTag[K], fields: Seq[EncoderField]) extends StructEncoder[K] with Product with Serializable
- case class JavaDecimalEncoder(dt: DecimalType, lenientSerialization: Boolean) extends LeafEncoder[BigDecimal] with Product with Serializable
- case class JavaEnumEncoder[E](clsTag: ClassTag[E]) extends EnumEncoder[E] with Product with Serializable
- abstract class LeafEncoder[E] extends AgnosticEncoder[E]
- Attributes
- protected
- case class LocalDateEncoder(lenientSerialization: Boolean) extends LeafEncoder[LocalDate] with Product with Serializable
- case class MapEncoder[C, K, V](clsTag: ClassTag[C], keyEncoder: AgnosticEncoder[K], valueEncoder: AgnosticEncoder[V], valueContainsNull: Boolean) extends AgnosticEncoder[C] with Product with Serializable
- case class OptionEncoder[E](elementEncoder: AgnosticEncoder[E]) extends AgnosticEncoder[Option[E]] with Product with Serializable
- abstract class PrimitiveLeafEncoder[E] extends LeafEncoder[E]
- case class ProductEncoder[K](clsTag: ClassTag[K], fields: Seq[EncoderField], outerPointerGetter: Option[() => AnyRef]) extends StructEncoder[K] with Product with Serializable
- case class RowEncoder(fields: Seq[EncoderField]) extends BaseRowEncoder with Product with Serializable
- case class ScalaDecimalEncoder(dt: DecimalType) extends LeafEncoder[BigDecimal] with Product with Serializable
- case class ScalaEnumEncoder[T, E](parent: Class[T], clsTag: ClassTag[E]) extends EnumEncoder[E] with Product with Serializable
- case class SparkDecimalEncoder(dt: DecimalType) extends LeafEncoder[Decimal] with Product with Serializable
- trait StructEncoder[K] extends AgnosticEncoder[K]
- case class TimestampEncoder(lenientSerialization: Boolean) extends LeafEncoder[Timestamp] with Product with Serializable
- 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).
- case class UDTEncoder[E >: Null](udt: UserDefinedType[E], udtClass: Class[_ <: UserDefinedType[_]]) extends AgnosticEncoder[E] with Product with Serializable
Value Members
- final def !=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def ##: Int
- Definition Classes
- AnyRef → Any
- final def ==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- val DEFAULT_JAVA_DECIMAL_ENCODER: JavaDecimalEncoder
- val DEFAULT_SCALA_DECIMAL_ENCODER: ScalaDecimalEncoder
- val DEFAULT_SPARK_DECIMAL_ENCODER: SparkDecimalEncoder
- val LENIENT_DATE_ENCODER: DateEncoder
- val LENIENT_INSTANT_ENCODER: InstantEncoder
- val LENIENT_LOCAL_DATE_ENCODER: LocalDateEncoder
- val LENIENT_TIMESTAMP_ENCODER: TimestampEncoder
- val STRICT_DATE_ENCODER: DateEncoder
- val STRICT_INSTANT_ENCODER: InstantEncoder
- val STRICT_LOCAL_DATE_ENCODER: LocalDateEncoder
- val STRICT_TIMESTAMP_ENCODER: TimestampEncoder
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @IntrinsicCandidate() @native()
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef → Any
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- def hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @IntrinsicCandidate() @native()
- final def isInstanceOf[T0]: Boolean
- Definition Classes
- Any
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @IntrinsicCandidate() @native()
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- def toString(): String
- Definition Classes
- AnyRef → Any
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- case object BinaryEncoder extends LeafEncoder[Array[Byte]] with Product with Serializable
- case object BoxedBooleanEncoder extends BoxedLeafEncoder[Boolean, Boolean] with Product with Serializable
- case object BoxedByteEncoder extends BoxedLeafEncoder[Byte, Byte] with Product with Serializable
- case object BoxedDoubleEncoder extends BoxedLeafEncoder[Double, Double] with Product with Serializable
- case object BoxedFloatEncoder extends BoxedLeafEncoder[Float, Float] with Product with Serializable
- case object BoxedIntEncoder extends BoxedLeafEncoder[Integer, Int] with Product with Serializable
- case object BoxedLongEncoder extends BoxedLeafEncoder[Long, Long] with Product with Serializable
- case object BoxedShortEncoder extends BoxedLeafEncoder[Short, Short] with Product with Serializable
- case object CalendarIntervalEncoder extends LeafEncoder[CalendarInterval] with Product with Serializable
- case object DayTimeIntervalEncoder extends LeafEncoder[Duration] with Product with Serializable
- case object JavaBigIntEncoder extends LeafEncoder[BigInteger] with Product with Serializable
- case object LocalDateTimeEncoder extends LeafEncoder[LocalDateTime] with Product with Serializable
- case object NullEncoder extends LeafEncoder[Void] with Product with Serializable
- case object PrimitiveBooleanEncoder extends PrimitiveLeafEncoder[Boolean] with Product with Serializable
- case object PrimitiveByteEncoder extends PrimitiveLeafEncoder[Byte] with Product with Serializable
- case object PrimitiveDoubleEncoder extends PrimitiveLeafEncoder[Double] with Product with Serializable
- case object PrimitiveFloatEncoder extends PrimitiveLeafEncoder[Float] with Product with Serializable
- case object PrimitiveIntEncoder extends PrimitiveLeafEncoder[Int] with Product with Serializable
- case object PrimitiveLongEncoder extends PrimitiveLeafEncoder[Long] with Product with Serializable
- case object PrimitiveShortEncoder extends PrimitiveLeafEncoder[Short] with Product with Serializable
- object ProductEncoder extends Serializable
- case object ScalaBigIntEncoder extends LeafEncoder[BigInt] with Product with Serializable
- case object StringEncoder extends LeafEncoder[String] with Product with Serializable
- object UnboundRowEncoder extends BaseRowEncoder
- case object VariantEncoder extends LeafEncoder[VariantVal] with Product with Serializable
- case object YearMonthIntervalEncoder extends LeafEncoder[Period] with Product with Serializable
Deprecated Value Members
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable]) @Deprecated
- Deprecated
(Since version 9)