public class StreamsConfig extends AbstractConfig
KafkaStreams
instance.
Can also be used to configure the Kafka Streams internal KafkaConsumer
, KafkaProducer
and AdminClient
.
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.msKafka 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):
"enable.auto.commit"
(false) - Streams client will always disable/turn off auto committing"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"max.in.flight.requests.per.connection"
(5) - Producer will always have one in-flight request per connectionModifier and Type | Class and Description |
---|---|
static class |
StreamsConfig.InternalConfig |
Modifier and Type | Field and Description |
---|---|
static java.lang.String |
ADMIN_CLIENT_PREFIX
Prefix used to isolate
admin configs from other client configs. |
static java.lang.String |
APPLICATION_ID_CONFIG
application.id |
static java.lang.String |
APPLICATION_SERVER_CONFIG
user.endpoint |
static java.lang.String |
AT_LEAST_ONCE
Config value for parameter
"processing.guarantee" for at-least-once processing guarantees. |
static java.lang.String |
BOOTSTRAP_SERVERS_CONFIG
bootstrap.servers |
static java.lang.String |
BUFFERED_RECORDS_PER_PARTITION_CONFIG
buffered.records.per.partition |
static java.lang.String |
CACHE_MAX_BYTES_BUFFERING_CONFIG
cache.max.bytes.buffering |
static java.lang.String |
CLIENT_ID_CONFIG
client.id |
static java.lang.String |
COMMIT_INTERVAL_MS_CONFIG
commit.interval.ms |
static java.lang.String |
CONNECTIONS_MAX_IDLE_MS_CONFIG
connections.max.idle.ms |
static java.lang.String |
CONSUMER_PREFIX
Prefix used to isolate
consumer configs from other client configs. |
static java.lang.String |
DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG
default.deserialization.exception.handler |
static java.lang.String |
DEFAULT_KEY_SERDE_CLASS_CONFIG
default key.serde |
static java.lang.String |
DEFAULT_PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG
default.production.exception.handler |
static java.lang.String |
DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_CONFIG
default.timestamp.extractor |
static java.lang.String |
DEFAULT_VALUE_SERDE_CLASS_CONFIG
default value.serde |
static java.lang.String |
DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS
default.windowed.key.serde.inner |
static java.lang.String |
DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS
default.windowed.value.serde.inner |
static java.lang.String |
EXACTLY_ONCE
Config value for parameter
"processing.guarantee" for exactly-once processing guarantees. |
static java.lang.String |
GLOBAL_CONSUMER_PREFIX
Prefix used to override
consumer configs for the global consumer client from
the general consumer client configs. |
static java.lang.String |
MAIN_CONSUMER_PREFIX
Prefix used to override
consumer configs for the main consumer client from
the general consumer client configs. |
static java.lang.String |
MAX_TASK_IDLE_MS_CONFIG
max.task.idle.ms |
static java.lang.String |
METADATA_MAX_AGE_CONFIG
metadata.max.age.ms |
static java.lang.String |
METRIC_REPORTER_CLASSES_CONFIG
metric.reporters |
static java.lang.String |
METRICS_NUM_SAMPLES_CONFIG
metrics.num.samples |
static java.lang.String |
METRICS_RECORDING_LEVEL_CONFIG
metrics.record.level |
static java.lang.String |
METRICS_SAMPLE_WINDOW_MS_CONFIG
metrics.sample.window.ms |
static java.lang.String |
NO_OPTIMIZATION
Config value for parameter (@link #TOPOLOGY_OPTIMIZATION "topology.optimization" for disabling topology optimization
|
static java.lang.String |
NUM_STANDBY_REPLICAS_CONFIG
num.standby.replicas |
static java.lang.String |
NUM_STREAM_THREADS_CONFIG
num.stream.threads |
static java.lang.String |
OPTIMIZE
Config value for parameter (@link #TOPOLOGY_OPTIMIZATION "topology.optimization" for enabling topology optimization
|
static java.lang.String |
PARTITION_GROUPER_CLASS_CONFIG
partition.grouper |
static java.lang.String |
POLL_MS_CONFIG
poll.ms |
static java.lang.String |
PROCESSING_GUARANTEE_CONFIG
processing.guarantee |
static java.lang.String |
PRODUCER_PREFIX
Prefix used to isolate
producer configs from other client configs. |
static java.lang.String |
RECEIVE_BUFFER_CONFIG
receive.buffer.bytes |
static java.lang.String |
RECONNECT_BACKOFF_MAX_MS_CONFIG
reconnect.backoff.max |
static java.lang.String |
RECONNECT_BACKOFF_MS_CONFIG
reconnect.backoff.ms |
static java.lang.String |
REPLICATION_FACTOR_CONFIG
replication.factor |
static java.lang.String |
REQUEST_TIMEOUT_MS_CONFIG
request.timeout.ms |
static java.lang.String |
RESTORE_CONSUMER_PREFIX
Prefix used to override
consumer configs for the restore consumer client from
the general consumer client configs. |
static java.lang.String |
RETRIES_CONFIG
retries |
static java.lang.String |
RETRY_BACKOFF_MS_CONFIG
retry.backoff.ms |
static java.lang.String |
ROCKSDB_CONFIG_SETTER_CLASS_CONFIG
rocksdb.config.setter |
static java.lang.String |
SECURITY_PROTOCOL_CONFIG
security.protocol |
static java.lang.String |
SEND_BUFFER_CONFIG
send.buffer.bytes |
static java.lang.String |
STATE_CLEANUP_DELAY_MS_CONFIG
state.cleanup.delay |
static java.lang.String |
STATE_DIR_CONFIG
state.dir |
static java.lang.String |
TOPIC_PREFIX
Prefix used to provide default topic configs to be applied when creating internal topics.
|
static java.lang.String |
TOPOLOGY_OPTIMIZATION
topology.optimization |
static java.lang.String |
UPGRADE_FROM_0100
Config value for parameter
"upgrade.from" for upgrading an application from version 0.10.0.x . |
static java.lang.String |
UPGRADE_FROM_0101
Config value for parameter
"upgrade.from" for upgrading an application from version 0.10.1.x . |
static java.lang.String |
UPGRADE_FROM_0102
Config value for parameter
"upgrade.from" for upgrading an application from version 0.10.2.x . |
static java.lang.String |
UPGRADE_FROM_0110
Config value for parameter
"upgrade.from" for upgrading an application from version 0.11.0.x . |
static java.lang.String |
UPGRADE_FROM_10
Config value for parameter
"upgrade.from" for upgrading an application from version 1.0.x . |
static java.lang.String |
UPGRADE_FROM_11
Config value for parameter
"upgrade.from" for upgrading an application from version 1.1.x . |
static java.lang.String |
UPGRADE_FROM_CONFIG
upgrade.from |
static java.lang.String |
WINDOW_STORE_CHANGE_LOG_ADDITIONAL_RETENTION_MS_CONFIG
windowstore.changelog.additional.retention.ms |
Modifier | Constructor and Description |
---|---|
|
StreamsConfig(java.util.Map<?,?> props)
Create a new
StreamsConfig using the given properties. |
protected |
StreamsConfig(java.util.Map<?,?> props,
boolean doLog) |
Modifier and Type | Method and Description |
---|---|
static java.lang.String |
adminClientPrefix(java.lang.String adminClientProp)
Prefix a property with
ADMIN_CLIENT_PREFIX . |
static ConfigDef |
configDef()
Return a copy of the config definition.
|
static java.lang.String |
consumerPrefix(java.lang.String consumerProp)
Prefix a property with
CONSUMER_PREFIX . |
DeserializationExceptionHandler |
defaultDeserializationExceptionHandler() |
Serde |
defaultKeySerde()
Return an
configured instance of key Serde
class . |
ProductionExceptionHandler |
defaultProductionExceptionHandler() |
TimestampExtractor |
defaultTimestampExtractor() |
Serde |
defaultValueSerde()
Return an
configured instance of value
Serde class . |
java.util.Map<java.lang.String,java.lang.Object> |
getAdminConfigs(java.lang.String clientId)
Get the configs for the
admin client . |
java.util.Map<java.lang.String,java.lang.Object> |
getConsumerConfigs(java.lang.String groupId,
java.lang.String clientId)
Deprecated.
|
java.util.Map<java.lang.String,java.lang.Object> |
getGlobalConsumerConfigs(java.lang.String clientId)
Get the configs for the
global consumer . |
java.util.Map<java.lang.String,java.lang.Object> |
getMainConsumerConfigs(java.lang.String groupId,
java.lang.String clientId)
Get the configs to the
main consumer . |
java.util.Map<java.lang.String,java.lang.Object> |
getProducerConfigs(java.lang.String clientId)
Get the configs for the
producer . |
java.util.Map<java.lang.String,java.lang.Object> |
getRestoreConsumerConfigs(java.lang.String clientId)
Get the configs for the
restore-consumer . |
static java.lang.String |
globalConsumerPrefix(java.lang.String consumerProp)
Prefix a property with
GLOBAL_CONSUMER_PREFIX . |
static void |
main(java.lang.String[] args) |
static java.lang.String |
mainConsumerPrefix(java.lang.String consumerProp)
Prefix a property with
MAIN_CONSUMER_PREFIX . |
protected java.util.Map<java.lang.String,java.lang.Object> |
postProcessParsedConfig(java.util.Map<java.lang.String,java.lang.Object> parsedValues)
Called directly after user configs got parsed (and thus default values got set).
|
static java.lang.String |
producerPrefix(java.lang.String producerProp)
Prefix a property with
PRODUCER_PREFIX . |
static java.lang.String |
restoreConsumerPrefix(java.lang.String consumerProp)
Prefix a property with
RESTORE_CONSUMER_PREFIX . |
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. |
equals, get, getBoolean, getClass, getConfiguredInstance, getConfiguredInstances, getConfiguredInstances, getConfiguredInstances, getDouble, getInt, getList, getLong, getPassword, getShort, getString, hashCode, ignore, logUnused, originals, originalsStrings, originalsWithPrefix, originalsWithPrefix, typeOf, unused, values, valuesWithPrefixAllOrNothing, valuesWithPrefixOverride
public static final java.lang.String TOPIC_PREFIX
TopicConfig
.
It is recommended to use topicPrefix(String)
.public static final java.lang.String CONSUMER_PREFIX
consumer
configs from other client configs.
It is recommended to use consumerPrefix(String)
to add this prefix to consumer
properties
.public static final java.lang.String MAIN_CONSUMER_PREFIX
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]public static final java.lang.String RESTORE_CONSUMER_PREFIX
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]public static final java.lang.String GLOBAL_CONSUMER_PREFIX
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]public static final java.lang.String PRODUCER_PREFIX
producer
configs from other client configs.
It is recommended to use producerPrefix(String)
to add this prefix to producer
properties
.public static final java.lang.String ADMIN_CLIENT_PREFIX
admin
configs from other client configs.
It is recommended to use adminClientPrefix(String)
to add this prefix to producer
properties
.public static final java.lang.String NO_OPTIMIZATION
public static final java.lang.String OPTIMIZE
public static final java.lang.String UPGRADE_FROM_0100
"upgrade.from"
for upgrading an application from version 0.10.0.x
.public static final java.lang.String UPGRADE_FROM_0101
"upgrade.from"
for upgrading an application from version 0.10.1.x
.public static final java.lang.String UPGRADE_FROM_0102
"upgrade.from"
for upgrading an application from version 0.10.2.x
.public static final java.lang.String UPGRADE_FROM_0110
"upgrade.from"
for upgrading an application from version 0.11.0.x
.public static final java.lang.String UPGRADE_FROM_10
"upgrade.from"
for upgrading an application from version 1.0.x
.public static final java.lang.String UPGRADE_FROM_11
"upgrade.from"
for upgrading an application from version 1.1.x
.public static final java.lang.String AT_LEAST_ONCE
"processing.guarantee"
for at-least-once processing guarantees.public static final java.lang.String EXACTLY_ONCE
"processing.guarantee"
for exactly-once processing guarantees.public static final java.lang.String APPLICATION_ID_CONFIG
application.id
public static final java.lang.String APPLICATION_SERVER_CONFIG
user.endpoint
public static final java.lang.String BOOTSTRAP_SERVERS_CONFIG
bootstrap.servers
public static final java.lang.String BUFFERED_RECORDS_PER_PARTITION_CONFIG
buffered.records.per.partition
public static final java.lang.String CACHE_MAX_BYTES_BUFFERING_CONFIG
cache.max.bytes.buffering
public static final java.lang.String CLIENT_ID_CONFIG
client.id
public static final java.lang.String COMMIT_INTERVAL_MS_CONFIG
commit.interval.ms
public static final java.lang.String MAX_TASK_IDLE_MS_CONFIG
max.task.idle.ms
public static final java.lang.String CONNECTIONS_MAX_IDLE_MS_CONFIG
connections.max.idle.ms
public static final java.lang.String DEFAULT_DESERIALIZATION_EXCEPTION_HANDLER_CLASS_CONFIG
default.deserialization.exception.handler
public static final java.lang.String DEFAULT_PRODUCTION_EXCEPTION_HANDLER_CLASS_CONFIG
default.production.exception.handler
public static final java.lang.String DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS
default.windowed.key.serde.inner
public static final java.lang.String DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS
default.windowed.value.serde.inner
public static final java.lang.String DEFAULT_KEY_SERDE_CLASS_CONFIG
default key.serde
public static final java.lang.String DEFAULT_VALUE_SERDE_CLASS_CONFIG
default value.serde
public static final java.lang.String DEFAULT_TIMESTAMP_EXTRACTOR_CLASS_CONFIG
default.timestamp.extractor
public static final java.lang.String METADATA_MAX_AGE_CONFIG
metadata.max.age.ms
public static final java.lang.String METRICS_NUM_SAMPLES_CONFIG
metrics.num.samples
public static final java.lang.String METRICS_RECORDING_LEVEL_CONFIG
metrics.record.level
public static final java.lang.String METRIC_REPORTER_CLASSES_CONFIG
metric.reporters
public static final java.lang.String METRICS_SAMPLE_WINDOW_MS_CONFIG
metrics.sample.window.ms
public static final java.lang.String NUM_STANDBY_REPLICAS_CONFIG
num.standby.replicas
public static final java.lang.String NUM_STREAM_THREADS_CONFIG
num.stream.threads
public static final java.lang.String PARTITION_GROUPER_CLASS_CONFIG
partition.grouper
public static final java.lang.String POLL_MS_CONFIG
poll.ms
public static final java.lang.String PROCESSING_GUARANTEE_CONFIG
processing.guarantee
public static final java.lang.String RECEIVE_BUFFER_CONFIG
receive.buffer.bytes
public static final java.lang.String RECONNECT_BACKOFF_MS_CONFIG
reconnect.backoff.ms
public static final java.lang.String RECONNECT_BACKOFF_MAX_MS_CONFIG
reconnect.backoff.max
public static final java.lang.String REPLICATION_FACTOR_CONFIG
replication.factor
public static final java.lang.String REQUEST_TIMEOUT_MS_CONFIG
request.timeout.ms
public static final java.lang.String RETRIES_CONFIG
retries
public static final java.lang.String RETRY_BACKOFF_MS_CONFIG
retry.backoff.ms
public static final java.lang.String ROCKSDB_CONFIG_SETTER_CLASS_CONFIG
rocksdb.config.setter
public static final java.lang.String SECURITY_PROTOCOL_CONFIG
security.protocol
public static final java.lang.String SEND_BUFFER_CONFIG
send.buffer.bytes
public static final java.lang.String STATE_CLEANUP_DELAY_MS_CONFIG
state.cleanup.delay
public static final java.lang.String STATE_DIR_CONFIG
state.dir
public static final java.lang.String TOPOLOGY_OPTIMIZATION
topology.optimization
public static final java.lang.String UPGRADE_FROM_CONFIG
upgrade.from
public static final java.lang.String WINDOW_STORE_CHANGE_LOG_ADDITIONAL_RETENTION_MS_CONFIG
windowstore.changelog.additional.retention.ms
public StreamsConfig(java.util.Map<?,?> props)
StreamsConfig
using the given properties.props
- properties that specify Kafka Streams and internal consumer/producer configurationprotected StreamsConfig(java.util.Map<?,?> props, boolean doLog)
public static java.lang.String consumerPrefix(java.lang.String consumerProp)
CONSUMER_PREFIX
. This is used to isolate consumer configs
from other client configs.consumerProp
- the consumer property to be maskedCONSUMER_PREFIX
+ consumerProp
public static java.lang.String mainConsumerPrefix(java.lang.String consumerProp)
MAIN_CONSUMER_PREFIX
. This is used to isolate main consumer configs
from other client configs.consumerProp
- the consumer property to be maskedMAIN_CONSUMER_PREFIX
+ consumerProp
public static java.lang.String restoreConsumerPrefix(java.lang.String consumerProp)
RESTORE_CONSUMER_PREFIX
. This is used to isolate restore consumer configs
from other client configs.consumerProp
- the consumer property to be maskedRESTORE_CONSUMER_PREFIX
+ consumerProp
public static java.lang.String globalConsumerPrefix(java.lang.String consumerProp)
GLOBAL_CONSUMER_PREFIX
. This is used to isolate global consumer configs
from other client configs.consumerProp
- the consumer property to be maskedGLOBAL_CONSUMER_PREFIX
+ consumerProp
public static java.lang.String producerPrefix(java.lang.String producerProp)
PRODUCER_PREFIX
. This is used to isolate producer configs
from other client configs.producerProp
- the producer property to be maskedproducerProp
public static java.lang.String adminClientPrefix(java.lang.String adminClientProp)
ADMIN_CLIENT_PREFIX
. This is used to isolate admin configs
from other client configs.adminClientProp
- the admin client property to be maskedadminClientProp
public static java.lang.String topicPrefix(java.lang.String topicProp)
TOPIC_PREFIX
used to provide default topic configs to be applied when creating internal topics.topicProp
- the topic property to be maskedtopicProp
public static ConfigDef configDef()
protected java.util.Map<java.lang.String,java.lang.Object> postProcessParsedConfig(java.util.Map<java.lang.String,java.lang.Object> parsedValues)
AbstractConfig
postProcessParsedConfig
in class AbstractConfig
parsedValues
- unmodifiable map of current configuration@Deprecated public java.util.Map<java.lang.String,java.lang.Object> getConsumerConfigs(java.lang.String groupId, java.lang.String clientId)
getMainConsumerConfigs(String, String)
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.groupId
- consumer groupIdclientId
- clientIdpublic java.util.Map<java.lang.String,java.lang.Object> getMainConsumerConfigs(java.lang.String groupId, java.lang.String clientId)
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
.groupId
- consumer groupIdclientId
- clientIdpublic java.util.Map<java.lang.String,java.lang.Object> getRestoreConsumerConfigs(java.lang.String clientId)
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
.clientId
- clientIdpublic java.util.Map<java.lang.String,java.lang.Object> getGlobalConsumerConfigs(java.lang.String clientId)
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
.clientId
- clientIdpublic java.util.Map<java.lang.String,java.lang.Object> getProducerConfigs(java.lang.String clientId)
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.clientId
- clientIdpublic java.util.Map<java.lang.String,java.lang.Object> getAdminConfigs(java.lang.String clientId)
admin client
.clientId
- clientIdpublic Serde defaultKeySerde()
configured
instance of key Serde
class
.public Serde defaultValueSerde()
configured
instance of value
Serde class
.public TimestampExtractor defaultTimestampExtractor()
public DeserializationExceptionHandler defaultDeserializationExceptionHandler()
public ProductionExceptionHandler defaultProductionExceptionHandler()
public static void main(java.lang.String[] args)