Class RegisteredKeyValueStateBackendMetaInfo<N,​S>

  • Type Parameters:
    S - Type of state value

    public class RegisteredKeyValueStateBackendMetaInfo<N,​S>
    extends RegisteredStateMetaInfoBase
    Compound meta information for a registered state in a keyed state backend. This combines all serializers and the state name.
    • Constructor Detail

      • RegisteredKeyValueStateBackendMetaInfo

        public RegisteredKeyValueStateBackendMetaInfo​(@Nonnull
                                                      String name,
                                                      @Nonnull
                                                      org.apache.flink.api.common.state.v2.StateDescriptor.Type stateType,
                                                      @Nonnull
                                                      org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
                                                      @Nonnull
                                                      org.apache.flink.api.common.typeutils.TypeSerializer<S> stateSerializer)
      • RegisteredKeyValueStateBackendMetaInfo

        public RegisteredKeyValueStateBackendMetaInfo​(@Nonnull
                                                      String name,
                                                      @Nonnull
                                                      org.apache.flink.api.common.state.v2.StateDescriptor.Type stateType,
                                                      @Nonnull
                                                      org.apache.flink.api.common.typeutils.TypeSerializer<N> namespaceSerializer,
                                                      @Nonnull
                                                      org.apache.flink.api.common.typeutils.TypeSerializer<S> stateSerializer,
                                                      @Nonnull
                                                      StateSnapshotTransformer.StateSnapshotTransformFactory<S> stateSnapshotTransformFactory)
      • RegisteredKeyValueStateBackendMetaInfo

        public RegisteredKeyValueStateBackendMetaInfo​(@Nonnull
                                                      StateMetaInfoSnapshot snapshot)
    • Method Detail

      • getStateType

        @Nonnull
        public org.apache.flink.api.common.state.v2.StateDescriptor.Type getStateType()
      • getNamespaceSerializer

        @Nonnull
        public org.apache.flink.api.common.typeutils.TypeSerializer<N> getNamespaceSerializer()
      • getStateSerializer

        @Nonnull
        public org.apache.flink.api.common.typeutils.TypeSerializer<S> getStateSerializer()
      • updateStateSerializer

        @Nonnull
        public org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility<S> updateStateSerializer​(org.apache.flink.api.common.typeutils.TypeSerializer<S> newStateSerializer)
      • hashCode

        public int hashCode()
        Overrides:
        hashCode in class Object
      • checkStateMetaInfo

        public void checkStateMetaInfo​(org.apache.flink.api.common.state.v2.StateDescriptor<?> stateDesc)