Index

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

A

AbstractKafkaStreamsBinderProcessor - Class in org.springframework.cloud.stream.binder.kafka.streams
 
AbstractKafkaStreamsBinderProcessor(BindingServiceProperties, KafkaStreamsBindingInformationCatalogue, KafkaStreamsExtendedBindingProperties, KeyValueSerdeResolver, CleanupConfig) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.AbstractKafkaStreamsBinderProcessor
 
accept(ConsumerRecord<?, ?>, Exception) - Method in class org.springframework.cloud.stream.binder.kafka.streams.SendToDlqAndContinue
 
addDlqProducerFactory(StreamsBuilderFactoryBean, ProducerFactory<byte[], byte[]>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBindingInformationCatalogue
 
addMetrics(Set<StreamsBuilderFactoryBean>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderMetrics
 
addOutputBinding(String, Class<?>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsBindableProxyFactory
 
addPreviousKafkaStreamsForApplicationId(String, KafkaStreams) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBindingInformationCatalogue
Caching the previous KafkaStreams for the applicaiton.id when binding is stopped through actuator.
afterPropertiesSet() - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsBindableProxyFactory
 
afterPropertiesSet() - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsFunctionBeanPostProcessor
 
applicationContext - Variable in class org.springframework.cloud.stream.binder.kafka.streams.AbstractKafkaStreamsBinderProcessor
 
apply(BindHandler) - Method in class org.springframework.cloud.stream.binder.kafka.streams.EncodingDecodingBindAdviceHandler
 

B

binderConfigurationProperties(KafkaProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.MultiBinderPropertiesConfiguration
 
binderConfigurationProperties(KafkaProperties, ConfigurableEnvironment, BindingServiceProperties, ConfigurableApplicationContext) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
binderStreamsListener(MeterRegistry) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfiguration.KafkaMicrometer
 
binderStreamsListener(MeterRegistry) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfigurationWithMultiBinder.KafkaMicrometer
 
bindTo(Set<StreamsBuilderFactoryBean>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderMetrics
 
buildStreamsBuilderAndRetrieveConfig(String, ApplicationContext, String, KafkaStreamsBinderConfigurationProperties, StreamsBuilderFactoryBeanConfigurer, ConfigurableEnvironment, BindingProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.AbstractKafkaStreamsBinderProcessor
 

C

cache() - Element in annotation type org.springframework.cloud.stream.binder.kafka.streams.annotations.KafkaStreamsStateStore
Whether catching is enabled or not.
close() - Method in class org.springframework.cloud.stream.binder.kafka.streams.serde.CollectionSerde
 
close() - Method in class org.springframework.cloud.stream.binder.kafka.streams.serde.MessageConverterDelegateSerde
Deprecated.
 
CollectionSerde<E> - Class in org.springframework.cloud.stream.binder.kafka.streams.serde
A convenient Serde for Collection implementations.
CollectionSerde(Class<?>, Class<?>) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.serde.CollectionSerde
Constructor to delegate serialization operations for the inner objects to JsonSerde.
CollectionSerde(Serde<E>, Class<?>) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.serde.CollectionSerde
Constructor to use when the application wants to specify the type of the Serde used for the inner object.
compositeNonNativeSerde(CompositeMessageConverter) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
CompositeNonNativeSerde - Class in org.springframework.cloud.stream.binder.kafka.streams.serde
Deprecated.
CompositeNonNativeSerde(CompositeMessageConverter) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.serde.CompositeNonNativeSerde
Deprecated.
 
configure(Map<String, ?>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.SkipAndContinueExceptionHandler
 
configure(Map<String, ?>, boolean) - Method in class org.springframework.cloud.stream.binder.kafka.streams.serde.CollectionSerde
 
configure(Map<String, ?>, boolean) - Method in class org.springframework.cloud.stream.binder.kafka.streams.serde.MessageConverterDelegateSerde
Deprecated.
 
createInput(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBoundElementFactory
 
createOutput(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBoundElementFactory
 

D

DeserializationExceptionHandler - Enum in org.springframework.cloud.stream.binder.kafka.streams
Enumeration for various DeserializationExceptionHandler types.
deserializeOnInbound(Class<?>, KStream<?, ?>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsMessageConversionDelegate
Deserialize incoming KStream based on content type.
deserializer() - Method in class org.springframework.cloud.stream.binder.kafka.streams.serde.CollectionSerde
 
deserializer() - Method in class org.springframework.cloud.stream.binder.kafka.streams.serde.MessageConverterDelegateSerde
Deprecated.
 
destroy() - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderHealthIndicator
 
doBindConsumer(String, String, GlobalKTable<Object, Object>, ExtendedConsumerProperties<KafkaStreamsConsumerProperties>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinder
 
doBindProducer(String, GlobalKTable<Object, Object>, ExtendedProducerProperties<KafkaStreamsProducerProperties>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinder
 
doHealthCheck(Health.Builder) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderHealthIndicator
 

E

encodingDecodingBindAdviceHandler() - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
EncodingDecodingBindAdviceHandler - Class in org.springframework.cloud.stream.binder.kafka.streams
ConfigurationPropertiesBindHandlerAdvisor to detect nativeEncoding/Decoding settings provided by the application explicitly.
EncodingDecodingBindAdviceHandler() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.EncodingDecodingBindAdviceHandler
 
ExtendedBindingHandlerMappingsProviderAutoConfiguration - Class in org.springframework.cloud.stream.binder.kafka.streams
Auto-configuration for extended binding metadata for Kafka Streams.
ExtendedBindingHandlerMappingsProviderAutoConfiguration() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.ExtendedBindingHandlerMappingsProviderAutoConfiguration
 

F

FunctionDetectorCondition - Class in org.springframework.cloud.stream.binder.kafka.streams.function
Custom Condition that detects the presence of java.util.Function|Consumer beans.
FunctionDetectorCondition() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.function.FunctionDetectorCondition
 
Functions() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.Functions
 

G

getAllHostsInfo(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.InteractiveQueryService
Gets the list of HostInfo where the provided store is hosted on.
getApplicationId() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.Functions
 
getApplicationId() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
 
getApplicationId() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
getAutoOffsetReset(String, KafkaStreamsConsumerProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.AbstractKafkaStreamsBinderProcessor
 
getBackoffPeriod() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.StateStoreRetry
 
getBindings() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsExtendedBindingProperties
 
getConfiguration() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.Functions
 
getConsumedAs() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
getConsumer() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBindingProperties
 
getConsumerPropertiesPerSbfb() - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBindingInformationCatalogue
 
getCurrentHostInfo() - Method in class org.springframework.cloud.stream.binder.kafka.streams.InteractiveQueryService
Gets the current HostInfo that the calling kafka streams application is running on.
getDefaultsPrefix() - Method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinder
 
getDefaultsPrefix() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsExtendedBindingProperties
 
getDeserializationExceptionHandler() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
 
getDeserializationExceptionHandler() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
getDlqProducerFactories() - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBindingInformationCatalogue
 
getDlqProducerFactory(StreamsBuilderFactoryBean) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBindingInformationCatalogue
 
getEventTypeHeaderKey() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
getEventTypes() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
getExtendedConsumerProperties(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinder
 
getExtendedProducerProperties(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinder
 
getExtendedPropertiesEntryClass() - Method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinder
 
getExtendedPropertiesEntryClass() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsExtendedBindingProperties
 
getFunctionName() - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsBindableProxyFactory
 
getFunctions() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
 
getHostInfo(String, K, Serializer<K>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.InteractiveQueryService
Gets the HostInfo where the provided store and key are hosted on.
getInboundKeySerde(KafkaStreamsConsumerProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KeyValueSerdeResolver
Provide the Serde for inbound key.
getInboundKeySerde(KafkaStreamsConsumerProperties, ResolvableType) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KeyValueSerdeResolver
 
getInboundValueSerde(ConsumerProperties, KafkaStreamsConsumerProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KeyValueSerdeResolver
Provide the Serde for inbound value.
getInboundValueSerde(ConsumerProperties, KafkaStreamsConsumerProperties, ResolvableType) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KeyValueSerdeResolver
 
getInputs() - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsBindableProxyFactory
 
getKafkaStreams(String, K, Serializer<K>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.InteractiveQueryService
Retrieves and returns the KafkaStreams object that is associated with the given combination of key and state store.
getKeyQueryMetadata(String, K, Serializer<K>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.InteractiveQueryService
Retrieves and returns the KeyQueryMetadata associated with the given combination of key and state store.
getKeySerde() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
getKeySerde() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsProducerProperties
 
getKeySerdeString() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
getKStream(String, BindingProperties, KafkaStreamsConsumerProperties, StreamsBuilder, Serde<?>, Serde<?>, Topology.AutoOffsetReset, boolean) - Method in class org.springframework.cloud.stream.binder.kafka.streams.AbstractKafkaStreamsBinderProcessor
 
getLength() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
getMatchOutcome(ConditionContext, AnnotatedTypeMetadata) - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.FunctionDetectorCondition
 
getMaterializedAs() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
getMaxAttempts() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.StateStoreRetry
 
getMethods() - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsFunctionBeanPostProcessor
 
getName() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
getOuboundKeySerde(KafkaStreamsProducerProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KeyValueSerdeResolver
Provide the Serde for outbound key.
getOuboundKeySerde(KafkaStreamsProducerProperties, ResolvableType) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KeyValueSerdeResolver
 
getOutboundValueSerde(ProducerProperties, KafkaStreamsProducerProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KeyValueSerdeResolver
Provide the Serde for outbound value.
getOutboundValueSerde(ProducerProperties, KafkaStreamsProducerProperties, ResolvableType) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KeyValueSerdeResolver
 
getOutputHolders() - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsBindableProxyFactory
 
getOutputs() - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsBindableProxyFactory
 
getPhase() - Method in class org.springframework.cloud.stream.binder.kafka.streams.StreamsBuilderFactoryManager
 
getProducedAs() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsProducerProperties
 
getProducer() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBindingProperties
 
getQueryableStore(String, QueryableStoreType<T>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.InteractiveQueryService
Retrieve and return a queryable store by name created in the application.
getResolvableTypes() - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsFunctionBeanPostProcessor
 
getRetention() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
getSerdeError() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
Deprecated.
getStateStoreKeySerde(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KeyValueSerdeResolver
Provide the Serde for state store.
getStateStoreRetry() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
 
getStateStoreValueSerde(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KeyValueSerdeResolver
Provide the Serde for state store value.
getStoppedKafkaStreams() - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBindingInformationCatalogue
Get all stopped KafkaStreams objects through actuator binding stop.
getStreamPartitionerBeanName() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsProducerProperties
 
getTimestampExtractorBeanName() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
getType() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
getValueSerde() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
getValueSerde() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsProducerProperties
 
getValueSerde(String, KafkaStreamsConsumerProperties, ResolvableType) - Method in class org.springframework.cloud.stream.binder.kafka.streams.AbstractKafkaStreamsBinderProcessor
 
getValueSerdeString() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
GlobalKTableBinder - Class in org.springframework.cloud.stream.binder.kafka.streams
An AbstractBinder implementation for GlobalKTable.
GlobalKTableBinder(KafkaStreamsBinderConfigurationProperties, KafkaTopicProvisioner, KafkaStreamsBindingInformationCatalogue, KafkaStreamsRegistry) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinder
 
GlobalKTableBinder(KafkaStreamsBinderConfigurationProperties, KafkaTopicProvisioner, KafkaStreamsExtendedBindingProperties, KafkaStreamsBindingInformationCatalogue, Map<String, Object>, KafkaStreamsRegistry) - Method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinderConfiguration
 
GlobalKTableBinderConfiguration - Class in org.springframework.cloud.stream.binder.kafka.streams
Configuration for GlobalKTable binder.
GlobalKTableBinderConfiguration() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinderConfiguration
 
globalKTableBoundElementFactory(BindingServiceProperties, EncodingDecodingBindAdviceHandler, KafkaStreamsBindingInformationCatalogue) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
GlobalKTableBoundElementFactory - Class in org.springframework.cloud.stream.binder.kafka.streams
BindingTargetFactory for GlobalKTable Input bindings are only created as output bindings on GlobalKTable are not allowed.
GlobalKTableBoundElementFactory.GlobalKTableWrapper - Interface in org.springframework.cloud.stream.binder.kafka.streams
Wrapper for GlobalKTable proxy.

H

handle(ProcessorContext, ConsumerRecord<byte[], byte[]>, Exception) - Method in class org.springframework.cloud.stream.binder.kafka.streams.SkipAndContinueExceptionHandler
 
handleKTableGlobalKTableInputs(Object[], int, String, Class<?>, Object, StreamsBuilderFactoryBean, StreamsBuilder, KafkaStreamsConsumerProperties, Serde<?>, Serde<?>, Topology.AutoOffsetReset, boolean) - Method in class org.springframework.cloud.stream.binder.kafka.streams.AbstractKafkaStreamsBinderProcessor
 

I

input() - Method in interface org.springframework.cloud.stream.binder.kafka.streams.annotations.KafkaStreamsProcessor
Input binding.
InteractiveQueryService - Class in org.springframework.cloud.stream.binder.kafka.streams
Services pertinent to the interactive query capabilities of Kafka Streams.
InteractiveQueryService(KafkaStreamsRegistry, KafkaStreamsBinderConfigurationProperties) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.InteractiveQueryService
Constructor for InteractiveQueryService.
interactiveQueryServices(KafkaStreamsRegistry, KafkaStreamsBinderConfigurationProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
isAutoStartup() - Method in class org.springframework.cloud.stream.binder.kafka.streams.StreamsBuilderFactoryManager
 
isCacheEnabled() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
isDecodingSettingProvided() - Method in class org.springframework.cloud.stream.binder.kafka.streams.EncodingDecodingBindAdviceHandler
 
isEncodingSettingProvided() - Method in class org.springframework.cloud.stream.binder.kafka.streams.EncodingDecodingBindAdviceHandler
 
isIncludeStoppedProcessorsForHealthCheck() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
 
isLoggingDisabled() - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
isRunning() - Method in class org.springframework.cloud.stream.binder.kafka.streams.StreamsBuilderFactoryManager
 

J

jaasInitializer(KafkaBinderConfigurationProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsJaasConfiguration
 

K

KafkaMicrometer() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfiguration.KafkaMicrometer
 
KafkaMicrometer() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfigurationWithMultiBinder.KafkaMicrometer
 
KafkaStreamsBindableProxyFactory - Class in org.springframework.cloud.stream.binder.kafka.streams.function
Kafka Streams specific target bindings proxy factory.
KafkaStreamsBindableProxyFactory(ResolvableType[], String, Method) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsBindableProxyFactory
 
KafkaStreamsBinderConfigurationProperties - Class in org.springframework.cloud.stream.binder.kafka.streams.properties
Kafka Streams binder configuration properties.
KafkaStreamsBinderConfigurationProperties(KafkaProperties) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
 
KafkaStreamsBinderConfigurationProperties.Functions - Class in org.springframework.cloud.stream.binder.kafka.streams.properties
 
KafkaStreamsBinderConfigurationProperties.SerdeError - Enum in org.springframework.cloud.stream.binder.kafka.streams.properties
Deprecated.
KafkaStreamsBinderConfigurationProperties.StateStoreRetry - Class in org.springframework.cloud.stream.binder.kafka.streams.properties
 
KafkaStreamsBinderEnvironmentPostProcessor - Class in org.springframework.cloud.stream.binder.kafka.streams
EnvironmentPostProcessor to ensure the sendToDlqAndContinue BiFunction is excluded in core Spring Cloud Function by adding it to the ineligible function definitions.
KafkaStreamsBinderEnvironmentPostProcessor() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderEnvironmentPostProcessor
 
kafkaStreamsBinderHealthIndicator(ObjectProvider<KafkaStreamsRegistry>, KafkaStreamsBinderConfigurationProperties, KafkaProperties, KafkaStreamsBindingInformationCatalogue) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderHealthIndicatorConfiguration
 
KafkaStreamsBinderHealthIndicator - Class in org.springframework.cloud.stream.binder.kafka.streams
Health indicator for Kafka Streams.
KafkaStreamsBinderHealthIndicatorConfiguration - Class in org.springframework.cloud.stream.binder.kafka.streams
Configuration class for Kafka-streams binder health indicator beans.
KafkaStreamsBinderHealthIndicatorConfiguration() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderHealthIndicatorConfiguration
 
kafkaStreamsBinderMetrics(MeterRegistry) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfiguration
 
kafkaStreamsBinderMetrics(ConfigurableApplicationContext) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfigurationWithMultiBinder
 
KafkaStreamsBinderMetrics - Class in org.springframework.cloud.stream.binder.kafka.streams
Kafka Streams binder metrics implementation that exports the metrics available through KafkaStreams.metrics() into a micrometer MeterRegistry.
KafkaStreamsBinderMetrics(MeterRegistry) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderMetrics
 
KafkaStreamsBinderMetricsConfiguration() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfiguration
 
KafkaStreamsBinderMetricsConfigurationWithMultiBinder() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfigurationWithMultiBinder
 
KafkaStreamsBinderSupportAutoConfiguration - Class in org.springframework.cloud.stream.binder.kafka.streams
Kafka Streams binder configuration.
KafkaStreamsBinderSupportAutoConfiguration() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfiguration - Class in org.springframework.cloud.stream.binder.kafka.streams
 
KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfiguration.KafkaMicrometer - Class in org.springframework.cloud.stream.binder.kafka.streams
 
KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfigurationWithMultiBinder - Class in org.springframework.cloud.stream.binder.kafka.streams
 
KafkaStreamsBinderSupportAutoConfiguration.KafkaStreamsBinderMetricsConfigurationWithMultiBinder.KafkaMicrometer - Class in org.springframework.cloud.stream.binder.kafka.streams
 
kafkaStreamsBindingInformationCatalogue() - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
KafkaStreamsBindingInformationCatalogue - Class in org.springframework.cloud.stream.binder.kafka.streams
A catalogue that provides binding information for Kafka Streams target types such as KStream.
KafkaStreamsBindingInformationCatalogue() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBindingInformationCatalogue
 
KafkaStreamsBindingProperties - Class in org.springframework.cloud.stream.binder.kafka.streams.properties
Extended binding properties holder that delegates to Kafka Streams producer and consumer properties.
KafkaStreamsBindingProperties() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBindingProperties
 
kafkaStreamsConfiguration(KafkaStreamsBinderConfigurationProperties, Environment) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
KafkaStreamsConsumerProperties - Class in org.springframework.cloud.stream.binder.kafka.streams.properties
Extended properties for Kafka Streams consumer.
KafkaStreamsConsumerProperties() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
KafkaStreamsExtendedBindingProperties - Class in org.springframework.cloud.stream.binder.kafka.streams.properties
Kafka streams specific extended binding properties class that extends from AbstractExtendedBindingProperties.
KafkaStreamsExtendedBindingProperties() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsExtendedBindingProperties
 
kafkaStreamsExtendedPropertiesDefaultMappingsProvider() - Method in class org.springframework.cloud.stream.binder.kafka.streams.ExtendedBindingHandlerMappingsProviderAutoConfiguration
 
KafkaStreamsFunctionAutoConfiguration - Class in org.springframework.cloud.stream.binder.kafka.streams.function
 
KafkaStreamsFunctionAutoConfiguration() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsFunctionAutoConfiguration
 
kafkaStreamsFunctionBeanPostProcessor(StreamFunctionProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsFunctionAutoConfiguration
 
KafkaStreamsFunctionBeanPostProcessor - Class in org.springframework.cloud.stream.binder.kafka.streams.function
 
KafkaStreamsFunctionBeanPostProcessor(StreamFunctionProperties) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsFunctionBeanPostProcessor
 
kafkaStreamsFunctionProcessor(BindingServiceProperties, KafkaStreamsExtendedBindingProperties, KeyValueSerdeResolver, KafkaStreamsBindingInformationCatalogue, KafkaStreamsMessageConversionDelegate, ObjectProvider<CleanupConfig>, StreamFunctionProperties, KafkaStreamsBinderConfigurationProperties, ObjectProvider<StreamsBuilderFactoryBeanConfigurer>, ConfigurableEnvironment) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
KafkaStreamsFunctionProcessor - Class in org.springframework.cloud.stream.binder.kafka.streams
 
KafkaStreamsFunctionProcessor(BindingServiceProperties, KafkaStreamsExtendedBindingProperties, KeyValueSerdeResolver, KafkaStreamsBindingInformationCatalogue, KafkaStreamsMessageConversionDelegate, CleanupConfig, StreamFunctionProperties, KafkaStreamsBinderConfigurationProperties, StreamsBuilderFactoryBeanConfigurer, ConfigurableEnvironment) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsFunctionProcessor
 
kafkaStreamsFunctionProcessorInvoker(KafkaStreamsFunctionBeanPostProcessor, KafkaStreamsFunctionProcessor, KafkaStreamsBindableProxyFactory[], StreamFunctionProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsFunctionAutoConfiguration
 
KafkaStreamsFunctionProcessorInvoker - Class in org.springframework.cloud.stream.binder.kafka.streams.function
 
KafkaStreamsFunctionProcessorInvoker(Map<String, ResolvableType>, KafkaStreamsFunctionProcessor, KafkaStreamsBindableProxyFactory[], Map<String, Method>, StreamFunctionProperties) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsFunctionProcessorInvoker
 
KafkaStreamsJaasConfiguration - Class in org.springframework.cloud.stream.binder.kafka.streams
Jaas configuration bean for Kafka Streams binder types.
KafkaStreamsJaasConfiguration() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsJaasConfiguration
 
KafkaStreamsMessageConversionDelegate - Class in org.springframework.cloud.stream.binder.kafka.streams
Delegate for handling all framework level message conversions inbound and outbound on KStream.
KafkaStreamsProcessor - Interface in org.springframework.cloud.stream.binder.kafka.streams.annotations
Bindable interface for KStream input and output.
KafkaStreamsProducerProperties - Class in org.springframework.cloud.stream.binder.kafka.streams.properties
Extended properties for Kafka Streams producer.
KafkaStreamsProducerProperties() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsProducerProperties
 
kafkaStreamsRegistry() - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
KafkaStreamsRegistry - Class in org.springframework.cloud.stream.binder.kafka.streams
An internal registry for holding KafkaStreams objects maintained through StreamsBuilderFactoryManager.
KafkaStreamsRegistry() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsRegistry
 
KafkaStreamsStateStore - Annotation Type in org.springframework.cloud.stream.binder.kafka.streams.annotations
Interface for Kafka Stream state store.
KafkaStreamsStateStoreProperties - Class in org.springframework.cloud.stream.binder.kafka.streams.properties
Properties for Kafka Streams state store.
KafkaStreamsStateStoreProperties() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
KafkaStreamsStateStoreProperties.StoreType - Enum in org.springframework.cloud.stream.binder.kafka.streams.properties
Enumeration for store type.
kafkaStreamsStreamListenerSetupMethodOrchestrator(BindingServiceProperties, KafkaStreamsExtendedBindingProperties, KeyValueSerdeResolver, KafkaStreamsBindingInformationCatalogue, KStreamStreamListenerParameterAdapter, Collection<StreamListenerResultAdapter>, ObjectProvider<CleanupConfig>, ObjectProvider<StreamsBuilderFactoryBeanConfigurer>, ConfigurableEnvironment) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
kafkaStreamsTopologies() - Method in class org.springframework.cloud.stream.binder.kafka.streams.endpoint.KafkaStreamsTopologyEndpoint
 
kafkaStreamsTopology(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.endpoint.KafkaStreamsTopologyEndpoint
 
KafkaStreamsTopologyEndpoint - Class in org.springframework.cloud.stream.binder.kafka.streams.endpoint
Actuator endpoint for topology description.
KafkaStreamsTopologyEndpoint(KafkaStreamsRegistry) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.endpoint.KafkaStreamsTopologyEndpoint
 
KafkaStreamsTopologyEndpointAutoConfiguration - Class in org.springframework.cloud.stream.binder.kafka.streams.endpoint
 
KafkaStreamsTopologyEndpointAutoConfiguration() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.endpoint.KafkaStreamsTopologyEndpointAutoConfiguration
 
keySerde() - Element in annotation type org.springframework.cloud.stream.binder.kafka.streams.annotations.KafkaStreamsStateStore
Serde used for key.
KEYVALUE - Enum constant in enum org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties.StoreType
Key value store.
keyValueSerdeResolver(Object, KafkaStreamsBinderConfigurationProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
KeyValueSerdeResolver - Class in org.springframework.cloud.stream.binder.kafka.streams
Resolver for key and value Serde.
kStreamBinder(KafkaStreamsBinderConfigurationProperties, KafkaTopicProvisioner, KafkaStreamsMessageConversionDelegate, KafkaStreamsBindingInformationCatalogue, KeyValueSerdeResolver, KafkaStreamsExtendedBindingProperties, KafkaStreamsRegistry) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KStreamBinderConfiguration
 
KStreamBinderConfiguration - Class in org.springframework.cloud.stream.binder.kafka.streams
Configuration for KStream binder.
KStreamBinderConfiguration() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KStreamBinderConfiguration
 
kStreamBoundElementFactory(BindingServiceProperties, KafkaStreamsBindingInformationCatalogue, EncodingDecodingBindAdviceHandler) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
kstreamStreamListenerParameterAdapter(KafkaStreamsMessageConversionDelegate, KafkaStreamsBindingInformationCatalogue) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
kstreamStreamListenerResultAdapter() - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
kTableBinder(KafkaStreamsBinderConfigurationProperties, KafkaTopicProvisioner, KafkaStreamsExtendedBindingProperties, KafkaStreamsBindingInformationCatalogue, Map<String, Object>, KafkaStreamsRegistry) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KTableBinderConfiguration
 
KTableBinderConfiguration - Class in org.springframework.cloud.stream.binder.kafka.streams
Configuration for KTable binder.
KTableBinderConfiguration() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.KTableBinderConfiguration
 
kTableBoundElementFactory(BindingServiceProperties, EncodingDecodingBindAdviceHandler, KafkaStreamsBindingInformationCatalogue) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 

L

lengthMs() - Element in annotation type org.springframework.cloud.stream.binder.kafka.streams.annotations.KafkaStreamsStateStore
Length in milli-second of Windowed store window.
logAndContinue - Enum constant in enum org.springframework.cloud.stream.binder.kafka.streams.DeserializationExceptionHandler
Deserialization error handler with log and continue.
logAndContinue - Enum constant in enum org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.SerdeError
Deprecated.
Deserialization error handler with log and continue.
logAndFail - Enum constant in enum org.springframework.cloud.stream.binder.kafka.streams.DeserializationExceptionHandler
Deserialization error handler with log and fail.
logAndFail - Enum constant in enum org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.SerdeError
Deprecated.
Deserialization error handler with log and fail.
logging() - Element in annotation type org.springframework.cloud.stream.binder.kafka.streams.annotations.KafkaStreamsStateStore
Whether logging is enabled or not.

M

messageConversionDelegate(CompositeMessageConverter, SendToDlqAndContinue, KafkaStreamsBindingInformationCatalogue, KafkaStreamsBinderConfigurationProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
messageConverterDelegateSerde(CompositeMessageConverter) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
MessageConverterDelegateSerde<T> - Class in org.springframework.cloud.stream.binder.kafka.streams.serde
Deprecated.
in favor of other schema registry providers instead of Spring Cloud Schema Registry. See its motivation above.
MessageConverterDelegateSerde(CompositeMessageConverter) - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.serde.MessageConverterDelegateSerde
Deprecated.
 
MultiBinderPropertiesConfiguration - Class in org.springframework.cloud.stream.binder.kafka.streams
 
MultiBinderPropertiesConfiguration() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.MultiBinderPropertiesConfiguration
 

N

name() - Element in annotation type org.springframework.cloud.stream.binder.kafka.streams.annotations.KafkaStreamsStateStore
Provides name of the state store.
NO_TOPOLOGY_FOUND_MSG - Static variable in class org.springframework.cloud.stream.binder.kafka.streams.endpoint.KafkaStreamsTopologyEndpoint
Topology not found message.

O

org.springframework.cloud.stream.binder.kafka.streams - package org.springframework.cloud.stream.binder.kafka.streams
 
org.springframework.cloud.stream.binder.kafka.streams.annotations - package org.springframework.cloud.stream.binder.kafka.streams.annotations
 
org.springframework.cloud.stream.binder.kafka.streams.endpoint - package org.springframework.cloud.stream.binder.kafka.streams.endpoint
 
org.springframework.cloud.stream.binder.kafka.streams.function - package org.springframework.cloud.stream.binder.kafka.streams.function
 
org.springframework.cloud.stream.binder.kafka.streams.properties - package org.springframework.cloud.stream.binder.kafka.streams.properties
 
org.springframework.cloud.stream.binder.kafka.streams.serde - package org.springframework.cloud.stream.binder.kafka.streams.serde
 
outerContextBeanFactoryPostProcessor() - Static method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinderConfiguration
 
outerContextBeanFactoryPostProcessor() - Static method in class org.springframework.cloud.stream.binder.kafka.streams.KStreamBinderConfiguration
 
outerContextBeanFactoryPostProcessor() - Static method in class org.springframework.cloud.stream.binder.kafka.streams.KTableBinderConfiguration
 
output() - Method in interface org.springframework.cloud.stream.binder.kafka.streams.annotations.KafkaStreamsProcessor
Output binding.

P

postProcessEnvironment(ConfigurableEnvironment, SpringApplication) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderEnvironmentPostProcessor
 
provisioningProvider(KafkaStreamsBinderConfigurationProperties, KafkaProperties, ObjectProvider<AdminClientConfigCustomizer>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinderConfiguration
 
provisioningProvider(KafkaStreamsBinderConfigurationProperties, KafkaProperties, ObjectProvider<AdminClientConfigCustomizer>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KStreamBinderConfiguration
 
provisioningProvider(KafkaStreamsBinderConfigurationProperties, KafkaProperties, ObjectProvider<AdminClientConfigCustomizer>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KTableBinderConfiguration
 

R

removePreviousKafkaStreamsForApplicationId(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBindingInformationCatalogue
Remove the previously cached KafkaStreams object.
retentionMs() - Element in annotation type org.springframework.cloud.stream.binder.kafka.streams.annotations.KafkaStreamsStateStore
Retention period for Windowed store windows.

S

sendToDlq - Enum constant in enum org.springframework.cloud.stream.binder.kafka.streams.DeserializationExceptionHandler
Deserialization error handler with DLQ send.
sendToDlq - Enum constant in enum org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.SerdeError
Deprecated.
Deserialization error handler with DLQ send.
sendToDlq(ConsumerRecord<?, ?>, Exception) - Method in class org.springframework.cloud.stream.binder.kafka.streams.SendToDlqAndContinue
For a given topic, send the key/value record to DLQ topic.
sendToDlqAndContinue() - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
SendToDlqAndContinue - Class in org.springframework.cloud.stream.binder.kafka.streams
Custom implementation for ConsumerRecordRecoverer that keeps a collection of recoverer objects per input topics.
SendToDlqAndContinue() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.SendToDlqAndContinue
 
serializeOnOutbound(KStream<?, ?>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsMessageConversionDelegate
Serialize KStream records on outbound based on contentType.
serializer() - Method in class org.springframework.cloud.stream.binder.kafka.streams.serde.CollectionSerde
 
serializer() - Method in class org.springframework.cloud.stream.binder.kafka.streams.serde.MessageConverterDelegateSerde
Deprecated.
 
SESSION - Enum constant in enum org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties.StoreType
Session store.
setApplicationContext(ApplicationContext) - Method in class org.springframework.cloud.stream.binder.kafka.streams.AbstractKafkaStreamsBinderProcessor
 
setApplicationContext(ApplicationContext) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KeyValueSerdeResolver
 
setApplicationId(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.Functions
 
setApplicationId(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
 
setApplicationId(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
setBackoffPeriod(long) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.StateStoreRetry
 
setBeanFactory(BeanFactory) - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsBindableProxyFactory
 
setBeanFactory(BeanFactory) - Method in class org.springframework.cloud.stream.binder.kafka.streams.function.KafkaStreamsFunctionBeanPostProcessor
 
setBeanFactory(BeanFactory) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsFunctionProcessor
 
setCacheEnabled(boolean) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
setConfiguration(Map<String, String>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.Functions
 
setConsumedAs(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
setConsumer(KafkaStreamsConsumerProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBindingProperties
 
setDeserializationExceptionHandler(DeserializationExceptionHandler) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
 
setDeserializationExceptionHandler(DeserializationExceptionHandler) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
setEventTypeHeaderKey(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
setEventTypes(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
setFunctions(Map<String, KafkaStreamsBinderConfigurationProperties.Functions>) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
 
setIncludeStoppedProcessorsForHealthCheck(boolean) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
 
setKafkaStreamsExtendedBindingProperties(KafkaStreamsExtendedBindingProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBinder
 
setKeySerde(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
setKeySerde(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsProducerProperties
 
setKeySerdeString(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
setLength(long) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
setLoggingDisabled(boolean) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
setMaterializedAs(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
setMaxAttempts(int) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.StateStoreRetry
 
setName(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
setProducedAs(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsProducerProperties
 
setProducer(KafkaStreamsProducerProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBindingProperties
 
setRetention(long) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
setSerdeError(KafkaStreamsBinderConfigurationProperties.SerdeError) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
Deprecated.
setStateStoreRetry(KafkaStreamsBinderConfigurationProperties.StateStoreRetry) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties
 
setStreamPartitionerBeanName(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsProducerProperties
 
setTimestampExtractorBeanName(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
setType(KafkaStreamsStateStoreProperties.StoreType) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
setupFunctionInvokerForKafkaStreams(ResolvableType, String, KafkaStreamsBindableProxyFactory, Method, ResolvableType, String...) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsFunctionProcessor
This method must be kept stateless.
setValueSerde(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsConsumerProperties
 
setValueSerde(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsProducerProperties
 
setValueSerdeString(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties
 
skipAndContinue - Enum constant in enum org.springframework.cloud.stream.binder.kafka.streams.DeserializationExceptionHandler
Deserialization error handler that silently skips the error and continue.
SkipAndContinueExceptionHandler - Class in org.springframework.cloud.stream.binder.kafka.streams
DeserializationExceptionHandler that allows to silently skip deserialization exceptions and continue processing.
SkipAndContinueExceptionHandler() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.SkipAndContinueExceptionHandler
 
start() - Method in class org.springframework.cloud.stream.binder.kafka.streams.StreamsBuilderFactoryManager
 
StateStoreRetry() - Constructor for class org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.StateStoreRetry
 
stop() - Method in class org.springframework.cloud.stream.binder.kafka.streams.StreamsBuilderFactoryManager
 
stop(Runnable) - Method in class org.springframework.cloud.stream.binder.kafka.streams.StreamsBuilderFactoryManager
 
streamConfigGlobalProperties(KafkaStreamsBinderConfigurationProperties, KafkaStreamsConfiguration, ConfigurableEnvironment, SendToDlqAndContinue) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
streamsBuilderFactoryBean(String) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsRegistry
 
streamsBuilderFactoryBeans() - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsRegistry
 
streamsBuilderFactoryManager(KafkaStreamsBindingInformationCatalogue, KafkaStreamsRegistry, KafkaStreamsBinderMetrics, KafkaStreamsMicrometerListener, KafkaProperties) - Method in class org.springframework.cloud.stream.binder.kafka.streams.KafkaStreamsBinderSupportAutoConfiguration
 
StreamsBuilderFactoryManager - Class in org.springframework.cloud.stream.binder.kafka.streams
Iterate through all StreamsBuilderFactoryBean in the application context and start them.

T

topologyEndpoint(KafkaStreamsRegistry) - Method in class org.springframework.cloud.stream.binder.kafka.streams.endpoint.KafkaStreamsTopologyEndpointAutoConfiguration
 
toString() - Method in enum org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties.StoreType
 
type() - Element in annotation type org.springframework.cloud.stream.binder.kafka.streams.annotations.KafkaStreamsStateStore
State store type.

V

valueOf(String) - Static method in enum org.springframework.cloud.stream.binder.kafka.streams.DeserializationExceptionHandler
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.SerdeError
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties.StoreType
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.springframework.cloud.stream.binder.kafka.streams.DeserializationExceptionHandler
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsBinderConfigurationProperties.SerdeError
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties.StoreType
Returns an array containing the constants of this enum type, in the order they are declared.
valueSerde() - Element in annotation type org.springframework.cloud.stream.binder.kafka.streams.annotations.KafkaStreamsStateStore
Serde used for value.

W

WINDOW - Enum constant in enum org.springframework.cloud.stream.binder.kafka.streams.properties.KafkaStreamsStateStoreProperties.StoreType
Window store.
wrap(GlobalKTable<Object, Object>) - Method in interface org.springframework.cloud.stream.binder.kafka.streams.GlobalKTableBoundElementFactory.GlobalKTableWrapper
 
A B C D E F G H I J K L M N O P R S T V W 
All Classes and Interfaces|All Packages|Constant Field Values