Package org.apache.kafka.streams
Interface KafkaClientSupplier
public interface KafkaClientSupplier
KafkaClientSupplier can be used to provide custom Kafka clients to a KafkaStreams instance.- See Also:
- 
Method SummaryModifier and TypeMethodDescriptiondefault AdminCreate anAdminwhich is used for internal topic management.Consumer<byte[], byte[]> getConsumer(Map<String, Object> config) Create aConsumerwhich is used to read records of source topics.Consumer<byte[], byte[]> getGlobalConsumer(Map<String, Object> config) Create aConsumerwhich is used to consume records forGlobalKTable.Producer<byte[], byte[]> getProducer(Map<String, Object> config) Create aProducerwhich is used to write records to sink topics.Consumer<byte[], byte[]> getRestoreConsumer(Map<String, Object> config) Create aConsumerwhich is used to read records to restoreStateStores.
- 
Method Details- 
getAdminCreate anAdminwhich is used for internal topic management.- Parameters:
- config- Supplied by the- Propertiesgiven to the- KafkaStreams
- Returns:
- an instance of Admin
 
- 
getProducerCreate aProducerwhich is used to write records to sink topics.- Parameters:
- config-- producer configwhich is supplied by the- Propertiesgiven to the- KafkaStreamsinstance
- Returns:
- an instance of Kafka producer
 
- 
getConsumerCreate aConsumerwhich is used to read records of source topics.- Parameters:
- config-- consumer configwhich is supplied by the- Propertiesgiven to the- KafkaStreamsinstance
- Returns:
- an instance of Kafka consumer
 
- 
getRestoreConsumerCreate aConsumerwhich is used to read records to restoreStateStores.- Parameters:
- config-- restore consumer configwhich is supplied by the- Propertiesgiven to the- KafkaStreams
- Returns:
- an instance of Kafka consumer
 
- 
getGlobalConsumerCreate aConsumerwhich is used to consume records forGlobalKTable.- Parameters:
- config-- global consumer configwhich is supplied by the- Propertiesgiven to the- KafkaStreams
- Returns:
- an instance of Kafka consumer
 
 
-