Class FlinkStateInternals.FlinkStateNamespaceKeySerializer

java.lang.Object
org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
org.apache.beam.runners.flink.translation.wrappers.streaming.state.FlinkStateInternals.FlinkStateNamespaceKeySerializer
All Implemented Interfaces:
Serializable
Enclosing class:
FlinkStateInternals<K>

public static class FlinkStateInternals.FlinkStateNamespaceKeySerializer extends org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
See Also:
  • Nested Class Summary

    Nested Classes
    Modifier and Type
    Class
    Description
    static final class 
    Serializer configuration snapshot for compatibility and format evolution.
  • Constructor Summary

    Constructors
    Constructor
    Description
     
  • Method Summary

    Modifier and Type
    Method
    Description
    org.apache.beam.runners.core.StateNamespace
    copy(org.apache.beam.runners.core.StateNamespace from)
     
    org.apache.beam.runners.core.StateNamespace
    copy(org.apache.beam.runners.core.StateNamespace from, org.apache.beam.runners.core.StateNamespace reuse)
     
    void
    copy(org.apache.flink.core.memory.DataInputView source, org.apache.flink.core.memory.DataOutputView target)
     
    org.apache.beam.runners.core.StateNamespace
     
    org.apache.beam.runners.core.StateNamespace
    deserialize(org.apache.beam.runners.core.StateNamespace reuse, org.apache.flink.core.memory.DataInputView source)
     
    org.apache.beam.runners.core.StateNamespace
    deserialize(org.apache.flink.core.memory.DataInputView source)
     
    org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
     
    boolean
     
    Coder<? extends BoundedWindow>
     
    int
     
    int
     
    boolean
     
    void
    serialize(org.apache.beam.runners.core.StateNamespace record, org.apache.flink.core.memory.DataOutputView target)
     
    org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<org.apache.beam.runners.core.StateNamespace>
     

    Methods inherited from class java.lang.Object

    clone, finalize, getClass, notify, notifyAll, toString, wait, wait, wait
  • Constructor Details

    • FlinkStateNamespaceKeySerializer

      public FlinkStateNamespaceKeySerializer(Coder<? extends BoundedWindow> coder)
  • Method Details

    • getCoder

      public Coder<? extends BoundedWindow> getCoder()
    • isImmutableType

      public boolean isImmutableType()
      Specified by:
      isImmutableType in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
    • duplicate

      public org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace> duplicate()
      Specified by:
      duplicate in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
    • createInstance

      public org.apache.beam.runners.core.StateNamespace createInstance()
      Specified by:
      createInstance in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
    • copy

      public org.apache.beam.runners.core.StateNamespace copy(org.apache.beam.runners.core.StateNamespace from)
      Specified by:
      copy in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
    • copy

      public org.apache.beam.runners.core.StateNamespace copy(org.apache.beam.runners.core.StateNamespace from, org.apache.beam.runners.core.StateNamespace reuse)
      Specified by:
      copy in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
    • getLength

      public int getLength()
      Specified by:
      getLength in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
    • serialize

      public void serialize(org.apache.beam.runners.core.StateNamespace record, org.apache.flink.core.memory.DataOutputView target) throws IOException
      Specified by:
      serialize in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
      Throws:
      IOException
    • deserialize

      public org.apache.beam.runners.core.StateNamespace deserialize(org.apache.flink.core.memory.DataInputView source) throws IOException
      Specified by:
      deserialize in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
      Throws:
      IOException
    • deserialize

      public org.apache.beam.runners.core.StateNamespace deserialize(org.apache.beam.runners.core.StateNamespace reuse, org.apache.flink.core.memory.DataInputView source) throws IOException
      Specified by:
      deserialize in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
      Throws:
      IOException
    • copy

      public void copy(org.apache.flink.core.memory.DataInputView source, org.apache.flink.core.memory.DataOutputView target) throws IOException
      Specified by:
      copy in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
      Throws:
      IOException
    • equals

      public boolean equals(Object obj)
      Specified by:
      equals in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
    • hashCode

      public int hashCode()
      Specified by:
      hashCode in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>
    • snapshotConfiguration

      public org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<org.apache.beam.runners.core.StateNamespace> snapshotConfiguration()
      Specified by:
      snapshotConfiguration in class org.apache.flink.api.common.typeutils.TypeSerializer<org.apache.beam.runners.core.StateNamespace>