Index

A B C D E F G H I J K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Serialized Form

A

add(ConfigEntry) - Method in class com.bakdata.kafka.admin.ConfigClient
Add a config for a Kafka resource.
addGlobalStore(StoreBuilder<?>, String, ConsumedX<KIn, VIn>, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
addGlobalStore(StoreBuilder<?>, String, Consumed<KIn, VIn>, ProcessorSupplier<KIn, VIn, Void, Void>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
addStateStore(StoreBuilder<?>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
admin() - Method in class com.bakdata.kafka.admin.AdminClientX
Get the underlying Admin client.
admin() - Method in class com.bakdata.kafka.KafkaTestClient
Create a new AdminClientX for the cluster
AdminClientX - Class in com.bakdata.kafka.admin
Provide methods for common operations when performing administrative actions on a Kafka cluster
aggregate(Initializer<VOut>) - Method in interface com.bakdata.kafka.streams.kstream.CogroupedKStreamX
 
aggregate(Initializer<VOut>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedCogroupedKStreamX
 
aggregate(Initializer<VOut>, MaterializedX<K, VOut, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.CogroupedKStreamX
 
aggregate(Initializer<VOut>, MaterializedX<K, VOut, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedCogroupedKStreamX
 
aggregate(Initializer<VOut>, Materialized<K, VOut, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.CogroupedKStreamX
 
aggregate(Initializer<VOut>, Materialized<K, VOut, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedCogroupedKStreamX
 
aggregate(Initializer<VOut>, Merger<? super K, VOut>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedCogroupedKStreamX
 
aggregate(Initializer<VOut>, Merger<? super K, VOut>, MaterializedX<K, VOut, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedCogroupedKStreamX
 
aggregate(Initializer<VOut>, Merger<? super K, VOut>, Materialized<K, VOut, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedCogroupedKStreamX
 
aggregate(Initializer<VOut>, Merger<? super K, VOut>, Named) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedCogroupedKStreamX
 
aggregate(Initializer<VOut>, Merger<? super K, VOut>, Named, MaterializedX<K, VOut, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedCogroupedKStreamX
 
aggregate(Initializer<VOut>, Merger<? super K, VOut>, Named, Materialized<K, VOut, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedCogroupedKStreamX
 
aggregate(Initializer<VOut>, Named) - Method in interface com.bakdata.kafka.streams.kstream.CogroupedKStreamX
 
aggregate(Initializer<VOut>, Named) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedCogroupedKStreamX
 
aggregate(Initializer<VOut>, Named, MaterializedX<K, VOut, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.CogroupedKStreamX
 
aggregate(Initializer<VOut>, Named, MaterializedX<K, VOut, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedCogroupedKStreamX
 
aggregate(Initializer<VOut>, Named, Materialized<K, VOut, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.CogroupedKStreamX
 
aggregate(Initializer<VOut>, Named, Materialized<K, VOut, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedCogroupedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, MaterializedX<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, MaterializedX<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named, MaterializedX<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Merger<? super K, VR>, Named, Materialized<K, VR, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, MaterializedX<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
aggregate(Initializer<VR>, Aggregator<? super K, ? super V, VR>, Named, Materialized<K, VR, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
app(App<?, ?>) - Method in class com.bakdata.kafka.KafkaPropertiesFactory.KafkaPropertiesFactoryBuilder
 
App<T,C> - Interface in com.bakdata.kafka
Kafka application that defines necessary configurations
AppConfiguration<T> - Class in com.bakdata.kafka
Configuration for setting up an app
AppConfiguration(T, Map<String, Object>) - Constructor for class com.bakdata.kafka.AppConfiguration
 
as(String) - Static method in class com.bakdata.kafka.streams.kstream.BranchedX
 
as(String) - Static method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
as(String) - Static method in class com.bakdata.kafka.streams.kstream.GroupedX
 
as(String) - Static method in class com.bakdata.kafka.streams.kstream.JoinedX
 
as(String) - Static method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
as(String) - Static method in class com.bakdata.kafka.streams.kstream.ProducedX
 
as(String) - Static method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
as(String) - Static method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
as(DslStoreSuppliers) - Static method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
as(KeyValueBytesStoreSupplier) - Static method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
as(SessionBytesStoreSupplier) - Static method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
as(WindowBytesStoreSupplier) - Static method in class com.bakdata.kafka.streams.kstream.MaterializedX
 

B

baseConfig(Map<String, Object>) - Method in class com.bakdata.kafka.KafkaPropertiesFactory.KafkaPropertiesFactoryBuilder
 
branch(Predicate<? super K, ? super V>) - Method in interface com.bakdata.kafka.streams.kstream.BranchedKStreamX
 
branch(Predicate<? super K, ? super V>, BranchedX<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.BranchedKStreamX
 
branch(Predicate<? super K, ? super V>, Branched<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.BranchedKStreamX
 
BranchedKStreamX<K,V> - Interface in com.bakdata.kafka.streams.kstream
Extends the BranchedKStream interface by adding methods to simplify Serde configuration, error handling, and topic access
BranchedX<K,V> - Class in com.bakdata.kafka.streams.kstream
Extends the Branched interface by adding methods to simplify Serde configuration, error handling, and topic access
build() - Method in class com.bakdata.kafka.admin.TopicSettings.TopicSettingsBuilder
 
build() - Method in class com.bakdata.kafka.KafkaPropertiesFactory.KafkaPropertiesFactoryBuilder
 
build() - Method in class com.bakdata.kafka.producer.ProducerExecutionOptions.ProducerExecutionOptionsBuilder
 
build() - Method in class com.bakdata.kafka.producer.ProducerTopicConfig.ProducerTopicConfigBuilder
 
build() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Returns the Topology that represents the specified processing logic.
build() - Method in class com.bakdata.kafka.streams.RunningStreams.RunningStreamsBuilder
 
build() - Method in class com.bakdata.kafka.streams.StreamsExecutionOptions.StreamsExecutionOptionsBuilder
 
build() - Method in class com.bakdata.kafka.streams.StreamsTopicConfig.StreamsTopicConfigBuilder
 
builder() - Static method in class com.bakdata.kafka.admin.TopicSettings
 
builder() - Static method in class com.bakdata.kafka.KafkaPropertiesFactory
 
builder() - Static method in class com.bakdata.kafka.producer.ProducerExecutionOptions
 
builder() - Static method in class com.bakdata.kafka.producer.ProducerTopicConfig
 
builder() - Static method in class com.bakdata.kafka.streams.RunningStreams
 
builder() - Static method in class com.bakdata.kafka.streams.StreamsExecutionOptions
 
builder() - Static method in class com.bakdata.kafka.streams.StreamsTopicConfig
 
buildRunnable(ProducerBuilder) - Method in interface com.bakdata.kafka.producer.ProducerApp
Create a runnable that produces Kafka messages
buildTopology(StreamsBuilderX) - Method in interface com.bakdata.kafka.streams.StreamsApp
Build the Kafka Streams Topology to be run by the app.

C

clean() - Method in interface com.bakdata.kafka.CleanUpRunner
Clean all resources associated with an application
clean() - Method in class com.bakdata.kafka.KafkaApplication
Clean all resources associated with this application
clean() - Method in class com.bakdata.kafka.producer.KafkaProducerApplication
Delete all output topics associated with the Kafka Producer application.
clean() - Method in class com.bakdata.kafka.producer.ProducerCleanUpRunner
Delete all output topics
clean() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
Reset the Kafka Streams application.
clean() - Method in class com.bakdata.kafka.streams.StreamsCleanUpRunner
Clean up your Streams app by resetting the app and deleting the output topics and consumer group.
clean(KafkaApplication<?, ?, ?, ?, ?, ?, ?, ?>) - Method in class com.bakdata.kafka.TestApplicationRunner
Clean the application.
clean(KafkaApplication<?, ?, ?, ?, ?, ?, ?, ?>, String...) - Method in class com.bakdata.kafka.TestApplicationRunner
Clean the application with the given arguments.
CleanableApp(ExecutableApp<?, ?, ?>, CR, Consumer<KafkaApplication.Stoppable>) - Constructor for class com.bakdata.kafka.KafkaApplication.CleanableApp
 
CleanUpException - Exception in com.bakdata.kafka
Exception thrown if running clean up was unsuccessful
CleanUpException(String) - Constructor for exception com.bakdata.kafka.CleanUpException
 
CleanUpException(String, Throwable) - Constructor for exception com.bakdata.kafka.CleanUpException
 
CleanUpRunner - Interface in com.bakdata.kafka
Cleans all resources associated with an application
close() - Method in class com.bakdata.kafka.admin.AdminClientX
 
close() - Method in interface com.bakdata.kafka.App
 
close() - Method in interface com.bakdata.kafka.CleanUpRunner
 
close() - Method in interface com.bakdata.kafka.ConfiguredApp
 
close() - Method in interface com.bakdata.kafka.ExecutableApp
 
close() - Method in interface com.bakdata.kafka.HasTopicHooks.TopicHook
 
close() - Method in class com.bakdata.kafka.KafkaApplication.CleanableApp
 
close() - Method in class com.bakdata.kafka.KafkaApplication
 
close() - Method in class com.bakdata.kafka.KafkaApplication.RunnableApp
 
close() - Method in class com.bakdata.kafka.producer.ConfiguredProducerApp
 
close() - Method in class com.bakdata.kafka.producer.ExecutableProducerApp
 
close() - Method in class com.bakdata.kafka.producer.ProducerCleanUpConfiguration
 
close() - Method in class com.bakdata.kafka.producer.ProducerCleanUpRunner
 
close() - Method in interface com.bakdata.kafka.producer.ProducerRunnable
 
close() - Method in class com.bakdata.kafka.producer.ProducerRunner
 
close() - Method in interface com.bakdata.kafka.Runner
 
close() - Method in class com.bakdata.kafka.streams.ConfiguredStreamsApp
 
close() - Method in class com.bakdata.kafka.streams.ExecutableStreamsApp
 
close() - Method in class com.bakdata.kafka.streams.StreamsCleanUpConfiguration
 
close() - Method in class com.bakdata.kafka.streams.StreamsCleanUpRunner
 
close() - Method in class com.bakdata.kafka.streams.StreamsRunner
 
closeTimeout(Duration) - Method in class com.bakdata.kafka.streams.StreamsExecutionOptions.StreamsExecutionOptionsBuilder
Defines KafkaStreams.CloseOptions.timeout(Duration) when calling KafkaStreams.close(CloseOptions)
cogroup(Aggregator<? super K, ? super V, VOut>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
cogroup(KGroupedStream<K, VIn>, Aggregator<? super K, ? super VIn, VOut>) - Method in interface com.bakdata.kafka.streams.kstream.CogroupedKStreamX
 
CogroupedKStreamX<K,VOut> - Interface in com.bakdata.kafka.streams.kstream
Extends the CogroupedKStream interface by adding methods to simplify Serde configuration, error handling, and topic access
com.bakdata.kafka - package com.bakdata.kafka
 
com.bakdata.kafka.admin - package com.bakdata.kafka.admin
 
com.bakdata.kafka.producer - package com.bakdata.kafka.producer
 
com.bakdata.kafka.streams - package com.bakdata.kafka.streams
 
com.bakdata.kafka.streams.kstream - package com.bakdata.kafka.streams.kstream
 
computeLag() - Method in class com.bakdata.kafka.ConsumerGroupVerifier
Compute lag of consumer group
config() - Method in class com.bakdata.kafka.admin.ConsumerGroupsClient.ConsumerGroupClient
Create a client for the configuration of this consumer group.
config() - Method in class com.bakdata.kafka.admin.TopicsClient.TopicClient
Create a client for the configuration of this topic.
config(StreamsConfigX) - Method in class com.bakdata.kafka.streams.RunningStreams.RunningStreamsBuilder
 
ConfigClient - Class in com.bakdata.kafka.admin
This class offers helpers to interact with Kafka resource configs.
configure(KafkaApplication<?, ?, ?, ?, ?, ?, ?, ?>) - Method in class com.bakdata.kafka.TestApplicationRunner
Configure the application according to the test environment.
configure(RuntimeConfiguration) - Method in class com.bakdata.kafka.TestSchemaRegistry
Configure the schema registry for the provided RuntimeConfiguration
ConfiguredApp<E> - Interface in com.bakdata.kafka
An application with a corresponding configuration
ConfiguredProducerApp<T extends ProducerApp> - Class in com.bakdata.kafka.producer
A ProducerApp with a corresponding ProducerAppConfiguration
ConfiguredProducerApp(T, ProducerAppConfiguration) - Constructor for class com.bakdata.kafka.producer.ConfiguredProducerApp
 
ConfiguredStreamsApp<T extends StreamsApp> - Class in com.bakdata.kafka.streams
A StreamsApp with a corresponding StreamsAppConfiguration
ConfiguredStreamsApp(T, StreamsAppConfiguration) - Constructor for class com.bakdata.kafka.streams.ConfiguredStreamsApp
 
ConsumedX<K,V> - Class in com.bakdata.kafka.streams.kstream
Use Preconfigured to lazily configure Serde for Consumed using Configurator
consumerGroups() - Method in class com.bakdata.kafka.admin.AdminClientX
Create a ConsumerGroupsClient to perform consumer group-related administrative actions
ConsumerGroupsClient - Class in com.bakdata.kafka.admin
This class offers helpers to interact with Kafka consumer groups.
ConsumerGroupsClient.ConsumerGroupClient - Class in com.bakdata.kafka.admin
A client for a specific consumer group.
ConsumerGroupVerifier - Class in com.bakdata.kafka
Utility class to verify the state of a Kafka consumer group
ConsumerGroupVerifier(String, Supplier<AdminClientX>) - Constructor for class com.bakdata.kafka.ConsumerGroupVerifier
 
convert(String) - Method in class com.bakdata.kafka.StringListConverter
 
count() - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
count() - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
count() - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
count() - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
count(MaterializedX<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
count(MaterializedX<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
count(MaterializedX<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
count(MaterializedX<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
count(Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
count(Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
count(Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
count(Named) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
count(Named) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
count(Named) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
count(Named) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
count(Named, MaterializedX<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
count(Named, MaterializedX<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
count(Named, MaterializedX<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
count(Named, MaterializedX<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
count(Named, Materialized<K, Long, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
count(Named, Materialized<K, Long, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
count(Named, Materialized<K, Long, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
create(ProducerTopicConfig, Map<String, Object>) - Static method in class com.bakdata.kafka.producer.ProducerCleanUpRunner
Create a new ProducerCleanUpRunner with default ProducerCleanUpConfiguration
create(ProducerTopicConfig, Map<String, Object>, ProducerCleanUpConfiguration) - Static method in class com.bakdata.kafka.producer.ProducerCleanUpRunner
Create a new ProducerCleanUpRunner
create(Map<String, Object>) - Static method in class com.bakdata.kafka.admin.AdminClientX
Create a new admin client with default timeout
create(Map<String, Object>, Duration) - Static method in class com.bakdata.kafka.admin.AdminClientX
Create a new admin client
create(Topology, StreamsConfig) - Static method in class com.bakdata.kafka.streams.StreamsCleanUpRunner
Create a new StreamsCleanUpRunner with default StreamsCleanUpConfiguration
create(Topology, StreamsConfig, StreamsCleanUpConfiguration) - Static method in class com.bakdata.kafka.streams.StreamsCleanUpRunner
Create a new StreamsCleanUpRunner
create(TopicSettings) - Method in class com.bakdata.kafka.admin.TopicsClient.TopicClient
Creates a new Kafka topic with the specified number of partitions.
create(TopicSettings, Map<String, String>) - Method in class com.bakdata.kafka.admin.TopicsClient.TopicClient
Creates a new Kafka topic with the specified number of partitions.
create(String) - Static method in class com.bakdata.kafka.RuntimeConfiguration
Create a runtime configuration with the given bootstrap servers.
create(String) - Static method in class com.bakdata.kafka.TestApplicationRunner
Create a test application runner with the given bootstrap servers.
createAdminClient() - Method in class com.bakdata.kafka.AppConfiguration
Create a new AdminClientX using AppConfiguration.kafkaProperties
createApp() - Method in class com.bakdata.kafka.KafkaApplication
Create a new app that will be configured and executed according to this application.
createApp() - Method in class com.bakdata.kafka.producer.SimpleKafkaProducerApplication
 
createApp() - Method in class com.bakdata.kafka.streams.SimpleKafkaStreamsApplication
 
createCleanableApp() - Method in class com.bakdata.kafka.KafkaApplication
createCleanUpRunner() - Method in interface com.bakdata.kafka.ExecutableApp
Create CleanUpRunner in order to clean application
createCleanUpRunner() - Method in class com.bakdata.kafka.producer.ExecutableProducerApp
Create ProducerCleanUpRunner in order to clean application
createCleanUpRunner() - Method in class com.bakdata.kafka.streams.ExecutableStreamsApp
Create StreamsCleanUpRunner in order to clean application
createConfiguration() - Method in class com.bakdata.kafka.producer.ProducerBuilder
Create AppConfiguration used by this app
createConfiguration() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Create AppConfiguration used by this app
createConfiguration(ProducerTopicConfig) - Method in class com.bakdata.kafka.producer.KafkaProducerApplication
 
createConfiguration(StreamsTopicConfig) - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
createConfiguration(T) - Method in class com.bakdata.kafka.KafkaApplication
Create configuration to configure app
createConfigurator() - Method in class com.bakdata.kafka.producer.ProducerBuilder
Create Configurator to configure Serde and Serializer using ProducerBuilder.kafkaProperties.
createConfigurator() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Create Configurator to configure Serde and Serializer using StreamsBuilderX.kafkaProperties.
createConfiguredApp() - Method in class com.bakdata.kafka.KafkaApplication
Create a new ConfiguredApp that will be executed according to this application.
createConfiguredApp(A, AC) - Method in class com.bakdata.kafka.KafkaApplication
Create a new ConfiguredApp that will be executed according to the given config.
createConfiguredApp(T, ProducerAppConfiguration) - Method in class com.bakdata.kafka.producer.KafkaProducerApplication
 
createConfiguredApp(T, StreamsAppConfiguration) - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
createConsumer() - Method in class com.bakdata.kafka.ReaderBuilder
Create a new Consumer for a Kafka cluster
createExecutableApp() - Method in class com.bakdata.kafka.KafkaApplication
Create a new ExecutableApp that will be executed according to the requested command.
createExecutionOptions() - Method in class com.bakdata.kafka.KafkaApplication
Create options for running the app
createExecutionOptions() - Method in class com.bakdata.kafka.producer.KafkaProducerApplication
 
createExecutionOptions() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
createIfNotExists(TopicSettings) - Method in class com.bakdata.kafka.admin.TopicsClient.TopicClient
Creates a new Kafka topic with the specified number of partitions if it does not yet exist.
createIfNotExists(TopicSettings, Map<String, String>) - Method in class com.bakdata.kafka.admin.TopicsClient.TopicClient
Creates a new Kafka topic with the specified number of partitions if it does not yet exist.
createKafkaProperties() - Method in interface com.bakdata.kafka.App
This method should give a default configuration to run your application with.
createKafkaProperties() - Method in class com.bakdata.kafka.RuntimeConfiguration
Create Kafka properties to connect to infrastructure and modify runtime behavior.
createKafkaProperties(Map<String, Object>) - Method in class com.bakdata.kafka.KafkaPropertiesFactory
This method creates the configuration to run a Kafka app.
createProducer() - Method in class com.bakdata.kafka.producer.ProducerBuilder
Create a new Producer using ProducerBuilder.kafkaProperties
createProducer() - Method in class com.bakdata.kafka.SenderBuilder
Create a new Producer for a Kafka cluster
createProducer(Serializer<K>, Serializer<V>) - Method in class com.bakdata.kafka.producer.ProducerBuilder
Create a new Producer using ProducerBuilder.kafkaProperties and provided Serializers
createProperties() - Method in class com.bakdata.kafka.producer.SerializerConfig
 
createProperties() - Method in interface com.bakdata.kafka.SerializationConfig
Create properties from this SerializationConfig
createProperties() - Method in class com.bakdata.kafka.streams.SerdeConfig
 
createRunnableApp() - Method in class com.bakdata.kafka.KafkaApplication
createRunner() - Method in interface com.bakdata.kafka.ExecutableApp
Create Runner in order to run application with default options
createRunner() - Method in class com.bakdata.kafka.producer.ExecutableProducerApp
Create ProducerRunner in order to run application
createRunner() - Method in class com.bakdata.kafka.streams.ExecutableStreamsApp
Create StreamsRunner in order to run application with default StreamsExecutionOptions
createRunner(ProducerExecutionOptions) - Method in class com.bakdata.kafka.producer.ExecutableProducerApp
 
createRunner(StreamsExecutionOptions) - Method in class com.bakdata.kafka.streams.ExecutableStreamsApp
Create StreamsRunner in order to run application
createRunner(O) - Method in interface com.bakdata.kafka.ExecutableApp
Create Runner in order to run application
createSchemaRegistryClient(Map<String, Object>, String) - Static method in class com.bakdata.kafka.SchemaRegistryAppUtils
Creates a new SchemaRegistryClient using the specified configuration.
createSchemaRegistryClient(Map<String, Object>) - Static method in class com.bakdata.kafka.SchemaRegistryAppUtils
Creates a new SchemaRegistryClient using the specified configuration if AbstractKafkaSchemaSerDeConfig.SCHEMA_REGISTRY_URL_CONFIG is configured.
createStateListener() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
Create a KafkaStreams.StateListener to use for Kafka Streams.
createTopic(String) - Method in class com.bakdata.kafka.KafkaTestClient
Creates a new Kafka topic with default settings.
createTopic(String, TopicSettings) - Method in class com.bakdata.kafka.KafkaTestClient
Creates a new Kafka topic with the specified settings.
createTopic(String, TopicSettings, Map<String, String>) - Method in class com.bakdata.kafka.KafkaTestClient
Creates a new Kafka topic with the specified settings.
createTopicConfig() - Method in class com.bakdata.kafka.KafkaApplication
Topics used by app
createTopicConfig() - Method in class com.bakdata.kafka.producer.KafkaProducerApplication
 
createTopicConfig() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
createTopicHook(AppConfiguration<?>) - Static method in class com.bakdata.kafka.LargeMessageAppUtils
Create a hook that cleans up LargeMessage files associated with a topic.
createTopicHook(AppConfiguration<?>) - Static method in class com.bakdata.kafka.SchemaRegistryAppUtils
Create a hook that cleans up schemas associated with a topic.
createTopicHook(Map<String, Object>) - Static method in class com.bakdata.kafka.LargeMessageAppUtils
Create a hook that cleans up LargeMessage files associated with a topic.
createTopicHook(Map<String, Object>) - Static method in class com.bakdata.kafka.SchemaRegistryAppUtils
Create a hook that cleans up schemas associated with a topic.
createTopology(ConfiguredStreamsApp<? extends StreamsApp>) - Method in class com.bakdata.kafka.streams.TestTopologyFactory
Create a TestTopology from a ConfiguredStreamsApp.
createTopology(KafkaStreamsApplication<? extends StreamsApp>) - Method in class com.bakdata.kafka.streams.TestApplicationTopologyFactory
Create a TestTopology from a KafkaStreamsApplication.
createTopology(Map<String, Object>) - Method in class com.bakdata.kafka.streams.ConfiguredStreamsApp
Create the topology of the Kafka Streams app
createTopologyExtension(ConfiguredStreamsApp<? extends StreamsApp>) - Method in class com.bakdata.kafka.streams.TestTopologyFactory
Create a TestTopologyExtension from a ConfiguredStreamsApp.
createTopologyExtension(KafkaStreamsApplication<? extends StreamsApp>) - Method in class com.bakdata.kafka.streams.TestApplicationTopologyFactory
Create a TestTopologyExtension from a KafkaStreamsApplication.
createUncaughtExceptionHandler() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
Create a StreamsUncaughtExceptionHandler to use for Kafka Streams.

D

defaultBranch() - Method in interface com.bakdata.kafka.streams.kstream.BranchedKStreamX
Deprecated.
defaultBranch(BranchedX<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.BranchedKStreamX
 
defaultBranch(Branched<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.BranchedKStreamX
defaultBranchX() - Method in interface com.bakdata.kafka.streams.kstream.BranchedKStreamX
 
defaultBranchX(Branched<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.BranchedKStreamX
 
defaultSerializationConfig() - Method in interface com.bakdata.kafka.App
Configure default serialization behavior
defaultSerializationConfig() - Method in interface com.bakdata.kafka.producer.ProducerApp
 
defaultSerializationConfig() - Method in interface com.bakdata.kafka.streams.StreamsApp
 
defaultTopicSettings() - Static method in class com.bakdata.kafka.KafkaTestClient
Create a new TopicSettings.TopicSettingsBuilder which uses a single partition and no replicas
delete() - Method in class com.bakdata.kafka.admin.ConsumerGroupsClient.ConsumerGroupClient
Delete a consumer group.
delete() - Method in class com.bakdata.kafka.admin.TopicsClient.TopicClient
Delete a Kafka topic.
deleted(String) - Method in interface com.bakdata.kafka.HasTopicHooks.TopicHook
Called when a topic is deleted
deleteIfExists() - Method in class com.bakdata.kafka.admin.ConsumerGroupsClient.ConsumerGroupClient
Delete a consumer group only if it exists.
deleteIfExists() - Method in class com.bakdata.kafka.admin.TopicsClient.TopicClient
Delete a Kafka topic only if it exists.
describe() - Method in class com.bakdata.kafka.admin.ConfigClient
Describes the current configuration of a Kafka resource.
describe() - Method in class com.bakdata.kafka.admin.ConsumerGroupsClient.ConsumerGroupClient
Describe a consumer group.
describe() - Method in class com.bakdata.kafka.admin.TopicsClient.TopicClient
Describe a Kafka topic.

E

emitStrategy(EmitStrategy) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
emitStrategy(EmitStrategy) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
EnvironmentArgumentsParser - Class in com.bakdata.kafka
This class is primarily used to inject environment variables to the passed in command line arguments in KafkaPropertiesFactory.
EnvironmentArgumentsParser(String) - Constructor for class com.bakdata.kafka.EnvironmentArgumentsParser
Create a new parser with a default command line delimiter of - and a default environment delimiter of _
EnvironmentArgumentsParser(String, String, String) - Constructor for class com.bakdata.kafka.EnvironmentArgumentsParser
Create a new parser
EnvironmentKafkaConfigParser - Class in com.bakdata.kafka
Parse configuration properties of a Kafka app from environment variables
equals(Object) - Method in class com.bakdata.kafka.admin.TopicSettings
 
equals(Object) - Method in class com.bakdata.kafka.AppConfiguration
 
equals(Object) - Method in class com.bakdata.kafka.producer.ProducerBuilder
 
equals(Object) - Method in class com.bakdata.kafka.producer.ProducerTopicConfig
 
equals(Object) - Method in class com.bakdata.kafka.SenderBuilder.SimpleProducerRecord
 
equals(Object) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
equals(Object) - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
 
equals(Object) - Method in class com.bakdata.kafka.streams.RunningStreams
 
equals(Object) - Method in class com.bakdata.kafka.streams.StreamsConfigX
 
equals(Object) - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
 
errors() - Method in interface com.bakdata.kafka.streams.kstream.KErrorStreamX
Get the stream of errors that occurred during processing
errors(Named) - Method in interface com.bakdata.kafka.streams.kstream.KErrorStreamX
Get the stream of errors that occurred during processing
errorTopic(String) - Method in class com.bakdata.kafka.streams.StreamsTopicConfig.StreamsTopicConfigBuilder
 
ExecutableApp<R,C,O> - Interface in com.bakdata.kafka
An application with a corresponding topic and Kafka configuration
ExecutableProducerApp<T extends ProducerApp> - Class in com.bakdata.kafka.producer
A ProducerApp with a corresponding ProducerTopicConfig and Kafka configuration
ExecutableStreamsApp<T extends StreamsApp> - Class in com.bakdata.kafka.streams
A StreamsApp with a corresponding Topology and StreamsConfig
exists() - Method in class com.bakdata.kafka.admin.ConsumerGroupsClient.ConsumerGroupClient
Checks whether a Kafka consumer group exists.
exists() - Method in class com.bakdata.kafka.admin.TopicsClient.TopicClient
Checks whether a Kafka topic exists.
existsTopic(String) - Method in class com.bakdata.kafka.KafkaTestClient
Checks whether a Kafka topic exists.

F

filter(Predicate<? super K, ? super V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
filter(Predicate<? super K, ? super V>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
filter(Predicate<? super K, ? super V>, MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
filter(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
filter(Predicate<? super K, ? super V>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
filter(Predicate<? super K, ? super V>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
filter(Predicate<? super K, ? super V>, Named, MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
filter(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
filterNot(Predicate<? super K, ? super V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
filterNot(Predicate<? super K, ? super V>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
filterNot(Predicate<? super K, ? super V>, MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
filterNot(Predicate<? super K, ? super V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
filterNot(Predicate<? super K, ? super V>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
filterNot(Predicate<? super K, ? super V>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
filterNot(Predicate<? super K, ? super V>, Named, MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
filterNot(Predicate<? super K, ? super V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
flatMap(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
flatMapCapturingErrors(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform each record of the input stream into zero or more records in the output stream.
flatMapCapturingErrors(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>, Predicate<Exception>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform each record of the input stream into zero or more records in the output stream.
flatMapCapturingErrors(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>, Predicate<Exception>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform each record of the input stream into zero or more records in the output stream.
flatMapCapturingErrors(KeyValueMapper<? super K, ? super V, ? extends Iterable<? extends KeyValue<? extends KR, ? extends VR>>>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform each record of the input stream into zero or more records in the output stream.
flatMapValues(ValueMapper<? super V, ? extends Iterable<? extends VR>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
flatMapValues(ValueMapper<? super V, ? extends Iterable<? extends VR>>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
flatMapValues(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
flatMapValues(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
flatMapValuesCapturingErrors(ValueMapper<? super V, ? extends Iterable<? extends VR>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Create a new KStream by transforming the value of each record in this stream into zero or more values with the same key in the new stream.
flatMapValuesCapturingErrors(ValueMapper<? super V, ? extends Iterable<? extends VR>>, Predicate<Exception>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Create a new KStream by transforming the value of each record in this stream into zero or more values with the same key in the new stream.
flatMapValuesCapturingErrors(ValueMapper<? super V, ? extends Iterable<? extends VR>>, Predicate<Exception>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Create a new KStream by transforming the value of each record in this stream into zero or more values with the same key in the new stream.
flatMapValuesCapturingErrors(ValueMapper<? super V, ? extends Iterable<? extends VR>>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Create a new KStream by transforming the value of each record in this stream into zero or more values with the same key in the new stream.
flatMapValuesCapturingErrors(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Create a new KStream by transforming the value of each record in this stream into zero or more values with the same key in the new stream.
flatMapValuesCapturingErrors(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>, Predicate<Exception>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Create a new KStream by transforming the value of each record in this stream into zero or more values with the same key in the new stream.
flatMapValuesCapturingErrors(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>, Predicate<Exception>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Create a new KStream by transforming the value of each record in this stream into zero or more values with the same key in the new stream.
flatMapValuesCapturingErrors(ValueMapperWithKey<? super K, ? super V, ? extends Iterable<? extends VR>>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Create a new KStream by transforming the value of each record in this stream into zero or more values with the same key in the new stream.
from(String, Duration) - Method in class com.bakdata.kafka.ReaderBuilder
Read all data from a topic.

G

getApp() - Method in class com.bakdata.kafka.producer.ConfiguredProducerApp
 
getApp() - Method in class com.bakdata.kafka.producer.ExecutableProducerApp
 
getApp() - Method in class com.bakdata.kafka.streams.ConfiguredStreamsApp
 
getApp() - Method in class com.bakdata.kafka.streams.ExecutableStreamsApp
 
getAppId() - Method in class com.bakdata.kafka.streams.StreamsConfigX
Get the application id of the underlying StreamsConfig
getApplicationId() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
getApplicationServer() - Method in class com.bakdata.kafka.streams.StreamsConfigX
Retrieves the host information based on the application server configuration.
getBoostrapServers() - Method in class com.bakdata.kafka.streams.StreamsConfigX
Get the bootstrap servers of the underlying StreamsConfig
getBootstrapServers() - Method in class com.bakdata.kafka.KafkaApplication
 
getCleanUpRunner() - Method in class com.bakdata.kafka.KafkaApplication.CleanableApp
 
getConfig() - Method in class com.bakdata.kafka.streams.ExecutableStreamsApp
 
getConfig() - Method in class com.bakdata.kafka.streams.RunningStreams
 
getContext() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Create a StreamsContext to wrap Kafka Streams interfaces
getErrorTopic() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
getErrorTopic() - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
 
getHeaders() - Method in class com.bakdata.kafka.SenderBuilder.SimpleProducerRecord
 
getInputPattern() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
getInputPattern() - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
 
getInputPattern(String) - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
Get input pattern for a specified label
getInputTopics() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
getInputTopics() - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
 
getInputTopics(String) - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
Get input topics for a specified label
getKafkaConfig() - Method in class com.bakdata.kafka.KafkaApplication
 
getKafkaProperties() - Method in class com.bakdata.kafka.AppConfiguration
 
getKafkaProperties() - Method in class com.bakdata.kafka.producer.ExecutableProducerApp
 
getKafkaProperties() - Method in class com.bakdata.kafka.producer.ProducerBuilder
 
getKafkaProperties() - Method in class com.bakdata.kafka.streams.ExecutableStreamsApp
 
getKafkaProperties() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
getKafkaProperties() - Method in class com.bakdata.kafka.streams.StreamsConfigX
Get all configs of the underlying StreamsConfig
getKafkaProperties(RuntimeConfiguration) - Method in class com.bakdata.kafka.producer.ConfiguredProducerApp
This method creates the configuration to run a ProducerApp.
getKafkaProperties(RuntimeConfiguration) - Method in class com.bakdata.kafka.streams.ConfiguredStreamsApp
This method creates the configuration to run a StreamsApp.
getKafkaProperties(ConfiguredStreamsApp<? extends StreamsApp>) - Method in class com.bakdata.kafka.streams.TestTopologyFactory
Get Kafka properties from a ConfiguredStreamsApp using a RuntimeConfiguration for test purposes with Schema Registry optionally configured.
getKafkaProperties(KafkaStreamsApplication<? extends StreamsApp>) - Method in class com.bakdata.kafka.streams.TestApplicationTopologyFactory
Get Kafka properties from a KafkaStreamsApplication using a RuntimeConfiguration for test purposes with Schema Registry optionally configured.
getKey() - Method in class com.bakdata.kafka.SenderBuilder.SimpleProducerRecord
 
getLabeledInputPatterns() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
getLabeledInputPatterns() - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
Input patterns that are identified by a label
getLabeledInputTopics() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
getLabeledInputTopics() - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
Input topics that are identified by a label
getLabeledOutputTopics() - Method in class com.bakdata.kafka.KafkaApplication
 
getLabeledOutputTopics() - Method in class com.bakdata.kafka.producer.ProducerTopicConfig
Output topics that are identified by a label
getLabeledOutputTopics() - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
Output topics that are identified by a label
getOutputTopic() - Method in class com.bakdata.kafka.KafkaApplication
 
getOutputTopic() - Method in class com.bakdata.kafka.producer.ProducerTopicConfig
 
getOutputTopic() - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
 
getOutputTopic(String) - Method in class com.bakdata.kafka.producer.ProducerTopicConfig
Get output topic for a specified label
getOutputTopic(String) - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
Get output topic for a specified label
getPartitions() - Method in class com.bakdata.kafka.admin.TopicSettings
 
getReplicationFactor() - Method in class com.bakdata.kafka.admin.TopicSettings
 
getRunner() - Method in class com.bakdata.kafka.KafkaApplication.RunnableApp
 
getRuntimeConfiguration() - Method in class com.bakdata.kafka.KafkaApplication
 
getSchemaRegistryClient() - Method in class com.bakdata.kafka.TestSchemaRegistry
Get SchemaRegistryClient for configured URL with default providers
getSchemaRegistryClient(List<SchemaProvider>) - Method in class com.bakdata.kafka.TestSchemaRegistry
Get SchemaRegistryClient for configured URL
getSchemaRegistryUrl() - Method in class com.bakdata.kafka.KafkaApplication
 
getSchemaRegistryUrl() - Method in class com.bakdata.kafka.TestSchemaRegistry
 
getSettings() - Method in class com.bakdata.kafka.admin.TopicsClient.TopicClient
Get the current settings of a Kafka topic.
getState() - Method in class com.bakdata.kafka.ConsumerGroupVerifier
Get current state of consumer group
getStreams() - Method in class com.bakdata.kafka.streams.RunningStreams
 
getStreamsBuilder() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
getStreamsConfig() - Method in class com.bakdata.kafka.streams.StreamsConfigX
 
getTimestamp() - Method in class com.bakdata.kafka.SenderBuilder.SimpleProducerRecord
 
getTopics() - Method in class com.bakdata.kafka.AppConfiguration
 
getTopics() - Method in class com.bakdata.kafka.producer.ConfiguredProducerApp
Get topic configuration
getTopics() - Method in class com.bakdata.kafka.producer.ExecutableProducerApp
 
getTopics() - Method in class com.bakdata.kafka.producer.ProducerAppConfiguration
 
getTopics() - Method in class com.bakdata.kafka.producer.ProducerBuilder
 
getTopics() - Method in class com.bakdata.kafka.streams.ConfiguredStreamsApp
Get topic configuration
getTopics() - Method in class com.bakdata.kafka.streams.ExecutableStreamsApp
 
getTopics() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
getTopics() - Method in class com.bakdata.kafka.streams.StreamsAppConfiguration
 
getTopology() - Method in class com.bakdata.kafka.streams.ExecutableStreamsApp
 
getTopology() - Method in class com.bakdata.kafka.streams.RunningStreams
 
getUniqueAppId() - Method in class com.bakdata.kafka.streams.ConfiguredStreamsApp
Get unique application identifier of StreamsApp
getUniqueAppId() - Method in class com.bakdata.kafka.streams.StreamsAppConfiguration
Get the provided unique application ID.
getUniqueAppId(StreamsAppConfiguration) - Method in interface com.bakdata.kafka.streams.StreamsApp
This must be set to a unique value for every application interacting with your Kafka cluster to ensure internal state encapsulation.
getValue() - Method in class com.bakdata.kafka.SenderBuilder.SimpleProducerRecord
 
globalTable(String) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
globalTable(String, ConsumedX<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
globalTable(String, ConsumedX<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
globalTable(String, MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
globalTable(String, Consumed<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
globalTable(String, Consumed<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
globalTable(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
group(String) - Method in class com.bakdata.kafka.admin.ConsumerGroupsClient
Create a client for a specific consumer group.
groupBy(KeyValueMapper<? super K, ? super V, KR>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
groupBy(KeyValueMapper<? super K, ? super V, KR>, GroupedX<KR, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
groupBy(KeyValueMapper<? super K, ? super V, KR>, Grouped<KR, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>, GroupedX<KR, VR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
groupBy(KeyValueMapper<? super K, ? super V, KeyValue<KR, VR>>, Grouped<KR, VR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
groupByKey() - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
groupByKey(GroupedX<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
groupByKey(Grouped<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
GroupedX<K,V> - Class in com.bakdata.kafka.streams.kstream
Use Preconfigured to lazily configure Serde for Grouped using Configurator

H

HasCleanHook<SELF> - Interface in com.bakdata.kafka
Interface for performing actions when cleaning apps
hasFinishedProcessing() - Method in class com.bakdata.kafka.ConsumerGroupVerifier
Check whether consumer group has assigned partitions and lag is 0
hashCode() - Method in class com.bakdata.kafka.admin.TopicSettings
 
hashCode() - Method in class com.bakdata.kafka.AppConfiguration
 
hashCode() - Method in class com.bakdata.kafka.producer.ProducerBuilder
 
hashCode() - Method in class com.bakdata.kafka.producer.ProducerTopicConfig
 
hashCode() - Method in class com.bakdata.kafka.SenderBuilder.SimpleProducerRecord
 
hashCode() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
hashCode() - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
 
hashCode() - Method in class com.bakdata.kafka.streams.RunningStreams
 
hashCode() - Method in class com.bakdata.kafka.streams.StreamsConfigX
 
hashCode() - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
 
HasTopicHooks<SELF> - Interface in com.bakdata.kafka
Interface for performing actions on topics
HasTopicHooks.TopicHook - Interface in com.bakdata.kafka
Hook for performing actions on topics

I

inputPattern(Pattern) - Method in class com.bakdata.kafka.streams.StreamsTopicConfig.StreamsTopicConfigBuilder
 
inputTopics(List<String>) - Method in class com.bakdata.kafka.streams.StreamsTopicConfig.StreamsTopicConfigBuilder
 
isActive() - Method in class com.bakdata.kafka.ConsumerGroupVerifier
Check whether consumer group has state GroupState.STABLE
isClosed() - Method in class com.bakdata.kafka.ConsumerGroupVerifier
Check whether consumer group has state GroupState.EMPTY
isVolatileGroupInstanceId() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 

J

join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoinedX<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoinedX<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>, JoinedX<K, V, VT>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>, JoinedX<K, V, VT>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
join(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
JoinedX<K,V1,V2> - Class in com.bakdata.kafka.streams.kstream
Use Preconfigured to lazily configure Serde for Joined using Configurator

K

KafkaAdminException - Exception in com.bakdata.kafka.admin
Exception thrown by if admin operations fail.
KafkaApplication<R extends Runner,CR extends CleanUpRunner,O,E extends ExecutableApp<R,CR,O>,CA extends ConfiguredApp<E>,T,A,AC> - Class in com.bakdata.kafka
The base class for creating Kafka applications.
KafkaApplication() - Constructor for class com.bakdata.kafka.KafkaApplication
 
KafkaApplication.CleanableApp<CR extends CleanUpRunner> - Class in com.bakdata.kafka
Provides access to a CleanUpRunner and closes the associated ExecutableApp
KafkaApplication.RunnableApp<R extends Runner> - Class in com.bakdata.kafka
Provides access to a Runner and closes the associated ExecutableApp
KafkaProducerApplication<T extends ProducerApp> - Class in com.bakdata.kafka.producer
The base class for creating Kafka Producer applications.
KafkaProducerApplication() - Constructor for class com.bakdata.kafka.producer.KafkaProducerApplication
 
KafkaPropertiesFactory - Class in com.bakdata.kafka
Creates properties for a Kafka app.
KafkaPropertiesFactory.KafkaPropertiesFactoryBuilder - Class in com.bakdata.kafka
 
KafkaStreamsApplication<T extends StreamsApp> - Class in com.bakdata.kafka.streams
The base class for creating Kafka Streams applications.
KafkaStreamsApplication() - Constructor for class com.bakdata.kafka.streams.KafkaStreamsApplication
 
KafkaTestClient - Class in com.bakdata.kafka
Client that supports communication with Kafka clusters in test setups, including topic management, reading from and sending to topics.
KafkaTestClient(RuntimeConfiguration) - Constructor for class com.bakdata.kafka.KafkaTestClient
 
KErrorStreamX<K,V,KR,VR> - Interface in com.bakdata.kafka.streams.kstream
KStreamX that contains successfully processed records and errors of a previous operation
keySerde(Preconfigured<? extends Serde<K>>) - Static method in class com.bakdata.kafka.streams.kstream.ConsumedX
Create an instance of ConsumedX with provided key serde
keySerde(Preconfigured<? extends Serde<K>>) - Static method in class com.bakdata.kafka.streams.kstream.GroupedX
 
keySerde(Preconfigured<? extends Serde<K>>) - Static method in class com.bakdata.kafka.streams.kstream.JoinedX
 
keySerde(Preconfigured<? extends Serde<K>>) - Static method in class com.bakdata.kafka.streams.kstream.MaterializedX
Create an instance of MaterializedX with provided key serde
keySerde(Preconfigured<? extends Serde<K>>) - Static method in class com.bakdata.kafka.streams.kstream.ProducedX
 
keySerde(Preconfigured<? extends Serde<K>>) - Static method in class com.bakdata.kafka.streams.kstream.RepartitionedX
Create an instance of RepartitionedX with provided key serde
keySerde(Preconfigured<? extends Serde<K>>) - Static method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
Create an instance of StreamJoinedX with provided key serde
keySerde(Serde<K>) - Static method in class com.bakdata.kafka.streams.kstream.ConsumedX
Create an instance of ConsumedX with provided key serde
keySerde(Serde<K>) - Static method in class com.bakdata.kafka.streams.kstream.GroupedX
 
keySerde(Serde<K>) - Static method in class com.bakdata.kafka.streams.kstream.JoinedX
 
keySerde(Serde<K>) - Static method in class com.bakdata.kafka.streams.kstream.MaterializedX
Create an instance of MaterializedX with provided key serde
keySerde(Serde<K>) - Static method in class com.bakdata.kafka.streams.kstream.ProducedX
 
keySerde(Serde<K>) - Static method in class com.bakdata.kafka.streams.kstream.RepartitionedX
Create an instance of RepartitionedX with provided key serde
keySerde(Serde<K>) - Static method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
Create an instance of StreamJoinedX with provided key serde
keyValueStoreBuilder(KeyValueBytesStoreSupplier, Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V>>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
keyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
KGroupedStreamX<K,V> - Interface in com.bakdata.kafka.streams.kstream
Extends the KGroupedStream interface by adding methods to simplify Serde configuration, error handling, and topic access
KGroupedTableX<K,V> - Interface in com.bakdata.kafka.streams.kstream
Extends the KGroupedTable interface by adding methods to simplify Serde configuration, error handling, and topic access
KStreamX<K,V> - Interface in com.bakdata.kafka.streams.kstream
Extends the KStream interface by adding methods to simplify Serde configuration, error handling, and topic access
KTableX<K,V> - Interface in com.bakdata.kafka.streams.kstream
Extends the KTable interface by adding methods to simplify Serde configuration, error handling, and topic access

L

labeledInputPatterns(Map<String, Pattern>) - Method in class com.bakdata.kafka.streams.StreamsTopicConfig.StreamsTopicConfigBuilder
Input patterns that are identified by a label
labeledInputTopics(Map<String, List<String>>) - Method in class com.bakdata.kafka.streams.StreamsTopicConfig.StreamsTopicConfigBuilder
Input topics that are identified by a label
labeledOutputTopics(Map<String, String>) - Method in class com.bakdata.kafka.producer.ProducerTopicConfig.ProducerTopicConfigBuilder
Output topics that are identified by a label
labeledOutputTopics(Map<String, String>) - Method in class com.bakdata.kafka.streams.StreamsTopicConfig.StreamsTopicConfigBuilder
Output topics that are identified by a label
LargeMessageAppUtils - Class in com.bakdata.kafka
Utility class that provides helpers for cleaning LargeMessageSerde artifacts
LargeMessageProducerApp - Interface in com.bakdata.kafka.producer
ProducerApp that automatically removes files associated with LargeMessageSerializer
LargeMessageStreamsApp - Interface in com.bakdata.kafka.streams
StreamsApp that automatically removes files associated with LargeMessageSerde
leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoiner<? super V, ? super GV, ? extends RV>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(GlobalKTable<GK, GV>, KeyValueMapper<? super K, ? super V, ? extends GK>, ValueJoinerWithKey<? super K, ? super V, ? super GV, ? extends RV>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoinedX<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoinedX<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>, JoinedX<K, V, VT>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KTable<K, VT>, ValueJoiner<? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>, JoinedX<K, V, VT>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KTable<K, VT>, ValueJoinerWithKey<? super K, ? super V, ? super VT, ? extends VR>, Joined<K, V, VT>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<KO, VO>, BiFunction<K, V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
leftJoin(KTable<KO, VO>, Function<V, KO>, ValueJoiner<V, VO, VR>, TableJoined<K, KO>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
list() - Method in class com.bakdata.kafka.admin.ConsumerGroupsClient
List consumer groups.
list() - Method in class com.bakdata.kafka.admin.TopicsClient
List Kafka topics.
listOffsets() - Method in class com.bakdata.kafka.admin.ConsumerGroupsClient.ConsumerGroupClient
List offsets for a consumer group.
listOffsets(Iterable<TopicPartition>) - Method in class com.bakdata.kafka.admin.TopicsClient
List offsets for a set of partitions.

M

map(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
map(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
mapCapturingErrors(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform each record of the input stream into a new record in the output stream.
mapCapturingErrors(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>, Predicate<Exception>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform each record of the input stream into a new record in the output stream.
mapCapturingErrors(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>, Predicate<Exception>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform each record of the input stream into a new record in the output stream.
mapCapturingErrors(KeyValueMapper<? super K, ? super V, ? extends KeyValue<? extends KR, ? extends VR>>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform each record of the input stream into a new record in the output stream.
mapValues(ValueMapper<? super V, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
mapValues(ValueMapper<? super V, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValues(ValueMapper<? super V, ? extends VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValues(ValueMapper<? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
mapValues(ValueMapper<? super V, ? extends VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValues(ValueMapper<? super V, ? extends VR>, Named, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValues(ValueMapper<? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValues(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
mapValuesCapturingErrors(ValueMapper<? super V, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform the value of each input record into a new value of the output record.
mapValuesCapturingErrors(ValueMapper<? super V, ? extends VR>, Predicate<Exception>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform the value of each input record into a new value of the output record.
mapValuesCapturingErrors(ValueMapper<? super V, ? extends VR>, Predicate<Exception>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform the value of each input record into a new value of the output record.
mapValuesCapturingErrors(ValueMapper<? super V, ? extends VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform the value of each input record into a new value of the output record.
mapValuesCapturingErrors(ValueMapperWithKey<? super K, ? super V, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform the value of each input record into a new value of the output record.
mapValuesCapturingErrors(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Predicate<Exception>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform the value of each input record into a new value of the output record.
mapValuesCapturingErrors(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Predicate<Exception>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform the value of each input record into a new value of the output record.
mapValuesCapturingErrors(ValueMapperWithKey<? super K, ? super V, ? extends VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Transform the value of each input record into a new value of the output record.
MaterializedX<K,V,S extends org.apache.kafka.streams.processor.StateStore> - Class in com.bakdata.kafka.streams.kstream
Use Preconfigured to lazily configure Serde for Materialized using Configurator
merge(KStream<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
merge(KStream<K, V>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
modify(BiFunction<? super StreamJoined<K, V1, V2>, ? super Configurator, ? extends StreamJoined<K, V1, V2>>) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
modify(Function<? super StreamJoined<K, V1, V2>, ? extends StreamJoined<K, V1, V2>>) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 

N

newInstance(Function<Configurator, Consumed<K, V>>) - Method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
newInstance(Function<Configurator, Grouped<K, V>>) - Method in class com.bakdata.kafka.streams.kstream.GroupedX
 
newInstance(Function<Configurator, Joined<K, V1, V2>>) - Method in class com.bakdata.kafka.streams.kstream.JoinedX
 
newInstance(Function<Configurator, Materialized<K, V, S>>) - Method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
newInstance(Function<Configurator, Produced<K, V>>) - Method in class com.bakdata.kafka.streams.kstream.ProducedX
 
newInstance(Function<Configurator, Repartitioned<K, V>>) - Method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
newInstance(Function<Configurator, StreamJoined<K, V1, V2>>) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
newInstance(Function<StreamsContext, Branched<K, V>>) - Method in class com.bakdata.kafka.streams.kstream.BranchedX
 
newTestClient() - Method in class com.bakdata.kafka.TestApplicationRunner
Create a new KafkaTestClient for the configured test environment.
noDefaultBranch() - Method in interface com.bakdata.kafka.streams.kstream.BranchedKStreamX
Deprecated.
noDefaultBranchX() - Method in interface com.bakdata.kafka.streams.kstream.BranchedKStreamX
 
numberOfPartitions(int) - Static method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 

O

onApplicationStart() - Method in class com.bakdata.kafka.KafkaApplication
Called before starting the application, e.g., invoking KafkaApplication.run()
onStart(Consumer<RunningStreams>) - Method in class com.bakdata.kafka.streams.StreamsExecutionOptions.StreamsExecutionOptionsBuilder
Hook that is called after calling KafkaStreams.start()
onStreamsStart(RunningStreams) - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
Called after starting Kafka Streams
otherValueSerde(Preconfigured<? extends Serde<V2>>) - Static method in class com.bakdata.kafka.streams.kstream.JoinedX
 
otherValueSerde(Preconfigured<? extends Serde<V2>>) - Static method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
Create an instance of StreamJoinedX with provided other value serde
otherValueSerde(Serde<V2>) - Static method in class com.bakdata.kafka.streams.kstream.JoinedX
 
otherValueSerde(Serde<V2>) - Static method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
Create an instance of StreamJoinedX with provided other value serde
outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoinedX<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
outerJoin(KStream<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
outerJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
outerJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoinedX<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
outerJoin(KStream<K, VO>, ValueJoinerWithKey<? super K, ? super V, ? super VO, ? extends VR>, JoinWindows, StreamJoined<K, V, VO>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
outerJoin(KTable<K, VO>, ValueJoiner<? super V, ? super VO, ? extends VR>, Named, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
outputTopic(String) - Method in class com.bakdata.kafka.producer.ProducerTopicConfig.ProducerTopicConfigBuilder
 
outputTopic(String) - Method in class com.bakdata.kafka.streams.StreamsTopicConfig.StreamsTopicConfigBuilder
 

P

parseVariables(Map<String, String>) - Method in class com.bakdata.kafka.EnvironmentArgumentsParser
Parse a list of environment variables as command line arguments.
parseVariables(Map<String, String>) - Static method in class com.bakdata.kafka.EnvironmentKafkaConfigParser
Parse a list of environment variables as a streams configuration.
partitions(int) - Method in class com.bakdata.kafka.admin.TopicSettings.TopicSettingsBuilder
 
peek(ForeachAction<? super K, ? super V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
peek(ForeachAction<? super K, ? super V>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
prepareClean() - Method in class com.bakdata.kafka.KafkaApplication
Called before cleaning the application, i.e., invoking KafkaApplication.clean()
prepareClean() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
Called before cleaning the application, i.e., invoking KafkaStreamsApplication.clean() or KafkaStreamsApplication.reset()
prepareRun() - Method in class com.bakdata.kafka.KafkaApplication
Called before running the application, i.e., invoking KafkaApplication.run()
process(ProcessorSupplier<? super K, ? super V, KOut, VOut>, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
process(ProcessorSupplier<? super K, ? super V, KOut, VOut>, Named, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
processCapturingErrors(ProcessorSupplier<? super K, ? super V, KOut, VOut>, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Process all records in this stream, one record at a time, by applying a Processor.
processCapturingErrors(ProcessorSupplier<? super K, ? super V, KOut, VOut>, Predicate<Exception>, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Process all records in this stream, one record at a time, by applying a Processor.
processCapturingErrors(ProcessorSupplier<? super K, ? super V, KOut, VOut>, Predicate<Exception>, Named, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Process all records in this stream, one record at a time, by applying a Processor.
processCapturingErrors(ProcessorSupplier<? super K, ? super V, KOut, VOut>, Named, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Process all records in this stream, one record at a time, by applying a Processor.
processValues(FixedKeyProcessorSupplier<? super K, ? super V, VOut>, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
processValues(FixedKeyProcessorSupplier<? super K, ? super V, VOut>, Named, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
processValuesCapturingErrors(FixedKeyProcessorSupplier<? super K, ? super V, VOut>, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Process all records in this stream, one record at a time, by applying a FixedKeyProcessor.
processValuesCapturingErrors(FixedKeyProcessorSupplier<? super K, ? super V, VOut>, Predicate<Exception>, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Process all records in this stream, one record at a time, by applying a FixedKeyProcessor.
processValuesCapturingErrors(FixedKeyProcessorSupplier<? super K, ? super V, VOut>, Predicate<Exception>, Named, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Process all records in this stream, one record at a time, by applying a FixedKeyProcessor.
processValuesCapturingErrors(FixedKeyProcessorSupplier<? super K, ? super V, VOut>, Named, String...) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Process all records in this stream, one record at a time, by applying a FixedKeyProcessor.
ProducedX<K,V> - Class in com.bakdata.kafka.streams.kstream
Use Preconfigured to lazily configure Serde for Produced using Configurator
ProducerApp - Interface in com.bakdata.kafka.producer
Application that defines how to produce messages to Kafka and necessary configurations
ProducerAppConfiguration - Class in com.bakdata.kafka.producer
Configuration of a ProducerApp
ProducerAppConfiguration(ProducerTopicConfig) - Constructor for class com.bakdata.kafka.producer.ProducerAppConfiguration
 
ProducerBuilder - Class in com.bakdata.kafka.producer
Provides all runtime configurations when running a ProducerApp
ProducerBuilder(ProducerTopicConfig, Map<String, Object>) - Constructor for class com.bakdata.kafka.producer.ProducerBuilder
 
ProducerCleanUpConfiguration - Class in com.bakdata.kafka.producer
Provides configuration options for ProducerCleanUpRunner
ProducerCleanUpConfiguration() - Constructor for class com.bakdata.kafka.producer.ProducerCleanUpConfiguration
 
ProducerCleanUpRunner - Class in com.bakdata.kafka.producer
Delete all output topics specified by a ProducerTopicConfig
ProducerExecutionOptions - Class in com.bakdata.kafka.producer
Options to run a Kafka Producer app using ProducerRunner
ProducerExecutionOptions.ProducerExecutionOptionsBuilder - Class in com.bakdata.kafka.producer
 
ProducerRunnable - Interface in com.bakdata.kafka.producer
Produce messages to Kafka
ProducerRunner - Class in com.bakdata.kafka.producer
Runs a Kafka Producer application
ProducerRunner(ProducerRunnable) - Constructor for class com.bakdata.kafka.producer.ProducerRunner
 
ProducerTopicConfig - Class in com.bakdata.kafka.producer
Provides topic configuration for a ProducerApp
ProducerTopicConfig.ProducerTopicConfigBuilder - Class in com.bakdata.kafka.producer
 

R

read() - Method in class com.bakdata.kafka.KafkaTestClient
Prepare reading data from the cluster.
ReaderBuilder<K,V> - Class in com.bakdata.kafka
Read data from a Kafka cluster
reduce(Reducer<V>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
reduce(Reducer<V>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
reduce(Reducer<V>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
reduce(Reducer<V>, MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
reduce(Reducer<V>, MaterializedX<K, V, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
reduce(Reducer<V>, MaterializedX<K, V, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
reduce(Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
reduce(Reducer<V>, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
reduce(Reducer<V>, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
reduce(Reducer<V>, Named) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
reduce(Reducer<V>, Named) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
reduce(Reducer<V>, Named, MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
reduce(Reducer<V>, Named, MaterializedX<K, V, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
reduce(Reducer<V>, Named, MaterializedX<K, V, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
reduce(Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
reduce(Reducer<V>, Named, Materialized<K, V, SessionStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.SessionWindowedKStreamX
 
reduce(Reducer<V>, Named, Materialized<K, V, WindowStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.TimeWindowedKStreamX
 
reduce(Reducer<V>, Reducer<V>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
reduce(Reducer<V>, Reducer<V>, MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
reduce(Reducer<V>, Reducer<V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
reduce(Reducer<V>, Reducer<V>, Named, MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
reduce(Reducer<V>, Reducer<V>, Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedTableX
 
registerCleanHook(Runnable) - Method in interface com.bakdata.kafka.HasCleanHook
Register a hook that is invoked when cleaning apps
registerCleanHook(Runnable) - Method in class com.bakdata.kafka.producer.ProducerCleanUpConfiguration
Register an action that is executed after ProducerCleanUpRunner.clean() has finished
registerCleanHook(Runnable) - Method in class com.bakdata.kafka.streams.StreamsCleanUpConfiguration
Register a hook that is executed after StreamsCleanUpRunner.clean() has finished
registerResetHook(Runnable) - Method in class com.bakdata.kafka.streams.StreamsCleanUpConfiguration
Register a hook that is executed after StreamsCleanUpRunner.reset() has finished
registerTopicHook(HasTopicHooks.TopicHook) - Method in interface com.bakdata.kafka.HasTopicHooks
Register a hook that is invoked when performing actions on topics
registerTopicHook(HasTopicHooks.TopicHook) - Method in class com.bakdata.kafka.producer.ProducerCleanUpConfiguration
Register a hook that is executed whenever a topic has been deleted by the cleanup runner.
registerTopicHook(HasTopicHooks.TopicHook) - Method in class com.bakdata.kafka.streams.StreamsCleanUpConfiguration
Register a hook that is executed whenever a topic has been deleted by the cleanup runner.
registerTopicHook(HasTopicHooks<T>, AppConfiguration<?>) - Static method in class com.bakdata.kafka.LargeMessageAppUtils
Register a hook that cleans up LargeMessage files associated with a topic
repartition() - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
repartition(RepartitionedX<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
repartition(Repartitioned<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
RepartitionedX<K,V> - Class in com.bakdata.kafka.streams.kstream
Use Preconfigured to lazily configure Serde for Repartitioned using Configurator
replicationFactor(short) - Method in class com.bakdata.kafka.admin.TopicSettings.TopicSettingsBuilder
 
reset() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
Clear all state stores, consumer group offsets, and internal topics associated with the Kafka Streams application.
reset() - Method in class com.bakdata.kafka.streams.StreamsCleanUpRunner
Clean up your Streams app by resetting all state stores, consumer group offsets, and internal topics, deleting local state.
reset(KafkaStreamsApplication<? extends StreamsApp>) - Method in class com.bakdata.kafka.TestApplicationRunner
Reset the application.
reset(KafkaStreamsApplication<? extends StreamsApp>, String...) - Method in class com.bakdata.kafka.TestApplicationRunner
Reset the application with the given arguments.
run() - Method in class com.bakdata.kafka.KafkaApplication
Run the application.
run() - Method in interface com.bakdata.kafka.producer.ProducerRunnable
Produce messages to Kafka
run() - Method in class com.bakdata.kafka.producer.ProducerRunner
 
run() - Method in interface com.bakdata.kafka.Runner
Run the application
run() - Method in class com.bakdata.kafka.streams.StreamsRunner
Run the Streams application.
run(KafkaApplication<?, ?, ?, ?, ?, ?, ?, ?>) - Method in class com.bakdata.kafka.TestApplicationRunner
Run the application asynchronously.
run(KafkaApplication<?, ?, ?, ?, ?, ?, ?, ?>, String...) - Method in class com.bakdata.kafka.TestApplicationRunner
Run the application asynchronously with the given arguments.
RunnableApp(ExecutableApp<?, ?, ?>, R, Consumer<KafkaApplication.Stoppable>) - Constructor for class com.bakdata.kafka.KafkaApplication.RunnableApp
 
Runner - Interface in com.bakdata.kafka
Interface for running applications
RunningStreams - Class in com.bakdata.kafka.streams
A running KafkaStreams instance along with its StreamsConfig and Topology
RunningStreams.RunningStreamsBuilder - Class in com.bakdata.kafka.streams
 
runResetter(Collection<String>, Collection<String>, StreamsConfigX) - Static method in class com.bakdata.kafka.streams.StreamsCleanUpRunner
runtimeConfig(RuntimeConfiguration) - Method in class com.bakdata.kafka.KafkaPropertiesFactory.KafkaPropertiesFactoryBuilder
 
RuntimeConfiguration - Class in com.bakdata.kafka
Runtime configuration to connect to Kafka infrastructure, e.g., bootstrap servers and schema registry.

S

schemaRegistry() - Method in class com.bakdata.kafka.admin.AdminClientX
Create a SchemaRegistryClient if schema registry is configured.
SchemaRegistryAppUtils - Class in com.bakdata.kafka
Utility class that provides helpers for removing schemas associated with topics
selectKey(KeyValueMapper<? super K, ? super V, ? extends KR>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
selectKey(KeyValueMapper<? super K, ? super V, ? extends KR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
send() - Method in class com.bakdata.kafka.KafkaTestClient
Prepare sending new data to the cluster
SenderBuilder<K,V> - Class in com.bakdata.kafka
Send data to a Kafka cluster
SenderBuilder.SimpleProducerRecord<K,V> - Class in com.bakdata.kafka
Represents a ProducerRecord without topic assignment
SerdeConfig - Class in com.bakdata.kafka.streams
Defines how to (de-)serialize the data in a Kafka Streams app
SerdeConfig(Class<? extends Serde>, Class<? extends Serde>) - Constructor for class com.bakdata.kafka.streams.SerdeConfig
 
SerializationConfig - Interface in com.bakdata.kafka
Defines how to (de-)serialize the data in a Kafka client
SerializerConfig - Class in com.bakdata.kafka.producer
Defines how to serialize the data in a Kafka producer
SerializerConfig(Class<? extends Serializer>, Class<? extends Serializer>) - Constructor for class com.bakdata.kafka.producer.SerializerConfig
 
sessionStoreBuilder(SessionBytesStoreSupplier, Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V>>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
sessionStoreBuilder(SessionBytesStoreSupplier, Serde<K>, Serde<V>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
SessionWindowedCogroupedKStreamX<K,VOut> - Interface in com.bakdata.kafka.streams.kstream
Extends the SessionWindowedCogroupedKStream interface by adding methods to simplify Serde configuration, error handling, and topic access
SessionWindowedKStreamX<K,V> - Interface in com.bakdata.kafka.streams.kstream
Extends the SessionWindowedKStream interface by adding methods to simplify Serde configuration, error handling, and topic access
setApplicationId(String) - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
setBootstrapServers(String) - Method in class com.bakdata.kafka.KafkaApplication
 
setErrorTopic(String) - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
setInputPattern(Pattern) - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
setInputTopics(List<String>) - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
setKafkaConfig(Map<String, String>) - Method in class com.bakdata.kafka.KafkaApplication
 
setLabeledInputPatterns(Map<String, Pattern>) - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
setLabeledInputTopics(Map<String, List<String>>) - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
setLabeledOutputTopics(Map<String, String>) - Method in class com.bakdata.kafka.KafkaApplication
 
setOutputTopic(String) - Method in class com.bakdata.kafka.KafkaApplication
 
setSchemaRegistryUrl(String) - Method in class com.bakdata.kafka.KafkaApplication
 
setup(AppConfiguration<T>) - Method in interface com.bakdata.kafka.App
Setup Kafka resources, such as topics, before running this app
setupCleanUp(AppConfiguration<ProducerTopicConfig>) - Method in interface com.bakdata.kafka.producer.LargeMessageProducerApp
 
setupCleanUp(AppConfiguration<ProducerTopicConfig>) - Method in interface com.bakdata.kafka.producer.ProducerApp
 
setupCleanUp(AppConfiguration<StreamsTopicConfig>) - Method in interface com.bakdata.kafka.streams.LargeMessageStreamsApp
 
setupCleanUp(AppConfiguration<StreamsTopicConfig>) - Method in interface com.bakdata.kafka.streams.StreamsApp
 
setupCleanUp(AppConfiguration<T>) - Method in interface com.bakdata.kafka.App
Configure clean up behavior
setVolatileGroupInstanceId(boolean) - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
SimpleKafkaProducerApplication<T extends ProducerApp> - Class in com.bakdata.kafka.producer
KafkaProducerApplication without any additional configuration options.
SimpleKafkaProducerApplication(Supplier<T>) - Constructor for class com.bakdata.kafka.producer.SimpleKafkaProducerApplication
 
SimpleKafkaStreamsApplication<T extends StreamsApp> - Class in com.bakdata.kafka.streams
KafkaStreamsApplication without any additional configuration options.
SimpleKafkaStreamsApplication(Supplier<T>) - Constructor for class com.bakdata.kafka.streams.SimpleKafkaStreamsApplication
 
SimpleProducerRecord(K, V) - Constructor for class com.bakdata.kafka.SenderBuilder.SimpleProducerRecord
Create a new SimpleProducerRecord without timestamp and headers
SimpleProducerRecord(K, V, Iterable<Header>) - Constructor for class com.bakdata.kafka.SenderBuilder.SimpleProducerRecord
Create a new SimpleProducerRecord without timestamp
SimpleProducerRecord(K, V, Instant) - Constructor for class com.bakdata.kafka.SenderBuilder.SimpleProducerRecord
Create a new SimpleProducerRecord without headers
SimpleProducerRecord(K, V, Instant, Iterable<Header>) - Constructor for class com.bakdata.kafka.SenderBuilder.SimpleProducerRecord
 
split() - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
split(Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
startApplication(String[]) - Method in class com.bakdata.kafka.KafkaApplication
This method should be called in the main method of your application
startApplicationWithoutExit(String[]) - Method in class com.bakdata.kafka.KafkaApplication
This method should be called in the main method of your application
stateListener(Supplier<KafkaStreams.StateListener>) - Method in class com.bakdata.kafka.streams.StreamsExecutionOptions.StreamsExecutionOptionsBuilder
Configures KafkaStreams.setStateListener(StateListener)
stop() - Method in class com.bakdata.kafka.KafkaApplication.CleanableApp
Close the app
stop() - Method in class com.bakdata.kafka.KafkaApplication.RunnableApp
Close the runner and app
stop() - Method in class com.bakdata.kafka.KafkaApplication
Stop all applications that have been started asynchronously, e.g., by using KafkaApplication.run() or KafkaApplication.clean().
stores() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Create stores using application context to lazily configures Serdes
StoresX - Class in com.bakdata.kafka.streams.kstream
Use Preconfigured to lazily configure Serde for Stores using Configurator
StoresX(Configurator) - Constructor for class com.bakdata.kafka.streams.kstream.StoresX
 
stream(String) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
stream(String, ConsumedX<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
stream(String, Consumed<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
stream(Collection<String>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
stream(Collection<String>, ConsumedX<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
stream(Collection<String>, Consumed<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
stream(Pattern) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
stream(Pattern, ConsumedX<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
stream(Pattern, Consumed<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
streamInput() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
streamInput(ConsumedX<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
streamInput(String) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
streamInput(String, ConsumedX<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
streamInput(String, Consumed<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
streamInput(Consumed<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
streamInputPattern() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Create a KStreamX from all topics matching StreamsTopicConfig.getInputPattern()
streamInputPattern(ConsumedX<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Create a KStreamX from all topics matching StreamsTopicConfig.getInputPattern()
streamInputPattern(String) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Create a KStreamX from all topics matching StreamsTopicConfig.getInputPattern(String)
streamInputPattern(String, ConsumedX<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Create a KStreamX from all topics matching StreamsTopicConfig.getInputPattern(String)
streamInputPattern(String, Consumed<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Create a KStreamX from all topics matching StreamsTopicConfig.getInputPattern(String)
streamInputPattern(Consumed<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Create a KStreamX from all topics matching StreamsTopicConfig.getInputPattern()
StreamJoinedX<K,V1,V2> - Class in com.bakdata.kafka.streams.kstream
Use Preconfigured to lazily configure Serde for StreamJoined using Configurator
streamPartitioner(StreamPartitioner<? super K, ? super V>) - Static method in class com.bakdata.kafka.streams.kstream.ProducedX
 
streamPartitioner(StreamPartitioner<K, V>) - Static method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
streams(KafkaStreams) - Method in class com.bakdata.kafka.streams.RunningStreams.RunningStreamsBuilder
 
StreamsApp - Interface in com.bakdata.kafka.streams
Application that defines a Kafka Streams Topology and necessary configurations
StreamsAppConfiguration - Class in com.bakdata.kafka.streams
Configuration of a StreamsApp
StreamsAppConfiguration(StreamsTopicConfig, String) - Constructor for class com.bakdata.kafka.streams.StreamsAppConfiguration
 
StreamsAppConfiguration(StreamsTopicConfig) - Constructor for class com.bakdata.kafka.streams.StreamsAppConfiguration
Create a new StreamsAppConfiguration with no provided StreamsAppConfiguration.uniqueAppId
StreamsApplicationException - Exception in com.bakdata.kafka.streams
Exception thrown if running streams application was unsuccessful
StreamsApplicationException(String) - Constructor for exception com.bakdata.kafka.streams.StreamsApplicationException
 
StreamsApplicationException(String, Throwable) - Constructor for exception com.bakdata.kafka.streams.StreamsApplicationException
 
StreamsBuilderX - Class in com.bakdata.kafka.streams.kstream
Provides all runtime configurations and supports building a Topology of a StreamsApp
StreamsBuilderX(StreamsBuilder, StreamsTopicConfig, Map<String, Object>) - Constructor for class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
StreamsBuilderX(StreamsTopicConfig, Map<String, Object>) - Constructor for class com.bakdata.kafka.streams.kstream.StreamsBuilderX
Create a new StreamsBuilderX.
StreamsCleanUpConfiguration - Class in com.bakdata.kafka.streams
Provides configuration options for StreamsCleanUpRunner
StreamsCleanUpConfiguration() - Constructor for class com.bakdata.kafka.streams.StreamsCleanUpConfiguration
 
StreamsCleanUpRunner - Class in com.bakdata.kafka.streams
Clean up the state and artifacts of your Kafka Streams app
StreamsConfigX - Class in com.bakdata.kafka.streams
Class for simplified access to configs provided by StreamsConfig
StreamsConfigX(StreamsConfig) - Constructor for class com.bakdata.kafka.streams.StreamsConfigX
 
StreamsContext - Class in com.bakdata.kafka.streams.kstream
Provides context for the configured Kafka Streams application environment, i.e., topic configuration and StreamsConfig
StreamsContext(StreamsTopicConfig, Configurator) - Constructor for class com.bakdata.kafka.streams.kstream.StreamsContext
 
StreamsExecutionOptions - Class in com.bakdata.kafka.streams
Options to run a Kafka Streams app using StreamsRunner
StreamsExecutionOptions.StreamsExecutionOptionsBuilder - Class in com.bakdata.kafka.streams
 
StreamsRunner - Class in com.bakdata.kafka.streams
Runs a Kafka Streams application
StreamsRunner(Topology, StreamsConfig) - Constructor for class com.bakdata.kafka.streams.StreamsRunner
Create a StreamsRunner with default StreamsExecutionOptions
StreamsRunner(Topology, StreamsConfig, StreamsExecutionOptions) - Constructor for class com.bakdata.kafka.streams.StreamsRunner
Create a StreamsRunner
StreamsTopicConfig - Class in com.bakdata.kafka.streams
Provides topic configuration for a StreamsApp
StreamsTopicConfig.StreamsTopicConfigBuilder - Class in com.bakdata.kafka.streams
 
StringListConverter - Class in com.bakdata.kafka
Converter for lists inside collection type parsed by PicoCLI.
StringListConverter() - Constructor for class com.bakdata.kafka.StringListConverter
 
suppress(Suppressed<? super K>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 

T

table(String) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
table(String, ConsumedX<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
table(String, ConsumedX<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
table(String, MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
table(String, Consumed<K, V>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
table(String, Consumed<K, V>, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
table(String, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
TestApplicationRunner - Class in com.bakdata.kafka
Class that provides helpers for using running KafkaApplication in tests
TestApplicationTopologyFactory - Class in com.bakdata.kafka.streams
Class that provides helpers for using Fluent Kafka Streams Tests with KafkaStreamsApplication
TestApplicationTopologyFactory() - Constructor for class com.bakdata.kafka.streams.TestApplicationTopologyFactory
Create a new TestApplicationTopologyFactory
TestSchemaRegistry - Class in com.bakdata.kafka
Class that provides helpers for using schema registry in tests.
TestSchemaRegistry() - Constructor for class com.bakdata.kafka.TestSchemaRegistry
Create a new TestSchemaRegistry.
TestSchemaRegistry(String) - Constructor for class com.bakdata.kafka.TestSchemaRegistry
 
TestTopologyFactory - Class in com.bakdata.kafka.streams
Class that provides helpers for using Fluent Kafka Streams Tests with ConfiguredStreamsApp
TestTopologyFactory() - Constructor for class com.bakdata.kafka.streams.TestTopologyFactory
Create a new TestTopologyFactory
timestampedKeyValueStoreBuilder(KeyValueBytesStoreSupplier, Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V>>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
timestampedKeyValueStoreBuilder(KeyValueBytesStoreSupplier, Serde<K>, Serde<V>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
timestampedWindowStoreBuilder(WindowBytesStoreSupplier, Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V>>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
timestampedWindowStoreBuilder(WindowBytesStoreSupplier, Serde<K>, Serde<V>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
TimeWindowedCogroupedKStreamX<K,VOut> - Interface in com.bakdata.kafka.streams.kstream
Extends the TimeWindowedCogroupedKStream interface by adding methods to simplify Serde configuration, error handling, and topic access
TimeWindowedKStreamX<K,V> - Interface in com.bakdata.kafka.streams.kstream
Extends the TimeWindowedKStream interface by adding methods to simplify Serde configuration, error handling, and topic access
to(String, ProducedX<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
to(String, Iterable<SenderBuilder.SimpleProducerRecord<K, V>>) - Method in class com.bakdata.kafka.SenderBuilder
Send data to a topic
to(TopicNameExtractor<K, V>, ProducedX<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
toErrorTopic() - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Materialize KStream to StreamsTopicConfig.getErrorTopic()
toErrorTopic(ProducedX<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Materialize KStream to StreamsTopicConfig.getErrorTopic()
toErrorTopic(Produced<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
Materialize KStream to StreamsTopicConfig.getErrorTopic()
toOutputTopic() - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
toOutputTopic(ProducedX<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
toOutputTopic(String) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
toOutputTopic(String, ProducedX<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
toOutputTopic(String, Produced<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
toOutputTopic(Produced<K, V>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
topic(String) - Method in class com.bakdata.kafka.admin.TopicsClient
Create a client for a specific topic.
topics() - Method in class com.bakdata.kafka.admin.AdminClientX
Create a TopicsClient to perform topic-related administrative actions.
TopicsClient - Class in com.bakdata.kafka.admin
This class offers helpers to interact with Kafka topics.
TopicsClient.TopicClient - Class in com.bakdata.kafka.admin
A client for a specific topic.
TopicSettings - Class in com.bakdata.kafka.admin
Contains information about a topic, including number of partitions and replication factor.
TopicSettings.TopicSettingsBuilder - Class in com.bakdata.kafka.admin
 
topology(Topology) - Method in class com.bakdata.kafka.streams.RunningStreams.RunningStreamsBuilder
 
toStream() - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
toStream(KeyValueMapper<? super K, ? super V, ? extends KR>) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
toStream(KeyValueMapper<? super K, ? super V, ? extends KR>, Named) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
toStream(Named) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
toString() - Method in class com.bakdata.kafka.admin.TopicSettings.TopicSettingsBuilder
 
toString() - Method in class com.bakdata.kafka.admin.TopicSettings
 
toString() - Method in class com.bakdata.kafka.AppConfiguration
 
toString() - Method in class com.bakdata.kafka.KafkaApplication
 
toString() - Method in class com.bakdata.kafka.KafkaPropertiesFactory.KafkaPropertiesFactoryBuilder
 
toString() - Method in class com.bakdata.kafka.producer.KafkaProducerApplication
 
toString() - Method in class com.bakdata.kafka.producer.ProducerBuilder
 
toString() - Method in class com.bakdata.kafka.producer.ProducerExecutionOptions.ProducerExecutionOptionsBuilder
 
toString() - Method in class com.bakdata.kafka.producer.ProducerTopicConfig.ProducerTopicConfigBuilder
 
toString() - Method in class com.bakdata.kafka.producer.ProducerTopicConfig
 
toString() - Method in class com.bakdata.kafka.SenderBuilder.SimpleProducerRecord
 
toString() - Method in class com.bakdata.kafka.streams.KafkaStreamsApplication
 
toString() - Method in class com.bakdata.kafka.streams.kstream.StreamsBuilderX
 
toString() - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
 
toString() - Method in class com.bakdata.kafka.streams.RunningStreams.RunningStreamsBuilder
 
toString() - Method in class com.bakdata.kafka.streams.RunningStreams
 
toString() - Method in class com.bakdata.kafka.streams.StreamsConfigX
 
toString() - Method in class com.bakdata.kafka.streams.StreamsExecutionOptions.StreamsExecutionOptionsBuilder
 
toString() - Method in class com.bakdata.kafka.streams.StreamsTopicConfig.StreamsTopicConfigBuilder
 
toString() - Method in class com.bakdata.kafka.streams.StreamsTopicConfig
 
toTable() - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
toTable(MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
toTable(Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
toTable(Named) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
toTable(Named, MaterializedX<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
toTable(Named, Materialized<K, V, KeyValueStore<Bytes, byte[]>>) - Method in interface com.bakdata.kafka.streams.kstream.KStreamX
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>, String...) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, MaterializedX<K, VR, KeyValueStore<Bytes, byte[]>>, Named, String...) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, String...) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, String...) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Materialized<K, VR, KeyValueStore<Bytes, byte[]>>, Named, String...) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 
transformValues(ValueTransformerWithKeySupplier<? super K, ? super V, ? extends VR>, Named, String...) - Method in interface com.bakdata.kafka.streams.kstream.KTableX
 

U

uncaughtExceptionHandler(Supplier<StreamsUncaughtExceptionHandler>) - Method in class com.bakdata.kafka.streams.StreamsExecutionOptions.StreamsExecutionOptionsBuilder
Configures KafkaStreams.setUncaughtExceptionHandler(StreamsUncaughtExceptionHandler)

V

values() - Method in interface com.bakdata.kafka.streams.kstream.KErrorStreamX
Get the stream of successfully processed values
values(Named) - Method in interface com.bakdata.kafka.streams.kstream.KErrorStreamX
Get the stream of successfully processed values
valueSerde(Preconfigured<? extends Serde<V>>) - Static method in class com.bakdata.kafka.streams.kstream.ConsumedX
Create an instance of ConsumedX with provided value serde
valueSerde(Preconfigured<? extends Serde<V>>) - Static method in class com.bakdata.kafka.streams.kstream.GroupedX
 
valueSerde(Preconfigured<? extends Serde<V>>) - Static method in class com.bakdata.kafka.streams.kstream.MaterializedX
Create an instance of MaterializedX with provided value serde
valueSerde(Preconfigured<? extends Serde<V>>) - Static method in class com.bakdata.kafka.streams.kstream.ProducedX
 
valueSerde(Preconfigured<? extends Serde<V>>) - Static method in class com.bakdata.kafka.streams.kstream.RepartitionedX
Create an instance of RepartitionedX with provided value serde
valueSerde(Preconfigured<? extends Serde<V1>>) - Static method in class com.bakdata.kafka.streams.kstream.JoinedX
 
valueSerde(Preconfigured<? extends Serde<V1>>) - Static method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
Create an instance of StreamJoinedX with provided value serde
valueSerde(Serde<V>) - Static method in class com.bakdata.kafka.streams.kstream.ConsumedX
Create an instance of ConsumedX with provided value serde
valueSerde(Serde<V>) - Static method in class com.bakdata.kafka.streams.kstream.GroupedX
 
valueSerde(Serde<V>) - Static method in class com.bakdata.kafka.streams.kstream.MaterializedX
Create an instance of MaterializedX with provided value serde
valueSerde(Serde<V>) - Static method in class com.bakdata.kafka.streams.kstream.ProducedX
 
valueSerde(Serde<V>) - Static method in class com.bakdata.kafka.streams.kstream.RepartitionedX
Create an instance of RepartitionedX with provided value serde
valueSerde(Serde<V1>) - Static method in class com.bakdata.kafka.streams.kstream.JoinedX
 
valueSerde(Serde<V1>) - Static method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
Create an instance of StreamJoinedX with provided value serde
verify(ExecutableStreamsApp<?>) - Static method in class com.bakdata.kafka.ConsumerGroupVerifier
Create a new verifier from an ExecutableStreamsApp
verify(KafkaStreamsApplication<? extends StreamsApp>) - Method in class com.bakdata.kafka.TestApplicationRunner
Create a new ConsumerGroupVerifier for the provided application.
versionedKeyValueStoreBuilder(VersionedBytesStoreSupplier, Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V>>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
versionedKeyValueStoreBuilder(VersionedBytesStoreSupplier, Serde<K>, Serde<V>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
volatileGroupInstanceId(boolean) - Method in class com.bakdata.kafka.streams.StreamsExecutionOptions.StreamsExecutionOptionsBuilder
Defines if ConsumerConfig.GROUP_INSTANCE_ID_CONFIG is volatile.

W

windowedBy(SessionWindows) - Method in interface com.bakdata.kafka.streams.kstream.CogroupedKStreamX
 
windowedBy(SessionWindows) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
windowedBy(SlidingWindows) - Method in interface com.bakdata.kafka.streams.kstream.CogroupedKStreamX
 
windowedBy(SlidingWindows) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
windowedBy(Windows<W>) - Method in interface com.bakdata.kafka.streams.kstream.CogroupedKStreamX
 
windowedBy(Windows<W>) - Method in interface com.bakdata.kafka.streams.kstream.KGroupedStreamX
 
windowStoreBuilder(WindowBytesStoreSupplier, Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V>>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
windowStoreBuilder(WindowBytesStoreSupplier, Serde<K>, Serde<V>) - Method in class com.bakdata.kafka.streams.kstream.StoresX
 
with(Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V>>) - Static method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
with(Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V>>) - Static method in class com.bakdata.kafka.streams.kstream.GroupedX
 
with(Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V>>) - Static method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
with(Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V>>) - Static method in class com.bakdata.kafka.streams.kstream.ProducedX
 
with(Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V>>) - Static method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
with(Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V1>>, Preconfigured<? extends Serde<V2>>) - Static method in class com.bakdata.kafka.streams.kstream.JoinedX
 
with(Preconfigured<? extends Serde<K>>, Preconfigured<? extends Serde<V1>>, Preconfigured<? extends Serde<V2>>) - Static method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
with(String, Object) - Method in class com.bakdata.kafka.ReaderBuilder
Add a consumer configuration
with(String, Object) - Method in class com.bakdata.kafka.SenderBuilder
Add a producer configuration
with(Map<String, ?>) - Method in class com.bakdata.kafka.RuntimeConfiguration
Configure arbitrary Kafka properties
with(Map<String, ?>) - Method in class com.bakdata.kafka.streams.TestApplicationTopologyFactory
Configure arbitrary Kafka properties for the application under test
with(Map<String, ?>) - Method in class com.bakdata.kafka.streams.TestTopologyFactory
Configure arbitrary Kafka properties for the application under test
with(Serde<K>, Serde<V>) - Static method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
with(Serde<K>, Serde<V>) - Static method in class com.bakdata.kafka.streams.kstream.GroupedX
 
with(Serde<K>, Serde<V>) - Static method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
with(Serde<K>, Serde<V>) - Static method in class com.bakdata.kafka.streams.kstream.ProducedX
 
with(Serde<K>, Serde<V>) - Static method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
with(Serde<K>, Serde<V1>, Serde<V2>) - Static method in class com.bakdata.kafka.streams.kstream.JoinedX
 
with(Serde<K>, Serde<V1>, Serde<V2>) - Static method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
with(AutoOffsetReset) - Static method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
with(TimestampExtractor) - Static method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
with(DslStoreSuppliers) - Static method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
with(WindowBytesStoreSupplier, WindowBytesStoreSupplier) - Static method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
with(Topology.AutoOffsetReset) - Static method in class com.bakdata.kafka.streams.kstream.ConsumedX
Deprecated.
withCachingDisabled() - Method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
withCachingEnabled() - Method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
withConsumer(Consumer<? super KStreamX<K, V>>) - Static method in class com.bakdata.kafka.streams.kstream.BranchedX
 
withDeserializers(Preconfigured<Deserializer<KN>>, Preconfigured<Deserializer<VN>>) - Method in class com.bakdata.kafka.ReaderBuilder
Provide custom deserializers for keys and values.
withDeserializers(Deserializer<KN>, Deserializer<VN>) - Method in class com.bakdata.kafka.ReaderBuilder
Provide custom deserializers for keys and values.
withDslStoreSuppliers(DslStoreSuppliers) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withFunction(Function<? super KStreamX<K, V>, ? extends KStream<K, V>>) - Static method in class com.bakdata.kafka.streams.kstream.BranchedX
 
withGracePeriod(Duration) - Method in class com.bakdata.kafka.streams.kstream.JoinedX
 
withKafkaConfig(Map<String, String>) - Method in class com.bakdata.kafka.TestApplicationRunner
Configure arbitrary Kafka properties
withKeyDeserializer(Preconfigured<Deserializer<KN>>) - Method in class com.bakdata.kafka.ReaderBuilder
Provide custom deserializers for keys.
withKeyDeserializer(Deserializer<KN>) - Method in class com.bakdata.kafka.ReaderBuilder
Provide custom deserializers for keys.
withKeySerde(Class<? extends Serde>) - Method in class com.bakdata.kafka.streams.SerdeConfig
 
withKeySerde(Preconfigured<? extends Serde<K>>) - Method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
withKeySerde(Preconfigured<? extends Serde<K>>) - Method in class com.bakdata.kafka.streams.kstream.GroupedX
 
withKeySerde(Preconfigured<? extends Serde<K>>) - Method in class com.bakdata.kafka.streams.kstream.JoinedX
 
withKeySerde(Preconfigured<? extends Serde<K>>) - Method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
withKeySerde(Preconfigured<? extends Serde<K>>) - Method in class com.bakdata.kafka.streams.kstream.ProducedX
 
withKeySerde(Preconfigured<? extends Serde<K>>) - Method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
withKeySerde(Preconfigured<? extends Serde<K>>) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withKeySerde(Serde<K>) - Method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
withKeySerde(Serde<K>) - Method in class com.bakdata.kafka.streams.kstream.GroupedX
 
withKeySerde(Serde<K>) - Method in class com.bakdata.kafka.streams.kstream.JoinedX
 
withKeySerde(Serde<K>) - Method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
withKeySerde(Serde<K>) - Method in class com.bakdata.kafka.streams.kstream.ProducedX
 
withKeySerde(Serde<K>) - Method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
withKeySerde(Serde<K>) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withKeySerializer(Class<? extends Serializer>) - Method in class com.bakdata.kafka.producer.SerializerConfig
 
withKeySerializer(Preconfigured<Serializer<KN>>) - Method in class com.bakdata.kafka.SenderBuilder
Provide a custom serializers for keys.
withKeySerializer(Serializer<KN>) - Method in class com.bakdata.kafka.SenderBuilder
Provide a custom serializers for keys.
withLoggingDisabled() - Method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
withLoggingDisabled() - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withLoggingEnabled(Map<String, String>) - Method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
withLoggingEnabled(Map<String, String>) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withName(String) - Method in class com.bakdata.kafka.streams.kstream.BranchedX
 
withName(String) - Method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
withName(String) - Method in class com.bakdata.kafka.streams.kstream.GroupedX
 
withName(String) - Method in class com.bakdata.kafka.streams.kstream.JoinedX
 
withName(String) - Method in class com.bakdata.kafka.streams.kstream.ProducedX
 
withName(String) - Method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
withName(String) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withNoStateStoreCaching() - Method in class com.bakdata.kafka.RuntimeConfiguration
Disable for Kafka Streams.
withNoStateStoreCaching() - Method in class com.bakdata.kafka.TestApplicationRunner
Disable for Kafka Streams.
withNumberOfPartitions(int) - Method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
withOffsetResetPolicy(AutoOffsetReset) - Method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
withOffsetResetPolicy(Topology.AutoOffsetReset) - Method in class com.bakdata.kafka.streams.kstream.ConsumedX
Deprecated.
withOtherStoreSupplier(WindowBytesStoreSupplier) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withOtherValueSerde(Preconfigured<? extends Serde<V2>>) - Method in class com.bakdata.kafka.streams.kstream.JoinedX
 
withOtherValueSerde(Preconfigured<Serde<V2>>) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withOtherValueSerde(Serde<V2>) - Method in class com.bakdata.kafka.streams.kstream.JoinedX
 
withOtherValueSerde(Serde<V2>) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withRetention(Duration) - Method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
withRuntimeConfiguration(RuntimeConfiguration) - Method in interface com.bakdata.kafka.ConfiguredApp
Create an executable app using the provided RuntimeConfiguration.
withRuntimeConfiguration(RuntimeConfiguration) - Method in class com.bakdata.kafka.producer.ConfiguredProducerApp
Create an ExecutableProducerApp using the provided RuntimeConfiguration
withRuntimeConfiguration(RuntimeConfiguration) - Method in class com.bakdata.kafka.streams.ConfiguredStreamsApp
Create an ExecutableStreamsApp using the provided RuntimeConfiguration
withSchemaRegistry() - Static method in class com.bakdata.kafka.streams.TestApplicationTopologyFactory
Create a new TestApplicationTopologyFactory with configured Schema Registry.
withSchemaRegistry() - Static method in class com.bakdata.kafka.streams.TestTopologyFactory
Create a new TestTopologyFactory with configured Schema Registry.
withSchemaRegistry() - Method in class com.bakdata.kafka.TestApplicationRunner
Configure a schema registry for (de-)serialization.
withSchemaRegistry(TestSchemaRegistry) - Method in class com.bakdata.kafka.TestApplicationRunner
Configure a schema registry for (de-)serialization.
withSchemaRegistry(TestSchemaRegistry) - Static method in class com.bakdata.kafka.streams.TestApplicationTopologyFactory
Create a new TestApplicationTopologyFactory with configured Schema Registry.
withSchemaRegistry(TestSchemaRegistry) - Static method in class com.bakdata.kafka.streams.TestTopologyFactory
Create a new TestTopologyFactory with configured Schema Registry.
withSchemaRegistryUrl(String) - Method in class com.bakdata.kafka.RuntimeConfiguration
Configure a schema registry for (de-)serialization.
withSerializers(Preconfigured<Serializer<KN>>, Preconfigured<Serializer<VN>>) - Method in class com.bakdata.kafka.SenderBuilder
Provide custom serializers for keys and values.
withSerializers(Serializer<KN>, Serializer<VN>) - Method in class com.bakdata.kafka.SenderBuilder
Provide custom serializers for keys and values.
withSessionTimeout(Duration) - Method in class com.bakdata.kafka.RuntimeConfiguration
Configure ConsumerConfig.SESSION_TIMEOUT_MS_CONFIG for Kafka consumers.
withSessionTimeout(Duration) - Method in class com.bakdata.kafka.TestApplicationRunner
Configure ConsumerConfig.SESSION_TIMEOUT_MS_CONFIG for Kafka consumers.
withStateDir(Path) - Method in class com.bakdata.kafka.RuntimeConfiguration
Configure StreamsConfig.STATE_DIR_CONFIG for Kafka Streams.
withStateDir(Path) - Method in class com.bakdata.kafka.TestApplicationRunner
Configure StreamsConfig.STATE_DIR_CONFIG for Kafka Streams.
withStoreName(String) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withStoreType(DslStoreSuppliers) - Method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
withStreamPartitioner(StreamPartitioner<? super K, ? super V>) - Method in class com.bakdata.kafka.streams.kstream.ProducedX
 
withStreamPartitioner(StreamPartitioner<K, V>) - Method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
withThisStoreSupplier(WindowBytesStoreSupplier) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withTimestampExtractor(TimestampExtractor) - Method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
withValueDeserializer(Preconfigured<Deserializer<VN>>) - Method in class com.bakdata.kafka.ReaderBuilder
Provide custom deserializers for values.
withValueDeserializer(Deserializer<VN>) - Method in class com.bakdata.kafka.ReaderBuilder
Provide custom deserializers for values.
withValueSerde(Class<? extends Serde>) - Method in class com.bakdata.kafka.streams.SerdeConfig
 
withValueSerde(Preconfigured<? extends Serde<V>>) - Method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
withValueSerde(Preconfigured<? extends Serde<V>>) - Method in class com.bakdata.kafka.streams.kstream.GroupedX
 
withValueSerde(Preconfigured<? extends Serde<V>>) - Method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
withValueSerde(Preconfigured<? extends Serde<V>>) - Method in class com.bakdata.kafka.streams.kstream.ProducedX
 
withValueSerde(Preconfigured<? extends Serde<V>>) - Method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
withValueSerde(Preconfigured<? extends Serde<V1>>) - Method in class com.bakdata.kafka.streams.kstream.JoinedX
 
withValueSerde(Preconfigured<? extends Serde<V1>>) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withValueSerde(Serde<V>) - Method in class com.bakdata.kafka.streams.kstream.ConsumedX
 
withValueSerde(Serde<V>) - Method in class com.bakdata.kafka.streams.kstream.GroupedX
 
withValueSerde(Serde<V>) - Method in class com.bakdata.kafka.streams.kstream.MaterializedX
 
withValueSerde(Serde<V>) - Method in class com.bakdata.kafka.streams.kstream.ProducedX
 
withValueSerde(Serde<V>) - Method in class com.bakdata.kafka.streams.kstream.RepartitionedX
 
withValueSerde(Serde<V1>) - Method in class com.bakdata.kafka.streams.kstream.JoinedX
 
withValueSerde(Serde<V1>) - Method in class com.bakdata.kafka.streams.kstream.StreamJoinedX
 
withValueSerializer(Class<? extends Serializer>) - Method in class com.bakdata.kafka.producer.SerializerConfig
 
withValueSerializer(Preconfigured<Serializer<VN>>) - Method in class com.bakdata.kafka.SenderBuilder
Provide a custom serializers for values.
withValueSerializer(Serializer<VN>) - Method in class com.bakdata.kafka.SenderBuilder
Provide a custom serializers for values.
wrap(BranchedKStream<KR, VR>) - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
Wrap a BranchedKStream and add methods to simplify Serde configuration, error handling, and topic access
wrap(CogroupedKStream<KR, VR>) - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
Wrap a CogroupedKStream and add methods to simplify Serde configuration, error handling, and topic access
wrap(KGroupedStream<KR, VR>) - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
Wrap a KGroupedStream and add methods to simplify Serde configuration, error handling, and topic access
wrap(KGroupedTable<KR, VR>) - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
Wrap a KGroupedTable and add methods to simplify Serde configuration, error handling, and topic access
wrap(KStream<KR, VR>) - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
Wrap a KStream and add methods to simplify Serde configuration, error handling, and topic access
wrap(KTable<KR, VR>) - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
Wrap a KTable and add methods to simplify Serde configuration, error handling, and topic access
wrap(SessionWindowedCogroupedKStream<KR, VR>) - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
Wrap a SessionWindowedCogroupedKStream and add methods to simplify Serde configuration, error handling, and topic access
wrap(SessionWindowedKStream<KR, VR>) - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
Wrap a SessionWindowedKStream and add methods to simplify Serde configuration, error handling, and topic access
wrap(TimeWindowedCogroupedKStream<KR, VR>) - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
Wrap a TimeWindowedCogroupedKStream and add methods to simplify Serde configuration, error handling, and topic access
wrap(TimeWindowedKStream<KR, VR>) - Method in class com.bakdata.kafka.streams.kstream.StreamsContext
Wrap a TimeWindowedKStream and add methods to simplify Serde configuration, error handling, and topic access
A B C D E F G H I J K L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Serialized Form