A B C D E F G H I K L M N O P R S T U V 
All Classes All Packages

A

AbstractCommitManager - Class in org.apache.camel.component.kafka.consumer
 
AbstractCommitManager(Consumer<?, ?>, KafkaConsumer, String, String) - Constructor for class org.apache.camel.component.kafka.consumer.AbstractCommitManager
 
add(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
addHealthCheck(HealthCheck) - Method in class org.apache.camel.component.kafka.KafkaHealthCheckRepository
 
afterConsume(Object) - Method in class org.apache.camel.component.kafka.consumer.errorhandler.KafkaConsumerListener
 
afterProcess(ProcessingResult) - Method in class org.apache.camel.component.kafka.consumer.errorhandler.KafkaConsumerListener
 
allSent() - Method in class org.apache.camel.component.kafka.producer.support.KafkaProducerCallBack
 
AsyncCommitManager - Class in org.apache.camel.component.kafka.consumer
 
AsyncCommitManager(Consumer<?, ?>, KafkaConsumer, String, String) - Constructor for class org.apache.camel.component.kafka.consumer.AsyncCommitManager
 

B

BEGINNING - org.apache.camel.component.kafka.SeekPolicy
 
BridgeErrorStrategy - Class in org.apache.camel.component.kafka.consumer.errorhandler
 
BridgeErrorStrategy(KafkaFetchRecords, Consumer<?, ?>) - Constructor for class org.apache.camel.component.kafka.consumer.errorhandler.BridgeErrorStrategy
 
build() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
buildStateMessage() - Method in class org.apache.camel.component.kafka.TaskHealthState
 
buildUri(String, Map<String, Object>, boolean) - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
 

C

camelExchangePayload - Variable in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
 
CamelExchangePayload(Exchange, Consumer<?, ?>, String, StateRepository<String, String>) - Constructor for class org.apache.camel.component.kafka.consumer.KafkaManualCommitFactory.CamelExchangePayload
 
canContinue() - Method in class org.apache.camel.component.kafka.consumer.errorhandler.BridgeErrorStrategy
 
canContinue() - Method in class org.apache.camel.component.kafka.consumer.errorhandler.DiscardErrorStrategy
 
canContinue() - Method in class org.apache.camel.component.kafka.consumer.errorhandler.ReconnectErrorStrategy
 
canContinue() - Method in class org.apache.camel.component.kafka.consumer.errorhandler.RetryErrorStrategy
 
canContinue() - Method in class org.apache.camel.component.kafka.consumer.errorhandler.StopErrorStrategy
 
canContinue() - Method in interface org.apache.camel.component.kafka.PollExceptionStrategy
This method provides an "answer" to whether the consumer can continue polling or not.
checkAndSubscribe(String) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Subscribe to the topic if not subscribed yet
checkAndSubscribe(String, long) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Subscribe to the topic if not subscribed yet
clear() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
close() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
commit() - Method in class org.apache.camel.component.kafka.consumer.AsyncCommitManager
 
commit() - Method in interface org.apache.camel.component.kafka.consumer.CommitManager
Commits everything that has been cached
commit() - Method in class org.apache.camel.component.kafka.consumer.CommitToOffsetManager
 
commit() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualAsyncCommit
 
commit() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualSyncCommit
 
commit() - Method in interface org.apache.camel.component.kafka.consumer.KafkaManualCommit
Commit synchronously or asynchronously depending on the implementation.
commit() - Method in class org.apache.camel.component.kafka.consumer.NoopCommitManager
 
commit() - Method in class org.apache.camel.component.kafka.consumer.SyncCommitManager
 
commit(TopicPartition) - Method in class org.apache.camel.component.kafka.consumer.AsyncCommitManager
 
commit(TopicPartition) - Method in interface org.apache.camel.component.kafka.consumer.CommitManager
Commits the offsets of the given partition
commit(TopicPartition) - Method in class org.apache.camel.component.kafka.consumer.CommitToOffsetManager
 
commit(TopicPartition) - Method in class org.apache.camel.component.kafka.consumer.NoopCommitManager
 
commit(TopicPartition) - Method in class org.apache.camel.component.kafka.consumer.SyncCommitManager
 
CommitManager - Interface in org.apache.camel.component.kafka.consumer
 
CommitManagers - Class in org.apache.camel.component.kafka.consumer
 
commitTimeout - Variable in class org.apache.camel.component.kafka.consumer.KafkaManualCommitFactory.KafkaRecordPayload
 
CommitToOffsetManager - Class in org.apache.camel.component.kafka.consumer
 
CommitToOffsetManager(Consumer<?, ?>, KafkaConsumer, String, String) - Constructor for class org.apache.camel.component.kafka.consumer.CommitToOffsetManager
 
configuration - Variable in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.component.kafka.KafkaComponentConfigurer
 
configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.component.kafka.KafkaEndpointConfigurer
 
confirm(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
consume() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Consumes message from the topic previously setup
consume(int) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Consumes message from the topic previously setup
consumer - Variable in class org.apache.camel.component.kafka.consumer.KafkaManualCommitFactory.CamelExchangePayload
 
contains(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
copy() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Returns a copy of this configuration
createCommitManager(Consumer<?, ?>, KafkaConsumer, String, String) - Static method in class org.apache.camel.component.kafka.consumer.CommitManagers
 
createConsumer() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
 
createConsumer(String) - Static method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Creates a basic string-based consumer
createConsumer(Processor) - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
createConsumerProperties() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
createEndpoint(String, String, Map<String, Object>) - Method in class org.apache.camel.component.kafka.KafkaComponent
 
createExecutor() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
createKeyValueHolder(Exchange, Message) - Method in class org.apache.camel.component.kafka.KafkaProducer
 
createPostProcessor(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
 
createPreProcessor(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
 
createProducer() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
createProducer(String) - Static method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Creates a basic string-based producer
createProducer(KafkaEndpoint) - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
createProducerExecutor() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
createProducerProperties() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
createRecord(Exchange, Message) - Method in class org.apache.camel.component.kafka.KafkaProducer
 
createRecordIterable(Exchange, Message) - Method in class org.apache.camel.component.kafka.KafkaProducer
 

D

DefaultKafkaClientFactory - Class in org.apache.camel.component.kafka
 
DefaultKafkaClientFactory() - Constructor for class org.apache.camel.component.kafka.DefaultKafkaClientFactory
 
DefaultKafkaHeaderDeserializer - Class in org.apache.camel.component.kafka.serde
 
DefaultKafkaHeaderDeserializer() - Constructor for class org.apache.camel.component.kafka.serde.DefaultKafkaHeaderDeserializer
 
DefaultKafkaHeaderSerializer - Class in org.apache.camel.component.kafka.serde
 
DefaultKafkaHeaderSerializer() - Constructor for class org.apache.camel.component.kafka.serde.DefaultKafkaHeaderSerializer
 
DefaultKafkaManualAsyncCommit - Class in org.apache.camel.component.kafka.consumer
 
DefaultKafkaManualAsyncCommit(KafkaManualCommitFactory.CamelExchangePayload, KafkaManualCommitFactory.KafkaRecordPayload, CommitManager) - Constructor for class org.apache.camel.component.kafka.consumer.DefaultKafkaManualAsyncCommit
 
DefaultKafkaManualAsyncCommitFactory - Class in org.apache.camel.component.kafka.consumer
 
DefaultKafkaManualAsyncCommitFactory() - Constructor for class org.apache.camel.component.kafka.consumer.DefaultKafkaManualAsyncCommitFactory
 
DefaultKafkaManualCommit - Class in org.apache.camel.component.kafka.consumer
 
DefaultKafkaManualCommit(KafkaManualCommitFactory.CamelExchangePayload, KafkaManualCommitFactory.KafkaRecordPayload) - Constructor for class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
 
DefaultKafkaManualCommitFactory - Class in org.apache.camel.component.kafka.consumer
 
DefaultKafkaManualCommitFactory() - Constructor for class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommitFactory
 
DefaultKafkaManualSyncCommit - Class in org.apache.camel.component.kafka.consumer
 
DefaultKafkaManualSyncCommit(KafkaManualCommitFactory.CamelExchangePayload, KafkaManualCommitFactory.KafkaRecordPayload, CommitManager) - Constructor for class org.apache.camel.component.kafka.consumer.DefaultKafkaManualSyncCommit
 
DelegatingCallback - Class in org.apache.camel.component.kafka.producer.support
 
DelegatingCallback(Callback, Callback) - Constructor for class org.apache.camel.component.kafka.producer.support.DelegatingCallback
 
deserialize(String, byte[]) - Method in class org.apache.camel.component.kafka.serde.DefaultKafkaHeaderDeserializer
 
deserialize(String, byte[]) - Method in interface org.apache.camel.component.kafka.serde.KafkaHeaderDeserializer
 
deserializeOffsetValue(String) - Static method in class org.apache.camel.component.kafka.consumer.support.KafkaRecordProcessor
 
DISCARD - org.apache.camel.component.kafka.PollOnError
 
DiscardErrorStrategy - Class in org.apache.camel.component.kafka.consumer.errorhandler
 
DiscardErrorStrategy(Consumer<?, ?>) - Constructor for class org.apache.camel.component.kafka.consumer.errorhandler.DiscardErrorStrategy
 
doBuild() - Method in class org.apache.camel.component.kafka.KafkaConsumer
 
doBuild() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
doCall(HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.component.kafka.KafkaConsumerHealthCheck
 
doCall(HealthCheckResultBuilder, Map<String, Object>) - Method in class org.apache.camel.component.kafka.KafkaProducerHealthCheck
 
doInit() - Method in class org.apache.camel.component.kafka.KafkaComponent
 
doResume() - Method in class org.apache.camel.component.kafka.KafkaConsumer
 
doStart() - Method in class org.apache.camel.component.kafka.KafkaConsumer
 
doStart() - Method in class org.apache.camel.component.kafka.KafkaProducer
 
doStart() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
doStop() - Method in class org.apache.camel.component.kafka.KafkaConsumer
 
doStop() - Method in class org.apache.camel.component.kafka.KafkaProducer
 
doStop() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
doSuspend() - Method in class org.apache.camel.component.kafka.KafkaConsumer
 

E

END - org.apache.camel.component.kafka.SeekPolicy
 
ERROR_HANDLER - org.apache.camel.component.kafka.PollOnError
 
exchange - Variable in class org.apache.camel.component.kafka.consumer.KafkaManualCommitFactory.CamelExchangePayload
 
executor - Variable in class org.apache.camel.component.kafka.KafkaConsumer
 

F

forceCommit(TopicPartition, long) - Method in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
 
forceCommit(TopicPartition, long) - Method in interface org.apache.camel.component.kafka.consumer.CommitManager
Forcefully commits the offset of the given partition
forceCommit(TopicPartition, long) - Method in class org.apache.camel.component.kafka.consumer.CommitToOffsetManager
 

G

getAdapter() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
getAdditionalProperties() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getAddressable() - Method in class org.apache.camel.component.kafka.consumer.support.KafkaResumable
 
getAutoCommitEnable() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getAutoCommitIntervalMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getAutoOffsetReset() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getAutowiredNames() - Method in class org.apache.camel.component.kafka.KafkaComponentConfigurer
 
getBootstrapServers() - Method in class org.apache.camel.component.kafka.TaskHealthState
 
getBootstrapServers() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
getBridge() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
 
getBrokers() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getBrokers(KafkaConfiguration) - Method in class org.apache.camel.component.kafka.DefaultKafkaClientFactory
 
getBrokers(KafkaConfiguration) - Method in interface org.apache.camel.component.kafka.KafkaClientFactory
URL of the Kafka brokers to use.
getBufferMemorySize() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getCamelContext() - Method in class org.apache.camel.component.kafka.KafkaHealthCheckRepository
 
getCamelContext() - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
 
getCamelContext() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
getCamelExchangePayload() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
Gets the Camel Exchange payload
getCheckCrcs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getClientId() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getClientId() - Method in class org.apache.camel.component.kafka.TaskHealthState
 
getCollectionValueType(Object, String, boolean) - Method in class org.apache.camel.component.kafka.KafkaComponentConfigurer
 
getCollectionValueType(Object, String, boolean) - Method in class org.apache.camel.component.kafka.KafkaEndpointConfigurer
 
getCommitTimeout() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
 
getCommitTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getComponent() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
getCompressionCodec() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getConfiguration() - Method in class org.apache.camel.component.kafka.KafkaComponent
 
getConfiguration() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
getConnectionMaxIdleMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getConsumer() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
getConsumer() - Method in class org.apache.camel.component.kafka.consumer.errorhandler.KafkaConsumerListener
 
getConsumer() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
getConsumer(Properties) - Method in class org.apache.camel.component.kafka.DefaultKafkaClientFactory
 
getConsumer(Properties) - Method in interface org.apache.camel.component.kafka.KafkaClientFactory
Creates a new instance of the Kafka Consumer class.
getConsumerConfig() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
getConsumerConfig() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
getConsumerListener() - Method in class org.apache.camel.component.kafka.KafkaConsumer
 
getConsumerRebalanceListener(long) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Creates a new consumer rebalance listener.
getConsumerRequestTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getConsumersCount() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getCreateConsumerBackoffInterval() - Method in class org.apache.camel.component.kafka.KafkaComponent
 
getCreateConsumerBackoffMaxAttempts() - Method in class org.apache.camel.component.kafka.KafkaComponent
 
getCurrentBackoffInterval() - Method in class org.apache.camel.component.kafka.TaskHealthState
 
getDeliveryTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getDuplicateCount() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
getEndpoint() - Method in class org.apache.camel.component.kafka.KafkaConsumer
 
getEndpoint() - Method in class org.apache.camel.component.kafka.KafkaProducer
 
getException() - Method in class org.apache.camel.processor.resume.kafka.RecordError
 
getFetchMaxBytes() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The maximum amount of data the server should return for a fetch request This is not an absolute maximum, if the first message in the first non-empty partition of the fetch is larger than this value, the message will still be returned to ensure that the consumer can make progress.
getFetchMinBytes() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getFetchWaitMaxMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getGroupId() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getGroupId() - Method in class org.apache.camel.component.kafka.TaskHealthState
 
getGroupInstanceId() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getHeaderDeserializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getHeaderFilterStrategy() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getHeaderSerializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getHeartbeatIntervalMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getId() - Method in class org.apache.camel.component.kafka.KafkaHealthCheckRepository
 
getInterceptorClasses() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getIsolationLevel() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getKafkaClientFactory() - Method in class org.apache.camel.component.kafka.KafkaComponent
 
getKafkaClientFactory() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
getKafkaManualCommitFactory() - Method in class org.apache.camel.component.kafka.KafkaComponent
 
getKafkaManualCommitFactory() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
getKafkaProducer() - Method in class org.apache.camel.component.kafka.KafkaProducer
 
getKafkaRecordPayload() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
Gets the Kafka record payload
getKerberosBeforeReloginMinTime() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getKerberosInitCmd() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getKerberosPrincipalToLocalRules() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getKerberosRenewJitter() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getKerberosRenewWindowFactor() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getKey() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getKeyDeserializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getKeySerializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getLastError() - Method in class org.apache.camel.component.kafka.TaskHealthState
 
getLastOffset() - Method in class org.apache.camel.component.kafka.consumer.support.KafkaResumable
 
getLingerMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getManualCommit(Exchange, TopicPartition, ConsumerRecord<Object, Object>) - Method in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
 
getManualCommit(Exchange, TopicPartition, ConsumerRecord<Object, Object>) - Method in class org.apache.camel.component.kafka.consumer.AsyncCommitManager
 
getManualCommit(Exchange, TopicPartition, ConsumerRecord<Object, Object>) - Method in interface org.apache.camel.component.kafka.consumer.CommitManager
 
getManualCommit(Exchange, TopicPartition, ConsumerRecord<Object, Object>, KafkaManualCommitFactory) - Method in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
 
getMaxBlockMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getMaxCacheSize() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
getMaxInFlightRequest() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getMaxPartitionFetchBytes() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getMaxPollIntervalMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getMaxPollRecords() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getMaxRequestSize() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getMetadataMaxAgeMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getMetricReporters() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getMetricsSampleWindowMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getNoOfMetricsSample() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getOffsetRepository() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
Deprecated.
getOffsetRepository() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getOptionType(String, boolean) - Method in class org.apache.camel.component.kafka.KafkaComponentConfigurer
 
getOptionType(String, boolean) - Method in class org.apache.camel.component.kafka.KafkaEndpointConfigurer
 
getOptionValue(Object, String, boolean) - Method in class org.apache.camel.component.kafka.KafkaComponentConfigurer
 
getOptionValue(Object, String, boolean) - Method in class org.apache.camel.component.kafka.KafkaEndpointConfigurer
 
getPartition() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
 
getPartitionAssignor() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getPartitioner() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getPartitionKey() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getPartitionLastOffset() - Method in class org.apache.camel.component.kafka.consumer.support.ProcessingResult
 
getPollDuration() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
getPollDurationMs() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
getPollExceptionStrategy() - Method in class org.apache.camel.component.kafka.KafkaComponent
 
getPollOnError() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getPollTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getProducer() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
getProducer(Properties) - Method in class org.apache.camel.component.kafka.DefaultKafkaClientFactory
 
getProducer(Properties) - Method in interface org.apache.camel.component.kafka.KafkaClientFactory
Creates a new instance of the Kafka Producer class.
getProducerBatchSize() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getProducerConfig() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
getProducerConfig() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
getProducerErrors() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Gets the set record of sent items
getQueueBufferingMaxMessages() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getReceiveBufferBytes() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getReconnectBackoffMaxMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getReconnectBackoffMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getRecordMetadata() - Method in class org.apache.camel.processor.resume.kafka.RecordError
 
getRecordOffset() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
 
getRequestRequiredAcks() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getRequestTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getResumeCache() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
getResumeStrategy() - Method in class org.apache.camel.component.kafka.KafkaConsumer
 
getRetries() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getRetryBackoffMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSaslJaasConfig() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSaslKerberosServiceName() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSaslMechanism() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSchemaRegistryURL() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getScheme() - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
 
getSecurityProtocol() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSeekPolicy() - Method in class org.apache.camel.component.kafka.consumer.errorhandler.KafkaConsumerListener
 
getSeekTo() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSendBufferBytes() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSessionTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getShutdownTimeout() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslCipherSuites() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslContextParameters() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslEnabledProtocols() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslEndpointAlgorithm() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslKeymanagerAlgorithm() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslKeyPassword() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslKeystoreLocation() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslKeystorePassword() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslKeystoreType() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslProtocol() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslProvider() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslTrustmanagerAlgorithm() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslTruststoreLocation() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslTruststorePassword() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSslTruststoreType() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getSubscribeConsumerBackoffInterval() - Method in class org.apache.camel.component.kafka.KafkaComponent
 
getSubscribeConsumerBackoffMaxAttempts() - Method in class org.apache.camel.component.kafka.KafkaComponent
 
getThreadId() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
 
getTopic() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getTopic() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
getTopic() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
getTopicName() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
 
getValueDeserializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getValueSerializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getWorkerPool() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getWorkerPool() - Method in class org.apache.camel.component.kafka.KafkaProducer
 
getWorkerPoolCoreSize() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
getWorkerPoolMaxSize() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 

H

handle(long, Exception) - Method in class org.apache.camel.component.kafka.consumer.errorhandler.BridgeErrorStrategy
 
handle(long, Exception) - Method in class org.apache.camel.component.kafka.consumer.errorhandler.DiscardErrorStrategy
 
handle(long, Exception) - Method in class org.apache.camel.component.kafka.consumer.errorhandler.ReconnectErrorStrategy
 
handle(long, Exception) - Method in class org.apache.camel.component.kafka.consumer.errorhandler.RetryErrorStrategy
 
handle(long, Exception) - Method in class org.apache.camel.component.kafka.consumer.errorhandler.StopErrorStrategy
 
handle(long, Exception) - Method in interface org.apache.camel.component.kafka.PollExceptionStrategy
Controls how to handle the exception while polling from Kafka.
hasNext() - Method in class org.apache.camel.component.kafka.producer.support.KeyValueHolderIterator
 
HEADERS - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
healthState() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
 
healthStates() - Method in class org.apache.camel.component.kafka.KafkaConsumer
 

I

increment() - Method in class org.apache.camel.component.kafka.producer.support.KafkaProducerCallBack
 
init() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
initialize() - Method in class org.apache.camel.component.kafka.KafkaHeaderFilterStrategy
 
isAllowManualCommit() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
isAutoCommitEnable() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
isBreakOnErrorHit() - Method in class org.apache.camel.component.kafka.consumer.support.ProcessingResult
 
isBreakOnFirstError() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
isConnected() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
 
isEnabled() - Method in class org.apache.camel.component.kafka.KafkaHealthCheckRepository
 
isEnabled(String) - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
 
isEnableIdempotence() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
isFailed() - Method in class org.apache.camel.component.kafka.consumer.support.ProcessingResult
 
isLenientProperties() - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
 
isLenientProperties() - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
 
isLiveness() - Method in class org.apache.camel.component.kafka.KafkaConsumerHealthCheck
 
isLiveness() - Method in class org.apache.camel.component.kafka.KafkaProducerHealthCheck
 
isMultipleConsumersSupported() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
isPaused() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
 
isPollerRunning() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
isReady() - Method in class org.apache.camel.component.kafka.KafkaProducer
 
isReady() - Method in class org.apache.camel.component.kafka.TaskHealthState
 
isRecordMetadata() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
isRecoverable() - Method in class org.apache.camel.component.kafka.TaskHealthState
 
isSpecificAvroReader() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
isSynchronous() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
isTerminated() - Method in class org.apache.camel.component.kafka.TaskHealthState
 
isTopicIsPattern() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
isUseGlobalSslContextParameters() - Method in class org.apache.camel.component.kafka.KafkaComponent
 

K

KAFKA_DEFAULT_DESERIALIZER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
KAFKA_DEFAULT_ENCODER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
Deprecated.
KAFKA_DEFAULT_PARTITIONER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
KAFKA_DEFAULT_SERIALIZER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
KAFKA_RECORDMETA - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
KAFKA_STRING_ENCODER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
Deprecated.
KafkaAsyncManualCommit - Interface in org.apache.camel.component.kafka.consumer
Can be used for forcing async manual offset commit when using Kafka consumer.
KafkaClientFactory - Interface in org.apache.camel.component.kafka
Factory to create a new Kafka Consumer and Kafka Producer instances.
KafkaComponent - Class in org.apache.camel.component.kafka
 
KafkaComponent() - Constructor for class org.apache.camel.component.kafka.KafkaComponent
 
KafkaComponent(CamelContext) - Constructor for class org.apache.camel.component.kafka.KafkaComponent
 
KafkaComponentConfigurer - Class in org.apache.camel.component.kafka
Generated by camel build tools - do NOT edit this file!
KafkaComponentConfigurer() - Constructor for class org.apache.camel.component.kafka.KafkaComponentConfigurer
 
KafkaConfiguration - Class in org.apache.camel.component.kafka
 
KafkaConfiguration() - Constructor for class org.apache.camel.component.kafka.KafkaConfiguration
 
KafkaConstants - Class in org.apache.camel.component.kafka
 
kafkaConsumer - Variable in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
 
KafkaConsumer - Class in org.apache.camel.component.kafka
 
KafkaConsumer(KafkaEndpoint, Processor) - Constructor for class org.apache.camel.component.kafka.KafkaConsumer
 
KafkaConsumerFatalException - Exception in org.apache.camel.component.kafka
A fatal exception such as the kafka consumer is not able to be created and/or subscribed to the kafka brokers within a given backoff period, leading to camel-kafka giving up and terminating the kafka consumer thread, meaning that the kafka consumer will not try to recover.
KafkaConsumerFatalException(String, Throwable) - Constructor for exception org.apache.camel.component.kafka.KafkaConsumerFatalException
 
KafkaConsumerHealthCheck - Class in org.apache.camel.component.kafka
Kafka consumer readiness health-check
KafkaConsumerHealthCheck(KafkaConsumer, String) - Constructor for class org.apache.camel.component.kafka.KafkaConsumerHealthCheck
 
KafkaConsumerListener - Class in org.apache.camel.component.kafka.consumer.errorhandler
 
KafkaConsumerListener() - Constructor for class org.apache.camel.component.kafka.consumer.errorhandler.KafkaConsumerListener
 
KafkaConsumerResumeAdapter - Interface in org.apache.camel.component.kafka.consumer.support
Defines a adapters for handling resume operations.
KafkaEndpoint - Class in org.apache.camel.component.kafka
Sent and receive messages to/from an Apache Kafka broker.
KafkaEndpoint() - Constructor for class org.apache.camel.component.kafka.KafkaEndpoint
 
KafkaEndpoint(String, KafkaComponent) - Constructor for class org.apache.camel.component.kafka.KafkaEndpoint
 
KafkaEndpointConfigurer - Class in org.apache.camel.component.kafka
Generated by camel build tools - do NOT edit this file!
KafkaEndpointConfigurer() - Constructor for class org.apache.camel.component.kafka.KafkaEndpointConfigurer
 
KafkaEndpointUriFactory - Class in org.apache.camel.component.kafka
Generated by camel build tools - do NOT edit this file!
KafkaEndpointUriFactory() - Constructor for class org.apache.camel.component.kafka.KafkaEndpointUriFactory
 
KafkaErrorStrategies - Class in org.apache.camel.component.kafka.consumer.errorhandler
 
KafkaFetchRecords - Class in org.apache.camel.component.kafka
 
KafkaHeaderDeserializer - Interface in org.apache.camel.component.kafka.serde
Deserializer for kafka header value.
KafkaHeaderFilterStrategy - Class in org.apache.camel.component.kafka
 
KafkaHeaderFilterStrategy() - Constructor for class org.apache.camel.component.kafka.KafkaHeaderFilterStrategy
 
KafkaHeaderSerializer - Interface in org.apache.camel.component.kafka.serde
Serializer for kafka header value.
KafkaHealthCheckRepository - Class in org.apache.camel.component.kafka
Repository for camel-kafka HealthChecks.
KafkaHealthCheckRepository() - Constructor for class org.apache.camel.component.kafka.KafkaHealthCheckRepository
 
KafkaIdempotentRepository - Class in org.apache.camel.processor.idempotent.kafka
A Kafka topic-based implementation of IdempotentRepository.
KafkaIdempotentRepository() - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
No-op constructor for XML/property-based object initialisation.
KafkaIdempotentRepository(String, String) - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
KafkaIdempotentRepository(String, String, int, int) - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
KafkaIdempotentRepository(String, Properties, Properties) - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
KafkaIdempotentRepository(String, Properties, Properties, int, int) - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
KafkaManualCommit - Interface in org.apache.camel.component.kafka.consumer
Can be used for forcing manual offset commit when using Kafka consumer.
KafkaManualCommitFactory - Interface in org.apache.camel.component.kafka.consumer
Factory to create a new KafkaManualCommit to store on the Exchange.
KafkaManualCommitFactory.CamelExchangePayload - Class in org.apache.camel.component.kafka.consumer
A holder class for the Camel exchange related payload, such as the exchange itself, the consumer, thread ID, etc
KafkaManualCommitFactory.KafkaRecordPayload - Class in org.apache.camel.component.kafka.consumer
A holder class for the payload related to the Kafka record, such as partition and topic information
KafkaOffset - Class in org.apache.camel.component.kafka.consumer.support
Offset class for Kafka
KafkaOffset(String, String) - Constructor for class org.apache.camel.component.kafka.consumer.support.KafkaOffset
 
KafkaProducer - Class in org.apache.camel.component.kafka
 
KafkaProducer(KafkaEndpoint) - Constructor for class org.apache.camel.component.kafka.KafkaProducer
 
KafkaProducerCallBack - Class in org.apache.camel.component.kafka.producer.support
 
KafkaProducerCallBack(Object, AsyncCallback, ExecutorService, boolean) - Constructor for class org.apache.camel.component.kafka.producer.support.KafkaProducerCallBack
 
KafkaProducerHealthCheck - Class in org.apache.camel.component.kafka
Kafka producer readiness health-check
KafkaProducerHealthCheck(KafkaProducer, String) - Constructor for class org.apache.camel.component.kafka.KafkaProducerHealthCheck
 
KafkaProducerMetadataCallBack - Class in org.apache.camel.component.kafka.producer.support
 
KafkaProducerMetadataCallBack(Object, boolean) - Constructor for class org.apache.camel.component.kafka.producer.support.KafkaProducerMetadataCallBack
 
kafkaRecordPayload - Variable in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
 
KafkaRecordPayload(TopicPartition, long, long) - Constructor for class org.apache.camel.component.kafka.consumer.KafkaManualCommitFactory.KafkaRecordPayload
 
KafkaRecordProcessor - Class in org.apache.camel.component.kafka.consumer.support
 
KafkaRecordProcessor(KafkaConfiguration, Processor, CommitManager) - Constructor for class org.apache.camel.component.kafka.consumer.support.KafkaRecordProcessor
 
KafkaRecordProcessorFacade - Class in org.apache.camel.component.kafka.consumer.support
 
KafkaRecordProcessorFacade(KafkaConsumer, String, CommitManager, KafkaConsumerListener) - Constructor for class org.apache.camel.component.kafka.consumer.support.KafkaRecordProcessorFacade
 
KafkaResumable - Class in org.apache.camel.component.kafka.consumer.support
 
KafkaResumable(String, String) - Constructor for class org.apache.camel.component.kafka.consumer.support.KafkaResumable
 
KafkaResumeStrategy<K,​V> - Interface in org.apache.camel.processor.resume.kafka
Base interface for resume strategies that publish the offsets to a Kafka topic
KafkaSendDynamicAware - Class in org.apache.camel.component.kafka
Kafka based SendDynamicAware which allows to optimise Kafka components with the toD (dynamic to) DSL in Camel.
KafkaSendDynamicAware() - Constructor for class org.apache.camel.component.kafka.KafkaSendDynamicAware
 
KafkaSerdeHelper - Class in org.apache.camel.component.kafka.serde
 
KEY - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
KeyValueHolderIterator - Class in org.apache.camel.component.kafka.producer.support
 
KeyValueHolderIterator(Iterator<Object>, Exchange, KafkaConfiguration, String, List<Header>) - Constructor for class org.apache.camel.component.kafka.producer.support.KeyValueHolderIterator
 

L

LAST_POLL_RECORD - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
LAST_RECORD_BEFORE_COMMIT - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
loadCache() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Loads the existing data into the cache

M

MANUAL_COMMIT - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
MultiNodeKafkaResumeStrategy<K,​V> - Class in org.apache.camel.processor.resume.kafka
A resume strategy that publishes offsets to a Kafka topic.
MultiNodeKafkaResumeStrategy(String, String, ResumeCache<K, V>, ResumeAdapter) - Constructor for class org.apache.camel.processor.resume.kafka.MultiNodeKafkaResumeStrategy
Create a new instance of this class
MultiNodeKafkaResumeStrategy(String, String, ResumeCache<K, V>, ResumeAdapter, ExecutorService) - Constructor for class org.apache.camel.processor.resume.kafka.MultiNodeKafkaResumeStrategy
Builds an instance of this class
MultiNodeKafkaResumeStrategy(String, ResumeCache<K, V>, ResumeAdapter, Properties, Properties) - Constructor for class org.apache.camel.processor.resume.kafka.MultiNodeKafkaResumeStrategy
Builds an instance of this class
MultiNodeKafkaResumeStrategy(String, ResumeCache<K, V>, ResumeAdapter, Properties, Properties, ExecutorService) - Constructor for class org.apache.camel.processor.resume.kafka.MultiNodeKafkaResumeStrategy
Builds an instance of this class
multiValuePrefixes() - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
 

N

newInstance(KafkaManualCommitFactory.CamelExchangePayload, KafkaManualCommitFactory.KafkaRecordPayload, CommitManager) - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualAsyncCommitFactory
 
newInstance(KafkaManualCommitFactory.CamelExchangePayload, KafkaManualCommitFactory.KafkaRecordPayload, CommitManager) - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommitFactory
 
newInstance(KafkaManualCommitFactory.CamelExchangePayload, KafkaManualCommitFactory.KafkaRecordPayload, CommitManager) - Method in interface org.apache.camel.component.kafka.consumer.KafkaManualCommitFactory
Creates a new instance
newUnprocessed() - Static method in class org.apache.camel.component.kafka.consumer.support.ProcessingResult
 
next() - Method in class org.apache.camel.component.kafka.producer.support.KeyValueHolderIterator
 
NoopCommitManager - Class in org.apache.camel.component.kafka.consumer
 
NoopCommitManager(Consumer<?, ?>, KafkaConsumer, String, String) - Constructor for class org.apache.camel.component.kafka.consumer.NoopCommitManager
 
numericHeader(String) - Static method in class org.apache.camel.component.kafka.serde.KafkaSerdeHelper
 

O

offset() - Method in class org.apache.camel.component.kafka.consumer.support.KafkaOffset
 
OFFSET - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
OffsetKafkaConsumerResumeAdapter - Class in org.apache.camel.component.kafka.consumer.support
A resume strategy that uses Kafka's offset for resuming
OffsetKafkaConsumerResumeAdapter(StateRepository<String, String>) - Constructor for class org.apache.camel.component.kafka.consumer.support.OffsetKafkaConsumerResumeAdapter
 
offsetRepository - Variable in class org.apache.camel.component.kafka.consumer.KafkaManualCommitFactory.CamelExchangePayload
 
onCompletion(RecordMetadata, Exception) - Method in class org.apache.camel.component.kafka.producer.support.DelegatingCallback
 
onCompletion(RecordMetadata, Exception) - Method in class org.apache.camel.component.kafka.producer.support.KafkaProducerCallBack
 
onCompletion(RecordMetadata, Exception) - Method in class org.apache.camel.component.kafka.producer.support.KafkaProducerMetadataCallBack
 
onPartitionsAssigned(Collection<TopicPartition>) - Method in class org.apache.camel.component.kafka.consumer.support.PartitionAssignmentListener
 
onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.apache.camel.component.kafka.consumer.support.PartitionAssignmentListener
 
org.apache.camel.component.kafka - package org.apache.camel.component.kafka
 
org.apache.camel.component.kafka.consumer - package org.apache.camel.component.kafka.consumer
 
org.apache.camel.component.kafka.consumer.errorhandler - package org.apache.camel.component.kafka.consumer.errorhandler
 
org.apache.camel.component.kafka.consumer.support - package org.apache.camel.component.kafka.consumer.support
 
org.apache.camel.component.kafka.producer.support - package org.apache.camel.component.kafka.producer.support
 
org.apache.camel.component.kafka.serde - package org.apache.camel.component.kafka.serde
 
org.apache.camel.processor.idempotent.kafka - package org.apache.camel.processor.idempotent.kafka
 
org.apache.camel.processor.resume.kafka - package org.apache.camel.processor.resume.kafka
 
OVERRIDE_TIMESTAMP - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
OVERRIDE_TOPIC - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 

P

partition - Variable in class org.apache.camel.component.kafka.consumer.KafkaManualCommitFactory.KafkaRecordPayload
 
PARTITION - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
PARTITION_KEY - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
PartitionAssignmentListener - Class in org.apache.camel.component.kafka.consumer.support
 
PartitionAssignmentListener(String, KafkaConfiguration, CommitManager, KafkaConsumerResumeAdapter) - Constructor for class org.apache.camel.component.kafka.consumer.support.PartitionAssignmentListener
 
PARTITIONER_RANGE_ASSIGNOR - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
pause() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
 
PollExceptionStrategy - Interface in org.apache.camel.component.kafka
Strategy to decide when a Kafka exception was thrown during polling, how to handle this.
PollOnError - Enum in org.apache.camel.component.kafka
DISCARD will discard the message and continue to poll next message.
prepare(Exchange, String, String) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
 
printableTopic - Variable in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
 
process(Exchange) - Method in class org.apache.camel.component.kafka.KafkaProducer
 
process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.kafka.KafkaProducer
 
processExchange(Exchange, TopicPartition, boolean, boolean, ConsumerRecord<Object, Object>, ProcessingResult, ExceptionHandler) - Method in class org.apache.camel.component.kafka.consumer.support.KafkaRecordProcessor
 
ProcessingResult - Class in org.apache.camel.component.kafka.consumer.support
 
processPolledRecords(ConsumerRecords<Object, Object>) - Method in class org.apache.camel.component.kafka.consumer.support.KafkaRecordProcessorFacade
 
produce(K, V) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Sends data to a topic.
ProducerUtil - Class in org.apache.camel.component.kafka.producer.support
 
propertyNames() - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
 

R

RECONNECT - org.apache.camel.component.kafka.PollOnError
 
ReconnectErrorStrategy - Class in org.apache.camel.component.kafka.consumer.errorhandler
 
ReconnectErrorStrategy(KafkaFetchRecords) - Constructor for class org.apache.camel.component.kafka.consumer.errorhandler.ReconnectErrorStrategy
 
RecordError - Class in org.apache.camel.processor.resume.kafka
Contains the error details when failing to produce records
RecordError(RecordMetadata, Exception) - Constructor for class org.apache.camel.processor.resume.kafka.RecordError
 
recordOffset - Variable in class org.apache.camel.component.kafka.consumer.KafkaManualCommitFactory.KafkaRecordPayload
 
recordOffset(TopicPartition, long) - Method in class org.apache.camel.component.kafka.consumer.AsyncCommitManager
 
recordOffset(TopicPartition, long) - Method in interface org.apache.camel.component.kafka.consumer.CommitManager
Record the last processed offset for future commit
recordOffset(TopicPartition, long) - Method in class org.apache.camel.component.kafka.consumer.CommitToOffsetManager
 
recordOffset(TopicPartition, long) - Method in class org.apache.camel.component.kafka.consumer.NoopCommitManager
 
recordOffset(TopicPartition, long) - Method in class org.apache.camel.component.kafka.consumer.SyncCommitManager
 
refresh() - Method in class org.apache.camel.processor.resume.kafka.MultiNodeKafkaResumeStrategy
Launch a thread to refresh the offsets periodically
remove() - Method in class org.apache.camel.component.kafka.producer.support.KeyValueHolderIterator
 
remove(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
removeHealthCheck(HealthCheck) - Method in class org.apache.camel.component.kafka.KafkaHealthCheckRepository
 
reset() - Method in class org.apache.camel.component.kafka.consumer.errorhandler.ReconnectErrorStrategy
 
reset() - Method in class org.apache.camel.component.kafka.consumer.errorhandler.StopErrorStrategy
 
reset() - Method in interface org.apache.camel.component.kafka.PollExceptionStrategy
Reset any error flags set by a previous error condition
resetProducerErrors() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Clear the producer errors
resolveResumeAdapter(KafkaConsumer) - Static method in class org.apache.camel.component.kafka.consumer.support.ResumeStrategyFactory
 
resolveStaticUri(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
 
resume() - Method in class org.apache.camel.component.kafka.consumer.support.OffsetKafkaConsumerResumeAdapter
 
resume() - Method in class org.apache.camel.component.kafka.consumer.support.SeekPolicyKafkaConsumerResumeAdapter
 
resume() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
 
ResumeStrategyFactory - Class in org.apache.camel.component.kafka.consumer.support
 
RETRY - org.apache.camel.component.kafka.PollOnError
 
RetryErrorStrategy - Class in org.apache.camel.component.kafka.consumer.errorhandler
 
RetryErrorStrategy() - Constructor for class org.apache.camel.component.kafka.consumer.errorhandler.RetryErrorStrategy
 
run() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
 

S

secretPropertyNames() - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
 
SeekPolicy - Enum in org.apache.camel.component.kafka
BEGINNING configures the consumer to consume from the beginning of the topic/partition.
SeekPolicyKafkaConsumerResumeAdapter - Class in org.apache.camel.component.kafka.consumer.support
A resume strategy that uses Camel's seekTo configuration for resuming
SeekPolicyKafkaConsumerResumeAdapter(SeekPolicy) - Constructor for class org.apache.camel.component.kafka.consumer.support.SeekPolicyKafkaConsumerResumeAdapter
 
serialize(String, Object) - Method in class org.apache.camel.component.kafka.serde.DefaultKafkaHeaderSerializer
 
serialize(String, Object) - Method in interface org.apache.camel.component.kafka.serde.KafkaHeaderSerializer
 
serializeOffsetKey(TopicPartition) - Static method in class org.apache.camel.component.kafka.consumer.support.KafkaRecordProcessor
 
setAdditionalProperties(Map<String, Object>) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Sets additional properties for either kafka consumer or kafka producer in case they can't be set directly on the camel configurations (e.g: new Kafka properties that are not reflected yet in Camel configurations), the properties have to be prefixed with `additionalProperties.`.
setAllowManualCommit(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Whether to allow doing manual commits via KafkaManualCommit.
setAutoCommitEnable(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
If true, periodically commit to ZooKeeper the offset of messages already fetched by the consumer.
setAutoCommitIntervalMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The frequency in ms that the consumer offsets are committed to zookeeper.
setAutoOffsetReset(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
What to do when there is no initial offset in ZooKeeper or if an offset is out of range: earliest : automatically reset the offset to the earliest offset latest : automatically reset the offset to the latest offset fail: throw exception to the consumer
setBootstrapServers(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
Sets the
setBreakOnFirstError(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
This options controls what happens when a consumer is processing an exchange and it fails.
setBrokers(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
URL of the Kafka brokers to use.
setBufferMemorySize(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The total bytes of memory the producer can use to buffer records waiting to be sent to the server.
setCamelContext(CamelContext) - Method in class org.apache.camel.component.kafka.KafkaHealthCheckRepository
 
setCamelContext(CamelContext) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
 
setCamelContext(CamelContext) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
 
setCheckCrcs(Boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Automatically check the CRC32 of the records consumed.
setClientId(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The client id is a user-specified string sent in each request to help trace calls.
setCommitTimeoutMs(Long) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The maximum time, in milliseconds, that the code will wait for a synchronous commit to complete
setCompressionCodec(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
This parameter allows you to specify the compression codec for all data generated by this producer.
setConfiguration(KafkaConfiguration) - Method in class org.apache.camel.component.kafka.KafkaComponent
Allows to pre-configure the Kafka component with common options that the endpoints will reuse.
setConfiguration(KafkaConfiguration) - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
setConnected(boolean) - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
 
setConnectionMaxIdleMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Close idle connections after the number of milliseconds specified by this config.
setConsumer(Consumer<?, ?>) - Method in class org.apache.camel.component.kafka.consumer.errorhandler.KafkaConsumerListener
 
setConsumer(Consumer<?, ?>) - Method in interface org.apache.camel.component.kafka.consumer.support.KafkaConsumerResumeAdapter
Sets the Kafka consumer instance for the adapter.
setConsumer(Consumer<?, ?>) - Method in class org.apache.camel.component.kafka.consumer.support.OffsetKafkaConsumerResumeAdapter
 
setConsumer(Consumer<?, ?>) - Method in class org.apache.camel.component.kafka.consumer.support.SeekPolicyKafkaConsumerResumeAdapter
 
setConsumerConfig(Properties) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
Sets the properties that will be used by the Kafka consumer.
setConsumerListener(KafkaConsumerListener) - Method in class org.apache.camel.component.kafka.KafkaConsumer
 
setConsumerRequestTimeoutMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The configuration controls the maximum amount of time the client will wait for the response of a request.
setConsumersCount(int) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The number of consumers that connect to kafka server.
setCreateConsumerBackoffInterval(long) - Method in class org.apache.camel.component.kafka.KafkaComponent
The delay in millis seconds to wait before trying again to create the kafka consumer (kafka-client).
setCreateConsumerBackoffMaxAttempts(int) - Method in class org.apache.camel.component.kafka.KafkaComponent
Maximum attempts to create the kafka consumer (kafka-client), before eventually giving up and failing.
setDeliveryTimeoutMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
An upper bound on the time to report success or failure after a call to send() returns.
setEnabled(boolean) - Method in class org.apache.camel.component.kafka.KafkaHealthCheckRepository
 
setEnableIdempotence(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
If set to 'true' the producer will ensure that exactly one copy of each message is written in the stream.
setFetchMaxBytes(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
setFetchMinBytes(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The minimum amount of data the server should return for a fetch request.
setFetchWaitMaxMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The maximum amount of time the server will block before answering the fetch request if there isn't sufficient data to immediately satisfy fetch.min.bytes
setGroupId(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
A string that uniquely identifies the group of consumer processes to which this consumer belongs.
setGroupInstanceId(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
A unique identifier of the consumer instance provided by the end user.
setHeaderDeserializer(KafkaHeaderDeserializer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Sets custom KafkaHeaderDeserializer for deserialization kafka headers values to camel headers values.
setHeaderFilterStrategy(HeaderFilterStrategy) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
To use a custom HeaderFilterStrategy to filter header to and from Camel message.
setHeaderSerializer(KafkaHeaderSerializer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Sets custom KafkaHeaderDeserializer for serialization camel headers values to kafka headers values.
setHeartbeatIntervalMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The expected time between heartbeats to the consumer coordinator when using Kafka's group management facilities.
setInterceptorClasses(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Sets interceptors for producer or consumers.
setIsolationLevel(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Controls how to read messages written transactionally.
setKafkaClientFactory(KafkaClientFactory) - Method in class org.apache.camel.component.kafka.KafkaComponent
Factory to use for creating KafkaConsumer and KafkaProducer instances.
setKafkaClientFactory(KafkaClientFactory) - Method in class org.apache.camel.component.kafka.KafkaEndpoint
Factory to use for creating KafkaConsumer and KafkaProducer instances.
setKafkaManualCommitFactory(KafkaManualCommitFactory) - Method in class org.apache.camel.component.kafka.KafkaComponent
Factory to use for creating KafkaManualCommit instances.
setKafkaManualCommitFactory(KafkaManualCommitFactory) - Method in class org.apache.camel.component.kafka.KafkaEndpoint
Factory to use for creating KafkaManualCommit instances.
setKafkaProducer(Producer) - Method in class org.apache.camel.component.kafka.KafkaProducer
To use a custom KafkaProducer instance.
setKafkaResumable(KafkaResumable) - Method in interface org.apache.camel.component.kafka.consumer.support.KafkaConsumerResumeAdapter
Sets an optional resumable instance for the adapter.
setKafkaResumable(KafkaResumable) - Method in class org.apache.camel.component.kafka.consumer.support.OffsetKafkaConsumerResumeAdapter
 
setKafkaResumable(KafkaResumable) - Method in class org.apache.camel.component.kafka.consumer.support.SeekPolicyKafkaConsumerResumeAdapter
 
setKerberosBeforeReloginMinTime(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Login thread sleep time between refresh attempts.
setKerberosInitCmd(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Kerberos kinit command path.
setKerberosPrincipalToLocalRules(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
A list of rules for mapping from principal names to short names (typically operating system usernames).
setKerberosRenewJitter(Double) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Percentage of random jitter added to the renewal time.
setKerberosRenewWindowFactor(Double) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Login thread will sleep until the specified window factor of time from last refresh to ticket's expiry has been reached, at which time it will try to renew the ticket.
setKey(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The record key (or null if no key is specified).
setKeyDeserializer(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Deserializer class for key that implements the Deserializer interface.
setKeySerializer(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The serializer class for keys (defaults to the same as for messages if nothing is given).
setLingerMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The producer groups together any records that arrive in between request transmissions into a single batched request.
setMaxBlockMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The configuration controls how long sending to kafka will block.
setMaxCacheSize(int) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
Sets the maximum size of the local key cache.
setMaxInFlightRequest(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The maximum number of unacknowledged requests the client will send on a single connection before blocking.
setMaxPartitionFetchBytes(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The maximum amount of data per-partition the server will return.
setMaxPollIntervalMs(Long) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The maximum delay between invocations of poll() when using consumer group management.
setMaxPollRecords(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The maximum number of records returned in a single call to poll()
setMaxRequestSize(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The maximum size of a request.
setMetadataMaxAgeMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The period of time in milliseconds after which we force a refresh of metadata even if we haven't seen any partition leadership changes to proactively discover any new brokers or partitions.
setMetricReporters(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
A list of classes to use as metrics reporters.
setMetricsSampleWindowMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The number of samples maintained to compute metrics.
setNoOfMetricsSample(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The number of samples maintained to compute metrics.
setOffsetRepository(StateRepository<String, String>) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The offset repository to use in order to locally store the offset of each partition of the topic.
setPartitionAssignor(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The class name of the partition assignment strategy that the client will use to distribute partition ownership amongst consumer instances when group management is used
setPartitioner(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The partitioner class for partitioning messages amongst sub-topics.
setPartitionKey(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The partition to which the record will be sent (or null if no partition was specified).
setPollDuration(Duration) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
setPollDurationMs(int) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
Sets the poll duration of the Kafka consumer.
setPollExceptionStrategy(PollExceptionStrategy) - Method in class org.apache.camel.component.kafka.KafkaComponent
To use a custom strategy with the consumer to control how to handle exceptions thrown from the Kafka broker while pooling messages.
setPollOnError(PollOnError) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
What to do if kafka threw an exception while polling for new messages.
setPollTimeoutMs(Long) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The timeout used when polling the KafkaConsumer.
setProducerBatchSize(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The producer will attempt to batch records together into fewer requests whenever multiple records are being sent to the same partition.
setProducerConfig(Properties) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
Sets the properties that will be used by the Kafka producer.
setQueueBufferingMaxMessages(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The maximum number of unsent messages that can be queued up the producer when using async mode before either the producer must be blocked or data must be dropped.
setReceiveBufferBytes(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The size of the TCP receive buffer (SO_RCVBUF) to use when reading data.
setReconnect(boolean) - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
 
setReconnectBackoffMaxMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The maximum amount of time in milliseconds to wait when reconnecting to a broker that has repeatedly failed to connect.
setReconnectBackoffMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The amount of time to wait before attempting to reconnect to a given host.
setRecordMetadata(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Whether the producer should store the RecordMetadata results from sending to Kafka.
setRecordMetadata(Object, List<RecordMetadata>) - Static method in class org.apache.camel.component.kafka.producer.support.ProducerUtil
 
setRequestRequiredAcks(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The number of acknowledgments the producer requires the leader to have received before considering a request complete.
setRequestTimeoutMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The amount of time the broker will wait trying to meet the request.required.acks requirement before sending back an error to the client.
setResumableCheck(Predicate<?>) - Method in class org.apache.camel.component.kafka.consumer.errorhandler.KafkaConsumerListener
 
setResumeStrategy(ResumeStrategy) - Method in class org.apache.camel.component.kafka.KafkaConsumer
 
setRetries(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Setting a value greater than zero will cause the client to resend any record whose send fails with a potentially transient error.
setRetryBackoffMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Before each retry, the producer refreshes the metadata of relevant topics to see if a new leader has been elected.
setSaslJaasConfig(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Expose the kafka sasl.jaas.config parameter Example: org.apache.kafka.common.security.plain.PlainLoginModule required username="USERNAME" password="PASSWORD";
setSaslKerberosServiceName(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The Kerberos principal name that Kafka runs as.
setSaslMechanism(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The Simple Authentication and Security Layer (SASL) Mechanism used.
setSchemaRegistryURL(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
URL of the Confluent Platform schema registry servers to use.
setScheme(String) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
 
setSecurityProtocol(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Protocol used to communicate with brokers.
setSeekPolicy(SeekPolicy) - Method in class org.apache.camel.component.kafka.consumer.errorhandler.KafkaConsumerListener
 
setSeekTo(SeekPolicy) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Set if KafkaConsumer will read from beginning or end on startup: SeekPolicy.BEGINNING: read from beginning.
setSendBufferBytes(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Socket write buffer size
setSessionTimeoutMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The timeout used to detect failures when using Kafka's group management facilities.
setShutdownTimeout(int) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Timeout in milliseconds to wait gracefully for the consumer or producer to shutdown and terminate its worker threads.
setSpecificAvroReader(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
This enables the use of a specific Avro reader for use with the Confluent Platform schema registry and the io.confluent.kafka.serializers.KafkaAvroDeserializer.
setSslCipherSuites(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
A list of cipher suites.
setSslContextParameters(SSLContextParameters) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
SSL configuration using a Camel SSLContextParameters object.
setSslEnabledProtocols(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The list of protocols enabled for SSL connections.
setSslEndpointAlgorithm(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The endpoint identification algorithm to validate server hostname using server certificate.
setSslKeymanagerAlgorithm(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The algorithm used by key manager factory for SSL connections.
setSslKeyPassword(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The password of the private key in the key store file.
setSslKeystoreLocation(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The location of the key store file.
setSslKeystorePassword(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The store password for the key store file.This is optional for client and only needed if ssl.keystore.location is configured.
setSslKeystoreType(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The file format of the key store file.
setSslProtocol(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The SSL protocol used to generate the SSLContext.
setSslProvider(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The name of the security provider used for SSL connections.
setSslTrustmanagerAlgorithm(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The algorithm used by trust manager factory for SSL connections.
setSslTruststoreLocation(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The location of the trust store file.
setSslTruststorePassword(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The password for the trust store file.
setSslTruststoreType(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The file format of the trust store file.
setSubscribeConsumerBackoffInterval(long) - Method in class org.apache.camel.component.kafka.KafkaComponent
The delay in millis seconds to wait before trying again to subscribe to the kafka broker.
setSubscribeConsumerBackoffMaxAttempts(int) - Method in class org.apache.camel.component.kafka.KafkaComponent
Maximum number the kafka consumer will attempt to subscribe to the kafka broker, before eventually giving up and failing.
setSynchronous(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
 
setTopic(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Name of the topic to use.
setTopic(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
Sets the name of the Kafka topic used by this idempotent repository.
setTopicIsPattern(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Whether the topic is a pattern (regular expression).
setUseGlobalSslContextParameters(boolean) - Method in class org.apache.camel.component.kafka.KafkaComponent
Enable usage of global SSL context parameters.
setValueDeserializer(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Deserializer class for value that implements the Deserializer interface.
setValueSerializer(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
The serializer class for messages.
setWorkerPool(ExecutorService) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
To use a custom worker pool for continue routing Exchange after kafka server has acknowledge the message that was sent to it from KafkaProducer using asynchronous non-blocking processing.
setWorkerPool(ExecutorService) - Method in class org.apache.camel.component.kafka.KafkaProducer
 
setWorkerPoolCoreSize(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Number of core threads for the worker pool for continue routing Exchange after kafka server has acknowledge the message that was sent to it from KafkaProducer using asynchronous non-blocking processing.
setWorkerPoolMaxSize(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
Maximum number of threads for the worker pool for continue routing Exchange after kafka server has acknowledge the message that was sent to it from KafkaProducer using asynchronous non-blocking processing.
SingleNodeKafkaResumeStrategy<K,​V> - Class in org.apache.camel.processor.resume.kafka
A resume strategy that publishes offsets to a Kafka topic.
SingleNodeKafkaResumeStrategy(String, String, ResumeCache<K, V>, ResumeAdapter) - Constructor for class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Builds an instance of this class
SingleNodeKafkaResumeStrategy(String, ResumeCache<K, V>, ResumeAdapter, Properties, Properties) - Constructor for class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Builds an instance of this class
start() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
START_OFFSET - Static variable in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
 
startPolling() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
 
stop() - Method in class org.apache.camel.processor.resume.kafka.MultiNodeKafkaResumeStrategy
 
stop() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
STOP - org.apache.camel.component.kafka.PollOnError
 
StopErrorStrategy - Class in org.apache.camel.component.kafka.consumer.errorhandler
 
StopErrorStrategy(KafkaFetchRecords) - Constructor for class org.apache.camel.component.kafka.consumer.errorhandler.StopErrorStrategy
 
strategies(KafkaFetchRecords, KafkaEndpoint, Consumer<?, ?>) - Static method in class org.apache.camel.component.kafka.consumer.errorhandler.KafkaErrorStrategies
 
stream() - Method in class org.apache.camel.component.kafka.KafkaHealthCheckRepository
 
subscribe() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 
SyncCommitManager - Class in org.apache.camel.component.kafka.consumer
 
SyncCommitManager(Consumer<?, ?>, KafkaConsumer, String, String) - Constructor for class org.apache.camel.component.kafka.consumer.SyncCommitManager
 

T

TaskHealthState - Class in org.apache.camel.component.kafka
 
TaskHealthState(boolean, boolean, boolean, Exception, String, long, Properties) - Constructor for class org.apache.camel.component.kafka.TaskHealthState
 
threadId - Variable in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
 
threadId - Variable in class org.apache.camel.component.kafka.consumer.KafkaManualCommitFactory.CamelExchangePayload
 
TIMESTAMP - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
TOPIC - Static variable in class org.apache.camel.component.kafka.KafkaConstants
 
tryConvertToSerializedType(Exchange, Object, String) - Static method in class org.apache.camel.component.kafka.producer.support.ProducerUtil
 

U

unsubscribe() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
Unsubscribe from the topic
updateClassProperties(Properties) - Method in class org.apache.camel.component.kafka.KafkaEndpoint
 
updateLastOffset(String) - Method in class org.apache.camel.component.kafka.consumer.support.KafkaResumable
 
updateLastOffset(Resumable<K, V>) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
 

V

valueOf(String) - Static method in enum org.apache.camel.component.kafka.PollOnError
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.camel.component.kafka.SeekPolicy
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.camel.component.kafka.PollOnError
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.camel.component.kafka.SeekPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
A B C D E F G H I K L M N O P R S T U V 
All Classes All Packages