Package

org.apache.flink.api.scala

typeutils

Permalink

package typeutils

Visibility
  1. Public
  2. All

Type Members

  1. class CaseClassComparator[T <: Product] extends TupleComparatorBase[T]

    Permalink

    Comparator for Case Classes.

    Comparator for Case Classes. Access is different from our Java Tuples so we have to treat them differently.

    Annotations
    @Internal()
  2. abstract class CaseClassSerializer[T <: Product] extends TupleSerializerBase[T] with Cloneable

    Permalink

    Serializer for Case Classes.

    Serializer for Case Classes. Creation and access is different from our Java Tuples so we have to treat them differently.

    Annotations
    @Internal() @SerialVersionUID()
  3. abstract class CaseClassTypeInfo[T <: Product] extends TupleTypeInfoBase[T]

    Permalink

    TypeInformation for Case Classes.

    TypeInformation for Case Classes. Creation and access is different from our Java Tuples so we have to treat them differently.

    Annotations
    @Public()
  4. class EitherSerializer[A, B] extends TypeSerializer[Either[A, B]] with LegacySerializerSnapshotTransformer[Either[A, B]]

    Permalink

    Serializer for Either.

    Serializer for Either.

    Annotations
    @Internal() @SerialVersionUID()
  5. class EitherTypeInfo[A, B, T <: Either[A, B]] extends TypeInformation[T]

    Permalink

    TypeInformation Either.

    TypeInformation Either.

    Annotations
    @Public()
  6. class EnumValueComparator[E <: Enumeration] extends TypeComparator[typeutils.EnumValueComparator.E.Value]

    Permalink

    Comparator for Enumeration values.

    Comparator for Enumeration values.

    Annotations
    @Internal() @SerialVersionUID()
  7. class EnumValueSerializer[E <: Enumeration] extends TypeSerializer[typeutils.EnumValueSerializer.E.Value]

    Permalink

    Serializer for Enumeration values.

    Serializer for Enumeration values.

    Annotations
    @Internal() @SerialVersionUID()
  8. class EnumValueTypeInfo[E <: Enumeration] extends TypeInformation[typeutils.EnumValueTypeInfo.E.Value] with AtomicType[typeutils.EnumValueTypeInfo.E.Value]

    Permalink

    TypeInformation for Enumeration values.

    TypeInformation for Enumeration values.

    Annotations
    @Public()
  9. class NothingSerializer extends TypeSerializer[Any]

    Permalink

    Serializer for cases where no serializer is required but the system still expects one.

    Serializer for cases where no serializer is required but the system still expects one. This happens for OptionTypeInfo when None is used, or for Either when one of the type parameters is Nothing.

    Annotations
    @Internal()
  10. class NothingSerializerSnapshot extends SimpleTypeSerializerSnapshot[Any]

    Permalink
  11. class OptionSerializer[A] extends TypeSerializer[Option[A]]

    Permalink

    Serializer for Option.

    Serializer for Option.

    Annotations
    @Internal() @SerialVersionUID()
  12. class OptionTypeComparator[A] extends TypeComparator[Option[A]]

    Permalink

    Comparator for Option values.

    Comparator for Option values. Note that None is lesser than any Some values.

    Annotations
    @Internal()
  13. class OptionTypeInfo[A, T <: Option[A]] extends TypeInformation[T] with AtomicType[T]

    Permalink

    TypeInformation for Option.

    TypeInformation for Option.

    Annotations
    @Public()
  14. class ScalaCaseClassSerializer[T <: Product] extends CaseClassSerializer[T] with SelfResolvingTypeSerializer[T]

    Permalink

    This is a non macro-generated, concrete Scala case class serializer.

    This is a non macro-generated, concrete Scala case class serializer.

    We need this serializer to replace the previously macro generated, anonymous CaseClassSerializer.

    Annotations
    @SerialVersionUID()
  15. final class ScalaCaseClassSerializerSnapshot[T <: Product] extends CompositeTypeSerializerSnapshot[T, ScalaCaseClassSerializer[T]]

    Permalink
  16. class ScalaEitherSerializerSnapshot[L, R] extends CompositeTypeSerializerSnapshot[Either[L, R], EitherSerializer[L, R]]

    Permalink
  17. class ScalaEnumSerializerSnapshot[E <: Enumeration] extends TypeSerializerSnapshot[typeutils.ScalaEnumSerializerSnapshot.E.Value]

    Permalink
  18. class ScalaNothingTypeInfo extends TypeInformation[Nothing]

    Permalink
    Annotations
    @Public()
  19. final class ScalaOptionSerializerConfigSnapshot[E] extends CompositeTypeSerializerConfigSnapshot[Option[E]]

    Permalink
  20. final class ScalaOptionSerializerSnapshot[E] extends CompositeTypeSerializerSnapshot[Option[E], OptionSerializer[E]]

    Permalink
  21. class ScalaTrySerializerConfigSnapshot[E] extends CompositeTypeSerializerConfigSnapshot[Try[E]]

    Permalink
  22. class ScalaTrySerializerSnapshot[E] extends CompositeTypeSerializerSnapshot[Try[E], TrySerializer[E]]

    Permalink
  23. class TraversableSerializer[T <: TraversableOnce[E], E] extends TypeSerializer[T] with Cloneable

    Permalink

    Serializer for Scala Collections.

    Serializer for Scala Collections.

    Annotations
    @Internal() @SerialVersionUID()
  24. class TraversableSerializerConfigSnapshot[T <: TraversableOnce[E], E] extends CompositeTypeSerializerConfigSnapshot[T]

    Permalink
  25. class TraversableSerializerSnapshot[T <: TraversableOnce[E], E] extends CompositeTypeSerializerSnapshot[T, TraversableSerializer[T, E]]

    Permalink
  26. abstract class TraversableTypeInfo[T <: TraversableOnce[E], E] extends TypeInformation[T]

    Permalink

    TypeInformation for Scala Collections.

    TypeInformation for Scala Collections.

    Annotations
    @Public()
  27. class TrySerializer[A] extends TypeSerializer[Try[A]]

    Permalink

    Serializer for scala.util.Try.

    Serializer for scala.util.Try.

    Annotations
    @Internal() @SerialVersionUID()
  28. class TryTypeInfo[A, T <: Try[A]] extends TypeInformation[T]

    Permalink

    TypeInformation for scala.util.Try.

    TypeInformation for scala.util.Try.

    Annotations
    @Public()
  29. final class Tuple2CaseClassSerializerSnapshot[T1, T2] extends CompositeTypeSerializerSnapshot[(T1, T2), ScalaCaseClassSerializer[(T1, T2)]]

    Permalink
  30. class UnitSerializer extends TypeSerializerSingleton[Unit]

    Permalink
    Annotations
    @Internal() @SerialVersionUID()
  31. class UnitTypeInfo extends TypeInformation[Unit]

    Permalink
    Annotations
    @Public()

Value Members

  1. object EnumValueSerializer extends Serializable

    Permalink
  2. object OptionSerializer extends Serializable

    Permalink
  3. object OptionTypeComparator extends Serializable

    Permalink
  4. object ScalaCaseClassSerializer extends Serializable

    Permalink
  5. object ScalaEnumSerializerSnapshot

    Permalink
  6. object TraversableSerializer extends Serializable

    Permalink
  7. object TrySerializer extends Serializable

    Permalink
  8. object Types

    Permalink

    This class gives access to the type information of the most common Scala types for which Flink has built-in serializers and comparators.

    This class gives access to the type information of the most common Scala types for which Flink has built-in serializers and comparators.

    This class contains types of org.apache.flink.api.common.typeinfo.Types and adds types for Scala specific classes (such as Unit or case classes).

    In many cases, Flink tries to analyze generic signatures of functions to determine return types automatically. This class is intended for cases where type information has to be supplied manually or cases where automatic type inference results in an inefficient type.

    Scala macros allow to determine type information of classes and type parameters. You can use Types.of to let type information be determined automatically.

    Annotations
    @PublicEvolving()
  9. object UnitSerializer extends Serializable

    Permalink

Ungrouped