Class StreamsConfig

  • Direct Known Subclasses:
    QuietStreamsConfig

    public class StreamsConfig
    extends org.apache.kafka.common.config.AbstractConfig
    Configuration for a KafkaStreams instance. Can also be used to configure the Kafka Streams internal KafkaConsumer, KafkaProducer and Admin. To avoid consumer/producer/admin property conflicts, you should prefix those properties using consumerPrefix(String), producerPrefix(String) and adminClientPrefix(String), respectively.

    Example:

    
     // potentially wrong: sets "metadata.max.age.ms" to 1 minute for producer AND consumer
     Properties streamsProperties = new Properties();
     streamsProperties.put(ConsumerConfig.METADATA_MAX_AGE_CONFIG, 60000);
     // or
     streamsProperties.put(ProducerConfig.METADATA_MAX_AGE_CONFIG, 60000);
    
     // suggested:
     Properties streamsProperties = new Properties();
     // sets "metadata.max.age.ms" to 1 minute for consumer only
     streamsProperties.put(StreamsConfig.consumerPrefix(ConsumerConfig.METADATA_MAX_AGE_CONFIG), 60000);
     // sets "metadata.max.age.ms" to 1 minute for producer only
     streamsProperties.put(StreamsConfig.producerPrefix(ProducerConfig.METADATA_MAX_AGE_CONFIG), 60000);
    
     StreamsConfig streamsConfig = new StreamsConfig(streamsProperties);
     
    This instance can also be used to pass in custom configurations to different modules (e.g. passing a special config in your customized serde class). The consumer/producer/admin prefix can also be used to distinguish these custom config values passed to different clients with the same config name. * Example:
    
     Properties streamsProperties = new Properties();
     // sets "my.custom.config" to "foo" for consumer only
     streamsProperties.put(StreamsConfig.consumerPrefix("my.custom.config"), "foo");
     // sets "my.custom.config" to "bar" for producer only
     streamsProperties.put(StreamsConfig.producerPrefix("my.custom.config"), "bar");
     // sets "my.custom.config2" to "boom" for all clients universally
     streamsProperties.put("my.custom.config2", "boom");
    
     // as a result, inside producer's serde class configure(..) function,
     // users can now read both key-value pairs "my.custom.config" -> "foo"
     // and "my.custom.config2" -> "boom" from the config map
     StreamsConfig streamsConfig = new StreamsConfig(streamsProperties);
     
    When increasing ProducerConfig.MAX_BLOCK_MS_CONFIG to be more resilient to non-available brokers you should also increase ConsumerConfig.MAX_POLL_INTERVAL_MS_CONFIG using the following guidance:
         max.poll.interval.ms > max.block.ms
     
    Kafka Streams requires at least the following properties to be set: By default, Kafka Streams does not allow users to overwrite the following properties (Streams setting shown in parentheses):
    • "group.id" (<application.id>) - Streams client will always use the application ID a consumer group ID
    • "enable.auto.commit" (false) - Streams client will always disable/turn off auto committing
    • "partition.assignment.strategy" (StreamsPartitionAssignor) - Streams client will always use its own partition assignor
    If "processing.guarantee" is set to "exactly_once", Kafka Streams does not allow users to overwrite the following properties (Streams setting shown in parentheses):
    • "isolation.level" (read_committed) - Consumers will always read committed data only
    • "enable.idempotence" (true) - Producer will always have idempotency enabled
    See Also:
    KafkaStreams(org.apache.kafka.streams.Topology, Properties), ConsumerConfig, ProducerConfig
    • Field Detail

      • STREAMS_INTERNAL_STREAM_COMMON_FOLDER

        public static final java.lang.String STREAMS_INTERNAL_STREAM_COMMON_FOLDER
        MapR specific constants.
        See Also:
        Constant Field Values
      • TOPIC_PREFIX

        public static final java.lang.String TOPIC_PREFIX
        Prefix used to provide default topic configs to be applied when creating internal topics. These should be valid properties from TopicConfig. It is recommended to use topicPrefix(String).
        See Also:
        Constant Field Values
      • CONSUMER_PREFIX

        public static final java.lang.String CONSUMER_PREFIX
        Prefix used to isolate consumer configs from other client configs. It is recommended to use consumerPrefix(String) to add this prefix to consumer properties.
        See Also:
        Constant Field Values
      • MAIN_CONSUMER_PREFIX

        public static final java.lang.String MAIN_CONSUMER_PREFIX
        Prefix used to override consumer configs for the main consumer client from the general consumer client configs. The override precedence is the following (from highest to lowest precedence): 1. main.consumer.[config-name] 2. consumer.[config-name] 3. [config-name]
        See Also:
        Constant Field Values
      • RESTORE_CONSUMER_PREFIX

        public static final java.lang.String RESTORE_CONSUMER_PREFIX
        Prefix used to override consumer configs for the restore consumer client from the general consumer client configs. The override precedence is the following (from highest to lowest precedence): 1. restore.consumer.[config-name] 2. consumer.[config-name] 3. [config-name]
        See Also:
        Constant Field Values
      • GLOBAL_CONSUMER_PREFIX

        public static final java.lang.String GLOBAL_CONSUMER_PREFIX
        Prefix used to override consumer configs for the global consumer client from the general consumer client configs. The override precedence is the following (from highest to lowest precedence): 1. global.consumer.[config-name] 2. consumer.[config-name] 3. [config-name]
        See Also:
        Constant Field Values
      • PRODUCER_PREFIX

        public static final java.lang.String PRODUCER_PREFIX
        Prefix used to isolate producer configs from other client configs. It is recommended to use producerPrefix(String) to add this prefix to producer properties.
        See Also:
        Constant Field Values
      • ADMIN_CLIENT_PREFIX

        public static final java.lang.String ADMIN_CLIENT_PREFIX
        Prefix used to isolate admin configs from other client configs. It is recommended to use adminClientPrefix(String) to add this prefix to admin client properties.
        See Also:
        Constant Field Values
      • UPGRADE_FROM_0100

        public static final java.lang.String UPGRADE_FROM_0100
        Config value for parameter "upgrade.from" for upgrading an application from version 0.10.0.x.
        See Also:
        Constant Field Values
      • UPGRADE_FROM_0101

        public static final java.lang.String UPGRADE_FROM_0101
        Config value for parameter "upgrade.from" for upgrading an application from version 0.10.1.x.
        See Also:
        Constant Field Values
      • UPGRADE_FROM_0102

        public static final java.lang.String UPGRADE_FROM_0102
        Config value for parameter "upgrade.from" for upgrading an application from version 0.10.2.x.
        See Also:
        Constant Field Values
      • UPGRADE_FROM_0110

        public static final java.lang.String UPGRADE_FROM_0110
        Config value for parameter "upgrade.from" for upgrading an application from version 0.11.0.x.
        See Also:
        Constant Field Values
      • UPGRADE_FROM_10

        public static final java.lang.String UPGRADE_FROM_10
        Config value for parameter "upgrade.from" for upgrading an application from version 1.0.x.
        See Also:
        Constant Field Values
      • UPGRADE_FROM_11

        public static final java.lang.String UPGRADE_FROM_11
        Config value for parameter "upgrade.from" for upgrading an application from version 1.1.x.
        See Also:
        Constant Field Values
      • UPGRADE_FROM_20

        public static final java.lang.String UPGRADE_FROM_20
        Config value for parameter "upgrade.from" for upgrading an application from version 2.0.x.
        See Also:
        Constant Field Values
      • UPGRADE_FROM_21

        public static final java.lang.String UPGRADE_FROM_21
        Config value for parameter "upgrade.from" for upgrading an application from version 2.1.x.
        See Also:
        Constant Field Values
      • UPGRADE_FROM_22

        public static final java.lang.String UPGRADE_FROM_22
        Config value for parameter "upgrade.from" for upgrading an application from version 2.2.x.
        See Also:
        Constant Field Values
      • UPGRADE_FROM_23

        public static final java.lang.String UPGRADE_FROM_23
        Config value for parameter "upgrade.from" for upgrading an application from version 2.3.x.
        See Also:
        Constant Field Values
      • EXACTLY_ONCE

        public static final java.lang.String EXACTLY_ONCE
        Config value for parameter "processing.guarantee" for exactly-once processing guarantees.

        Enabling exactly-once processing semantics requires broker version 0.11.0 or higher. If you enable this feature Kafka Streams will use more resources (like broker connections) compared to the AT_LEAST_ONCE case.

        See Also:
        EXACTLY_ONCE_BETA, Constant Field Values
      • EXACTLY_ONCE_BETA

        public static final java.lang.String EXACTLY_ONCE_BETA
        Config value for parameter "processing.guarantee" for exactly-once processing guarantees.

        Enabling exactly-once (beta) requires broker version 2.5 or higher. If you enable this feature Kafka Streams will use less resources (like broker connections) compare to the EXACTLY_ONCE case.

        See Also:
        Constant Field Values
      • ACCEPTABLE_RECOVERY_LAG_CONFIG

        public static final java.lang.String ACCEPTABLE_RECOVERY_LAG_CONFIG
        acceptable.recovery.lag
        See Also:
        Constant Field Values
      • APPLICATION_ID_CONFIG

        public static final java.lang.String APPLICATION_ID_CONFIG
        application.id
        See Also:
        Constant Field Values
      • APPLICATION_SERVER_CONFIG

        public static final java.lang.String APPLICATION_SERVER_CONFIG
        application.server
        See Also:
        Constant Field Values
      • BUFFERED_RECORDS_PER_PARTITION_CONFIG

        public static final java.lang.String BUFFERED_RECORDS_PER_PARTITION_CONFIG
        buffered.records.per.partition
        See Also:
        Constant Field Values
      • BUILT_IN_METRICS_VERSION_CONFIG

        public static final java.lang.String BUILT_IN_METRICS_VERSION_CONFIG
        built.in.metrics.version
        See Also:
        Constant Field Values
      • CACHE_MAX_BYTES_BUFFERING_CONFIG

        public static final java.lang.String CACHE_MAX_BYTES_BUFFERING_CONFIG
        cache.max.bytes.buffering
        See Also:
        Constant Field Values
      • CLIENT_ID_CONFIG

        public static final java.lang.String CLIENT_ID_CONFIG
        client.id
        See Also:
        Constant Field Values
      • COMMIT_INTERVAL_MS_CONFIG

        public static final java.lang.String COMMIT_INTERVAL_MS_CONFIG
        commit.interval.ms
        See Also:
        Constant Field Values
      • CONNECTIONS_MAX_IDLE_MS_CONFIG

        public static final java.lang.String CONNECTIONS_MAX_IDLE_MS_CONFIG
        connections.max.idle.ms
        See Also:
        Constant Field Values
      • DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG

        public static final java.lang.String DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG
        default.deserialization.exception.handler
        See Also:
        Constant Field Values
      • DEFAULT_PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG

        public static final java.lang.String DEFAULT_PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG
        default.production.exception.handler
        See Also:
        Constant Field Values
      • DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS

        public static final java.lang.String DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS
        default.windowed.key.serde.inner
        See Also:
        Constant Field Values
      • DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS

        public static final java.lang.String DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS
        default.windowed.value.serde.inner
        See Also:
        Constant Field Values
      • DEFAULT_KEY_SERDE_CLASS_CONFIG

        public static final java.lang.String DEFAULT_KEY_SERDE_CLASS_CONFIG
        default key.serde
        See Also:
        Constant Field Values
      • DEFAULT_VALUE_SERDE_CLASS_CONFIG

        public static final java.lang.String DEFAULT_VALUE_SERDE_CLASS_CONFIG
        default value.serde
        See Also:
        Constant Field Values
      • DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_CONFIG

        public static final java.lang.String DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_CONFIG
        default.timestamp.extractor
        See Also:
        Constant Field Values
      • MAX_TASK_IDLE_MS_CONFIG

        public static final java.lang.String MAX_TASK_IDLE_MS_CONFIG
        max.task.idle.ms
        See Also:
        Constant Field Values
      • MAX_WARMUP_REPLICAS_CONFIG

        public static final java.lang.String MAX_WARMUP_REPLICAS_CONFIG
        max.warmup.replicas
        See Also:
        Constant Field Values
      • METADATA_MAX_AGE_CONFIG

        public static final java.lang.String METADATA_MAX_AGE_CONFIG
        metadata.max.age.ms
        See Also:
        Constant Field Values
      • METRICS_NUM_SAMPLES_CONFIG

        public static final java.lang.String METRICS_NUM_SAMPLES_CONFIG
        metrics.num.samples
        See Also:
        Constant Field Values
      • METRICS_RECORDING_LEVEL_CONFIG

        public static final java.lang.String METRICS_RECORDING_LEVEL_CONFIG
        metrics.record.level
        See Also:
        Constant Field Values
      • METRIC_REPORTER_CLASSES_CONFIG

        public static final java.lang.String METRIC_REPORTER_CLASSES_CONFIG
        metric.reporters
        See Also:
        Constant Field Values
      • METRICS_SAMPLE_WINDOW_MS_CONFIG

        public static final java.lang.String METRICS_SAMPLE_WINDOW_MS_CONFIG
        metrics.sample.window.ms
        See Also:
        Constant Field Values
      • NUM_STANDBY_REPLICAS_CONFIG

        public static final java.lang.String NUM_STANDBY_REPLICAS_CONFIG
        num.standby.replicas
        See Also:
        Constant Field Values
      • NUM_STREAM_THREADS_CONFIG

        public static final java.lang.String NUM_STREAM_THREADS_CONFIG
        num.stream.threads
        See Also:
        Constant Field Values
      • POLL_MS_CONFIG

        public static final java.lang.String POLL_MS_CONFIG
        poll.ms
        See Also:
        Constant Field Values
      • PROBING_REBALANCE_INTERVAL_MS_CONFIG

        public static final java.lang.String PROBING_REBALANCE_INTERVAL_MS_CONFIG
        probing.rebalance.interval.ms
        See Also:
        Constant Field Values
      • PROCESSING_GUARANTEE_CONFIG

        public static final java.lang.String PROCESSING_GUARANTEE_CONFIG
        processing.guarantee
        See Also:
        Constant Field Values
      • RECEIVE_BUFFER_CONFIG

        public static final java.lang.String RECEIVE_BUFFER_CONFIG
        receive.buffer.bytes
        See Also:
        Constant Field Values
      • RECONNECT_BACKOFF_MS_CONFIG

        public static final java.lang.String RECONNECT_BACKOFF_MS_CONFIG
        reconnect.backoff.ms
        See Also:
        Constant Field Values
      • RECONNECT_BACKOFF_MAX_MS_CONFIG

        public static final java.lang.String RECONNECT_BACKOFF_MAX_MS_CONFIG
        reconnect.backoff.max
        See Also:
        Constant Field Values
      • REPLICATION_FACTOR_CONFIG

        public static final java.lang.String REPLICATION_FACTOR_CONFIG
        replication.factor
        See Also:
        Constant Field Values
      • REQUEST_TIMEOUT_MS_CONFIG

        public static final java.lang.String REQUEST_TIMEOUT_MS_CONFIG
        request.timeout.ms
        See Also:
        Constant Field Values
      • RETRIES_CONFIG

        public static final java.lang.String RETRIES_CONFIG
        retries
        See Also:
        Constant Field Values
      • RETRY_BACKOFF_MS_CONFIG

        public static final java.lang.String RETRY_BACKOFF_MS_CONFIG
        retry.backoff.ms
        See Also:
        Constant Field Values
      • ROCKSDB_CONFIG_SETTER_CLASS_CONFIG

        public static final java.lang.String ROCKSDB_CONFIG_SETTER_CLASS_CONFIG
        rocksdb.config.setter
        See Also:
        Constant Field Values
      • SECURITY_PROTOCOL_CONFIG

        public static final java.lang.String SECURITY_PROTOCOL_CONFIG
        security.protocol
        See Also:
        Constant Field Values
      • SEND_BUFFER_CONFIG

        public static final java.lang.String SEND_BUFFER_CONFIG
        send.buffer.bytes
        See Also:
        Constant Field Values
      • STATE_CLEANUP_DELAY_MS_CONFIG

        public static final java.lang.String STATE_CLEANUP_DELAY_MS_CONFIG
        state.cleanup.delay
        See Also:
        Constant Field Values
      • STATE_DIR_CONFIG

        public static final java.lang.String STATE_DIR_CONFIG
        state.dir
        See Also:
        Constant Field Values
      • TOPOLOGY_OPTIMIZATION

        public static final java.lang.String TOPOLOGY_OPTIMIZATION
        topology.optimization
        See Also:
        Constant Field Values
      • UPGRADE_FROM_CONFIG

        public static final java.lang.String UPGRADE_FROM_CONFIG
        upgrade.from
        See Also:
        Constant Field Values
      • WINDOW_STORE_CHANGE_LOG_ADDITIONAL_RETENTION_MS_CONFIG

        public static final java.lang.String WINDOW_STORE_CHANGE_LOG_ADDITIONAL_RETENTION_MS_CONFIG
        windowstore.changelog.additional.retention.ms
        See Also:
        Constant Field Values
      • PARTITION_GROUPER_CLASS_CONFIG

        @Deprecated
        public static final java.lang.String PARTITION_GROUPER_CLASS_CONFIG
        Deprecated.
        partition.grouper
        See Also:
        Constant Field Values
      • STREAMS_DEFAULT_STREAM_CONFIG

        public static final java.lang.String STREAMS_DEFAULT_STREAM_CONFIG
        streams.default.stream}
        See Also:
        Constant Field Values
      • APPLICATION_DIR_ACES_CONFIG

        public static final java.lang.String APPLICATION_DIR_ACES_CONFIG
        streams.appdir.permissions}
        See Also:
        Constant Field Values
    • Constructor Detail

      • StreamsConfig

        public StreamsConfig​(java.util.Map<?,​?> props)
        Create a new StreamsConfig using the given properties.
        Parameters:
        props - properties that specify Kafka Streams and internal consumer/producer configuration
      • StreamsConfig

        protected StreamsConfig​(java.util.Map<?,​?> props,
                                boolean doLog)
    • Method Detail

      • consumerPrefix

        public static java.lang.String consumerPrefix​(java.lang.String consumerProp)
        Prefix a property with CONSUMER_PREFIX. This is used to isolate consumer configs from other client configs.
        Parameters:
        consumerProp - the consumer property to be masked
        Returns:
        CONSUMER_PREFIX + consumerProp
      • mainConsumerPrefix

        public static java.lang.String mainConsumerPrefix​(java.lang.String consumerProp)
        Prefix a property with MAIN_CONSUMER_PREFIX. This is used to isolate main consumer configs from other client configs.
        Parameters:
        consumerProp - the consumer property to be masked
        Returns:
        MAIN_CONSUMER_PREFIX + consumerProp
      • restoreConsumerPrefix

        public static java.lang.String restoreConsumerPrefix​(java.lang.String consumerProp)
        Prefix a property with RESTORE_CONSUMER_PREFIX. This is used to isolate restore consumer configs from other client configs.
        Parameters:
        consumerProp - the consumer property to be masked
        Returns:
        RESTORE_CONSUMER_PREFIX + consumerProp
      • globalConsumerPrefix

        public static java.lang.String globalConsumerPrefix​(java.lang.String consumerProp)
        Prefix a property with GLOBAL_CONSUMER_PREFIX. This is used to isolate global consumer configs from other client configs.
        Parameters:
        consumerProp - the consumer property to be masked
        Returns:
        GLOBAL_CONSUMER_PREFIX + consumerProp
      • producerPrefix

        public static java.lang.String producerPrefix​(java.lang.String producerProp)
        Prefix a property with PRODUCER_PREFIX. This is used to isolate producer configs from other client configs.
        Parameters:
        producerProp - the producer property to be masked
        Returns:
        PRODUCER_PREFIX + producerProp
      • adminClientPrefix

        public static java.lang.String adminClientPrefix​(java.lang.String adminClientProp)
        Prefix a property with ADMIN_CLIENT_PREFIX. This is used to isolate admin configs from other client configs.
        Parameters:
        adminClientProp - the admin client property to be masked
        Returns:
        ADMIN_CLIENT_PREFIX + adminClientProp
      • topicPrefix

        public static java.lang.String topicPrefix​(java.lang.String topicProp)
        Prefix a property with TOPIC_PREFIX used to provide default topic configs to be applied when creating internal topics.
        Parameters:
        topicProp - the topic property to be masked
        Returns:
        TOPIC_PREFIX + topicProp
      • configDef

        public static org.apache.kafka.common.config.ConfigDef configDef()
        Return a copy of the config definition.
        Returns:
        a copy of the config definition
      • postProcessParsedConfig

        protected java.util.Map<java.lang.String,​java.lang.Object> postProcessParsedConfig​(java.util.Map<java.lang.String,​java.lang.Object> parsedValues)
        Overrides:
        postProcessParsedConfig in class org.apache.kafka.common.config.AbstractConfig
      • getConsumerConfigs

        @Deprecated
        public java.util.Map<java.lang.String,​java.lang.Object> getConsumerConfigs​(java.lang.String groupId,
                                                                                         java.lang.String clientId)
        Get the configs to the consumer. Properties using the prefix CONSUMER_PREFIX will be used in favor over their non-prefixed versions except in the case of ConsumerConfig.BOOTSTRAP_SERVERS_CONFIG where we always use the non-prefixed version as we only support reading/writing from/to the same Kafka Cluster.
        Parameters:
        groupId - consumer groupId
        clientId - clientId
        Returns:
        Map of the consumer configuration.
      • getMainConsumerConfigs

        public java.util.Map<java.lang.String,​java.lang.Object> getMainConsumerConfigs​(java.lang.String groupId,
                                                                                             java.lang.String clientId,
                                                                                             int threadIdx)
        Get the configs to the main consumer. Properties using the prefix MAIN_CONSUMER_PREFIX will be used in favor over the properties prefixed with CONSUMER_PREFIX and the non-prefixed versions (read the override precedence ordering in MAIN_CONSUMER_PREFIX except in the case of ConsumerConfig.BOOTSTRAP_SERVERS_CONFIG where we always use the non-prefixed version as we only support reading/writing from/to the same Kafka Cluster. If not specified by MAIN_CONSUMER_PREFIX, main consumer will share the general consumer configs prefixed by CONSUMER_PREFIX.
        Parameters:
        groupId - consumer groupId
        clientId - clientId
        threadIdx - stream thread index
        Returns:
        Map of the consumer configuration.
      • getRestoreConsumerConfigs

        public java.util.Map<java.lang.String,​java.lang.Object> getRestoreConsumerConfigs​(java.lang.String clientId)
        Get the configs for the restore-consumer. Properties using the prefix RESTORE_CONSUMER_PREFIX will be used in favor over the properties prefixed with CONSUMER_PREFIX and the non-prefixed versions (read the override precedence ordering in RESTORE_CONSUMER_PREFIX except in the case of ConsumerConfig.BOOTSTRAP_SERVERS_CONFIG where we always use the non-prefixed version as we only support reading/writing from/to the same Kafka Cluster. If not specified by RESTORE_CONSUMER_PREFIX, restore consumer will share the general consumer configs prefixed by CONSUMER_PREFIX.
        Parameters:
        clientId - clientId
        Returns:
        Map of the restore consumer configuration.
      • getGlobalConsumerConfigs

        public java.util.Map<java.lang.String,​java.lang.Object> getGlobalConsumerConfigs​(java.lang.String clientId)
        Get the configs for the global consumer. Properties using the prefix GLOBAL_CONSUMER_PREFIX will be used in favor over the properties prefixed with CONSUMER_PREFIX and the non-prefixed versions (read the override precedence ordering in GLOBAL_CONSUMER_PREFIX except in the case of ConsumerConfig.BOOTSTRAP_SERVERS_CONFIG where we always use the non-prefixed version as we only support reading/writing from/to the same Kafka Cluster. If not specified by GLOBAL_CONSUMER_PREFIX, global consumer will share the general consumer configs prefixed by CONSUMER_PREFIX.
        Parameters:
        clientId - clientId
        Returns:
        Map of the global consumer configuration.
      • getProducerConfigs

        public java.util.Map<java.lang.String,​java.lang.Object> getProducerConfigs​(java.lang.String clientId)
        Get the configs for the producer. Properties using the prefix PRODUCER_PREFIX will be used in favor over their non-prefixed versions except in the case of ProducerConfig.BOOTSTRAP_SERVERS_CONFIG where we always use the non-prefixed version as we only support reading/writing from/to the same Kafka Cluster.
        Parameters:
        clientId - clientId
        Returns:
        Map of the producer configuration.
      • getAdminConfigs

        public java.util.Map<java.lang.String,​java.lang.Object> getAdminConfigs​(java.lang.String clientId)
        Get the configs for the admin client.
        Parameters:
        clientId - clientId
        Returns:
        Map of the admin client configuration.
      • defaultKeySerde

        public org.apache.kafka.common.serialization.Serde defaultKeySerde()
        Return an configured instance of key Serde class.
        Returns:
        an configured instance of key Serde class
      • defaultValueSerde

        public org.apache.kafka.common.serialization.Serde defaultValueSerde()
        Return an configured instance of value Serde class.
        Returns:
        an configured instance of value Serde class
      • getStreamsInternalStreamFolder

        public java.lang.String getStreamsInternalStreamFolder()
      • getStreamsInternalStreamNotcompacted

        public java.lang.String getStreamsInternalStreamNotcompacted()
      • getStreamsInternalStreamCompacted

        public java.lang.String getStreamsInternalStreamCompacted()
      • getStreamsCliSideAssignmentInternalStream

        public java.lang.String getStreamsCliSideAssignmentInternalStream()
      • main

        public static void main​(java.lang.String[] args)