Class AbstractKeyedStateBackend<K>

    • Field Detail

      • keySerializer

        protected final org.apache.flink.api.common.typeutils.TypeSerializer<K> keySerializer
        The key serializer.
      • numberOfKeyGroups

        protected final int numberOfKeyGroups
        The number of key-groups aka max parallelism.
      • keyGroupRange

        protected final KeyGroupRange keyGroupRange
        Range of key-groups for which this backend is responsible.
      • kvStateRegistry

        protected final TaskKvStateRegistry kvStateRegistry
        KvStateRegistry helper for this task.
      • cancelStreamRegistry

        protected org.apache.flink.core.fs.CloseableRegistry cancelStreamRegistry
        Registry for all opened streams, so they can be closed if the task using this backend is closed.
      • userCodeClassLoader

        protected final ClassLoader userCodeClassLoader
      • keyGroupCompressionDecorator

        protected final StreamCompressionDecorator keyGroupCompressionDecorator
        Decorates the input and output streams to write key-groups compressed.
      • keyContext

        protected final InternalKeyContext<K> keyContext
        The key context for this backend.