Class ProducerConfig
- java.lang.Object
-
- org.apache.kafka.common.config.AbstractConfig
-
- org.apache.kafka.clients.producer.ProducerConfig
-
public class ProducerConfig extends AbstractConfig
Configuration for the Kafka Producer. Documentation for these configurations can be found in the Kafka documentation
-
-
Field Summary
-
Fields inherited from class org.apache.kafka.common.config.AbstractConfig
CONFIG_PROVIDERS_CONFIG
-
-
Constructor Summary
Constructors Constructor Description ProducerConfig(Map<String,Object> props)
ProducerConfig(Properties props)
-
Method Summary
All Methods Static Methods Concrete Methods Modifier and Type Method Description static ConfigDef
configDef()
static Set<String>
configNames()
static void
main(String[] args)
-
Methods inherited from class org.apache.kafka.common.config.AbstractConfig
documentationOf, equals, getBoolean, getClass, getConfiguredInstance, getConfiguredInstance, getConfiguredInstances, getConfiguredInstances, getConfiguredInstances, getDouble, getInt, getList, getLong, getPassword, getShort, getString, hashCode, ignore, logUnused, nonInternalValues, originals, originals, originalsStrings, originalsWithPrefix, originalsWithPrefix, typeOf, unused, values, valuesWithPrefixAllOrNothing, valuesWithPrefixOverride
-
-
-
-
Field Detail
-
BOOTSTRAP_SERVERS_CONFIG
public static final String BOOTSTRAP_SERVERS_CONFIG
bootstrap.servers
- See Also:
- Constant Field Values
-
CLIENT_DNS_LOOKUP_CONFIG
public static final String CLIENT_DNS_LOOKUP_CONFIG
client.dns.lookup
- See Also:
- Constant Field Values
-
METADATA_MAX_AGE_CONFIG
public static final String METADATA_MAX_AGE_CONFIG
metadata.max.age.ms
- See Also:
- Constant Field Values
-
METADATA_MAX_IDLE_CONFIG
public static final String METADATA_MAX_IDLE_CONFIG
metadata.max.idle.ms
- See Also:
- Constant Field Values
-
BATCH_SIZE_CONFIG
public static final String BATCH_SIZE_CONFIG
batch.size
- See Also:
- Constant Field Values
-
PARTITIONER_ADPATIVE_PARTITIONING_ENABLE_CONFIG
public static final String PARTITIONER_ADPATIVE_PARTITIONING_ENABLE_CONFIG
partitioner.adaptive.partitioning.enable
- See Also:
- Constant Field Values
-
PARTITIONER_AVAILABILITY_TIMEOUT_MS_CONFIG
public static final String PARTITIONER_AVAILABILITY_TIMEOUT_MS_CONFIG
partitioner.availability.timeout.ms
- See Also:
- Constant Field Values
-
PARTITIONER_IGNORE_KEYS_CONFIG
public static final String PARTITIONER_IGNORE_KEYS_CONFIG
partitioner.ignore.keys
- See Also:
- Constant Field Values
-
ACKS_CONFIG
public static final String ACKS_CONFIG
acks
- See Also:
- Constant Field Values
-
LINGER_MS_CONFIG
public static final String LINGER_MS_CONFIG
linger.ms
- See Also:
- Constant Field Values
-
REQUEST_TIMEOUT_MS_CONFIG
public static final String REQUEST_TIMEOUT_MS_CONFIG
request.timeout.ms
- See Also:
- Constant Field Values
-
DELIVERY_TIMEOUT_MS_CONFIG
public static final String DELIVERY_TIMEOUT_MS_CONFIG
delivery.timeout.ms
- See Also:
- Constant Field Values
-
CLIENT_ID_CONFIG
public static final String CLIENT_ID_CONFIG
client.id
- See Also:
- Constant Field Values
-
SEND_BUFFER_CONFIG
public static final String SEND_BUFFER_CONFIG
send.buffer.bytes
- See Also:
- Constant Field Values
-
RECEIVE_BUFFER_CONFIG
public static final String RECEIVE_BUFFER_CONFIG
receive.buffer.bytes
- See Also:
- Constant Field Values
-
MAX_REQUEST_SIZE_CONFIG
public static final String MAX_REQUEST_SIZE_CONFIG
max.request.size
- See Also:
- Constant Field Values
-
RECONNECT_BACKOFF_MS_CONFIG
public static final String RECONNECT_BACKOFF_MS_CONFIG
reconnect.backoff.ms
- See Also:
- Constant Field Values
-
RECONNECT_BACKOFF_MAX_MS_CONFIG
public static final String RECONNECT_BACKOFF_MAX_MS_CONFIG
reconnect.backoff.max.ms
- See Also:
- Constant Field Values
-
MAX_BLOCK_MS_CONFIG
public static final String MAX_BLOCK_MS_CONFIG
max.block.ms
- See Also:
- Constant Field Values
-
BUFFER_MEMORY_CONFIG
public static final String BUFFER_MEMORY_CONFIG
buffer.memory
- See Also:
- Constant Field Values
-
RETRY_BACKOFF_MS_CONFIG
public static final String RETRY_BACKOFF_MS_CONFIG
retry.backoff.ms
- See Also:
- Constant Field Values
-
COMPRESSION_TYPE_CONFIG
public static final String COMPRESSION_TYPE_CONFIG
compression.type
- See Also:
- Constant Field Values
-
METRICS_SAMPLE_WINDOW_MS_CONFIG
public static final String METRICS_SAMPLE_WINDOW_MS_CONFIG
metrics.sample.window.ms
- See Also:
- Constant Field Values
-
METRICS_NUM_SAMPLES_CONFIG
public static final String METRICS_NUM_SAMPLES_CONFIG
metrics.num.samples
- See Also:
- Constant Field Values
-
METRICS_RECORDING_LEVEL_CONFIG
public static final String METRICS_RECORDING_LEVEL_CONFIG
metrics.recording.level
- See Also:
- Constant Field Values
-
METRIC_REPORTER_CLASSES_CONFIG
public static final String METRIC_REPORTER_CLASSES_CONFIG
metric.reporters
- See Also:
- Constant Field Values
-
AUTO_INCLUDE_JMX_REPORTER_CONFIG
@Deprecated public static final String AUTO_INCLUDE_JMX_REPORTER_CONFIG
Deprecated.auto.include.jmx.reporter
- See Also:
- Constant Field Values
-
MAX_IN_FLIGHT_REQUESTS_PER_CONNECTION
public static final String MAX_IN_FLIGHT_REQUESTS_PER_CONNECTION
max.in.flight.requests.per.connection
- See Also:
- Constant Field Values
-
RETRIES_CONFIG
public static final String RETRIES_CONFIG
retries
- See Also:
- Constant Field Values
-
KEY_SERIALIZER_CLASS_CONFIG
public static final String KEY_SERIALIZER_CLASS_CONFIG
key.serializer
- See Also:
- Constant Field Values
-
KEY_SERIALIZER_CLASS_DOC
public static final String KEY_SERIALIZER_CLASS_DOC
- See Also:
- Constant Field Values
-
VALUE_SERIALIZER_CLASS_CONFIG
public static final String VALUE_SERIALIZER_CLASS_CONFIG
value.serializer
- See Also:
- Constant Field Values
-
VALUE_SERIALIZER_CLASS_DOC
public static final String VALUE_SERIALIZER_CLASS_DOC
- See Also:
- Constant Field Values
-
SOCKET_CONNECTION_SETUP_TIMEOUT_MS_CONFIG
public static final String SOCKET_CONNECTION_SETUP_TIMEOUT_MS_CONFIG
socket.connection.setup.timeout.ms
- See Also:
- Constant Field Values
-
SOCKET_CONNECTION_SETUP_TIMEOUT_MAX_MS_CONFIG
public static final String SOCKET_CONNECTION_SETUP_TIMEOUT_MAX_MS_CONFIG
socket.connection.setup.timeout.max.ms
- See Also:
- Constant Field Values
-
CONNECTIONS_MAX_IDLE_MS_CONFIG
public static final String CONNECTIONS_MAX_IDLE_MS_CONFIG
connections.max.idle.ms
- See Also:
- Constant Field Values
-
PARTITIONER_CLASS_CONFIG
public static final String PARTITIONER_CLASS_CONFIG
partitioner.class
- See Also:
- Constant Field Values
-
INTERCEPTOR_CLASSES_CONFIG
public static final String INTERCEPTOR_CLASSES_CONFIG
interceptor.classes
- See Also:
- Constant Field Values
-
INTERCEPTOR_CLASSES_DOC
public static final String INTERCEPTOR_CLASSES_DOC
- See Also:
- Constant Field Values
-
ENABLE_IDEMPOTENCE_CONFIG
public static final String ENABLE_IDEMPOTENCE_CONFIG
enable.idempotence
- See Also:
- Constant Field Values
-
ENABLE_IDEMPOTENCE_DOC
public static final String ENABLE_IDEMPOTENCE_DOC
- See Also:
- Constant Field Values
-
TRANSACTION_TIMEOUT_CONFIG
public static final String TRANSACTION_TIMEOUT_CONFIG
transaction.timeout.ms
- See Also:
- Constant Field Values
-
TRANSACTION_TIMEOUT_DOC
public static final String TRANSACTION_TIMEOUT_DOC
- See Also:
- Constant Field Values
-
TRANSACTIONAL_ID_CONFIG
public static final String TRANSACTIONAL_ID_CONFIG
transactional.id
- See Also:
- Constant Field Values
-
TRANSACTIONAL_ID_DOC
public static final String TRANSACTIONAL_ID_DOC
- See Also:
- Constant Field Values
-
USE_BROKERS_CONFIG
public static final String USE_BROKERS_CONFIG
use.brokers
- See Also:
- Constant Field Values
-
SECURITY_PROVIDERS_CONFIG
public static final String SECURITY_PROVIDERS_CONFIG
security.providers
- See Also:
- Constant Field Values
-
STREAMS_RPC_TIMEOUT_MS_CONFIG
public static final String STREAMS_RPC_TIMEOUT_MS_CONFIG
streams.rpc.timeout.ms
- See Also:
- Constant Field Values
-
STREAMS_HARDMOUNT_CONFIG
public static final String STREAMS_HARDMOUNT_CONFIG
fs.mapr.hardmount
- See Also:
- Constant Field Values
-
STREAMS_BUFFER_TIME_CONFIG
public static final String STREAMS_BUFFER_TIME_CONFIG
streams.buffer.max.time.ms
- See Also:
- Constant Field Values
-
STREAMS_PARALLEL_FLUSHERS_PER_PARTITION_CONFIG
public static final String STREAMS_PARALLEL_FLUSHERS_PER_PARTITION_CONFIG
streams.parallel.flushers.per.partition
- See Also:
- Constant Field Values
-
STREAMS_PARTITIONER_CLASS_CONFIG
public static final String STREAMS_PARTITIONER_CLASS_CONFIG
streams.partitioner.class
- See Also:
- Constant Field Values
-
STREAMS_PRODUCER_DEFAULT_STREAM_CONFIG
public static final String STREAMS_PRODUCER_DEFAULT_STREAM_CONFIG
streams.producer.default.stream
- See Also:
- Constant Field Values
-
METRICS_ENABLED_CONFIG
public static final String METRICS_ENABLED_CONFIG
metrics.enabled
- See Also:
- Constant Field Values
-
-
Constructor Detail
-
ProducerConfig
public ProducerConfig(Properties props)
-
-