Class CoderTypeInformation<T>

java.lang.Object
org.apache.flink.api.common.typeinfo.TypeInformation<T>
org.apache.beam.runners.flink.translation.types.CoderTypeInformation<T>
All Implemented Interfaces:
Serializable, org.apache.flink.api.common.typeinfo.AtomicType<T>

public class CoderTypeInformation<T> extends org.apache.flink.api.common.typeinfo.TypeInformation<T> implements org.apache.flink.api.common.typeinfo.AtomicType<T>
Flink TypeInformation for Beam Coders.
See Also:
  • Constructor Details

    • CoderTypeInformation

      public CoderTypeInformation(Coder<T> coder, PipelineOptions pipelineOptions)
    • CoderTypeInformation

      public CoderTypeInformation(Coder<T> coder, org.apache.beam.runners.core.construction.SerializablePipelineOptions pipelineOptions)
  • Method Details

    • getCoder

      public Coder<T> getCoder()
    • isBasicType

      public boolean isBasicType()
      Specified by:
      isBasicType in class org.apache.flink.api.common.typeinfo.TypeInformation<T>
    • isTupleType

      public boolean isTupleType()
      Specified by:
      isTupleType in class org.apache.flink.api.common.typeinfo.TypeInformation<T>
    • getArity

      public int getArity()
      Specified by:
      getArity in class org.apache.flink.api.common.typeinfo.TypeInformation<T>
    • getTypeClass

      public Class<T> getTypeClass()
      Specified by:
      getTypeClass in class org.apache.flink.api.common.typeinfo.TypeInformation<T>
    • isKeyType

      public boolean isKeyType()
      Specified by:
      isKeyType in class org.apache.flink.api.common.typeinfo.TypeInformation<T>
    • createSerializer

      public org.apache.flink.api.common.typeutils.TypeSerializer<T> createSerializer(org.apache.flink.api.common.ExecutionConfig config)
      Specified by:
      createSerializer in class org.apache.flink.api.common.typeinfo.TypeInformation<T>
    • getTotalFields

      public int getTotalFields()
      Specified by:
      getTotalFields in class org.apache.flink.api.common.typeinfo.TypeInformation<T>
    • withPipelineOptions

      public CoderTypeInformation<T> withPipelineOptions(PipelineOptions pipelineOptions)
      Creates a new CoderTypeInformation with PipelineOptions, that can be used for FileSystems registration.
      Parameters:
      pipelineOptions - Options of current pipeline.
      Returns:
      New type information.
      See Also:
    • equals

      public boolean equals(@Nullable Object o)
      Specified by:
      equals in class org.apache.flink.api.common.typeinfo.TypeInformation<T>
    • hashCode

      public int hashCode()
      Specified by:
      hashCode in class org.apache.flink.api.common.typeinfo.TypeInformation<T>
    • canEqual

      public boolean canEqual(Object obj)
      Specified by:
      canEqual in class org.apache.flink.api.common.typeinfo.TypeInformation<T>
    • toString

      public String toString()
      Specified by:
      toString in class org.apache.flink.api.common.typeinfo.TypeInformation<T>
    • createComparator

      public org.apache.flink.api.common.typeutils.TypeComparator<T> createComparator(boolean sortOrderAscending, org.apache.flink.api.common.ExecutionConfig executionConfig)
      Specified by:
      createComparator in interface org.apache.flink.api.common.typeinfo.AtomicType<T>