Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
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
- AbstractKafkaRecordProcessorFacade - Class in org.apache.camel.component.kafka.consumer.support
-
Common code for processing consumer records retrieved from Kafka
- AbstractKafkaRecordProcessorFacade(KafkaConsumer, String, CommitManager, KafkaConsumerListener) - Constructor for class org.apache.camel.component.kafka.consumer.support.AbstractKafkaRecordProcessorFacade
- adapterFactoryService() - Method in class org.apache.camel.component.kafka.KafkaConsumer
- add(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- add(OffsetKey<?>, Offset<?>) - Method in class org.apache.camel.component.kafka.consumer.support.resume.KafkaResumeAdapter
- 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
- BatchManualCommit - Class in org.apache.camel.component.kafka
- BatchManualCommit() - Constructor for class org.apache.camel.component.kafka.BatchManualCommit
- BEGINNING - Enum constant in enum class 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.KafkaResumeStrategyConfigurationBuilder
- 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
- camelKafkaConsumer - Variable in class org.apache.camel.component.kafka.consumer.support.AbstractKafkaRecordProcessorFacade
- 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(Consumer<byte[], byte[]>, String) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
-
Subscribe to the topic if not subscribed yet
- checkAndSubscribe(Consumer<byte[], byte[]>, String, long) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
-
Subscribe to the topic if not subscribed yet
- ClassicRebalanceListener - Class in org.apache.camel.component.kafka.consumer.support.classic
- ClassicRebalanceListener(String, KafkaConfiguration, CommitManager, Consumer<?, ?>) - Constructor for class org.apache.camel.component.kafka.consumer.support.classic.ClassicRebalanceListener
- clear() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- close() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- collectCommitMetrics(Consumer<?, ?>) - Method in class org.apache.camel.component.kafka.consumer.devconsole.DefaultMetricsCollector
- collectCommitMetrics(Consumer<?, ?>) - Method in interface org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector
- collectCommitMetrics(Consumer<?, ?>) - Method in class org.apache.camel.component.kafka.consumer.devconsole.NoopMetricsCollector
- 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 - Variable in class org.apache.camel.component.kafka.consumer.support.AbstractKafkaRecordProcessorFacade
- CommitManager - Interface in org.apache.camel.component.kafka.consumer
- CommitManagers - Class in org.apache.camel.component.kafka.consumer
- COMMITTED - Static variable in class org.apache.camel.component.kafka.KafkaDevConsole
-
Whether to include committed offset (sync operation to Kafka broker)
- 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
- configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepositoryConfigurer
- confirm(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- consume(int, Consumer<byte[], byte[]>) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
-
Consumes message from the topic previously setup
- consume(Consumer<byte[], byte[]>) - 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
- consumerListener - Variable in class org.apache.camel.component.kafka.consumer.support.AbstractKafkaRecordProcessorFacade
- 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(Processor) - Method in class org.apache.camel.component.kafka.KafkaEndpoint
- createConsumerProperties() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- createConsumerProperties() - Static method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
-
Creates a basic consumer
- 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(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
- createProducerProperties() - Static method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
-
Creates a basic producer
- 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
- DefaultMetricsCollector - Class in org.apache.camel.component.kafka.consumer.devconsole
-
The default collector if the dev console is enabled for Kafka
- DefaultMetricsCollector(String) - Constructor for class org.apache.camel.component.kafka.consumer.devconsole.DefaultMetricsCollector
- DefaultSubscribeAdapter - Class in org.apache.camel.component.kafka.consumer.support.subcription
- DefaultSubscribeAdapter() - Constructor for class org.apache.camel.component.kafka.consumer.support.subcription.DefaultSubscribeAdapter
- DefaultSubscribeAdapter(String, boolean) - Constructor for class org.apache.camel.component.kafka.consumer.support.subcription.DefaultSubscribeAdapter
- 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.consumer.support.interop.JMSDeserializer
- 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
- deserialize(String, byte[]) - Method in class org.apache.camel.component.kafka.serde.ToStringKafkaHeaderDeserializer
- deserialize(ByteBuffer, ByteBuffer) - Method in class org.apache.camel.component.kafka.consumer.support.resume.KafkaResumeAdapter
- deserializeOffsetValue(String) - Static method in class org.apache.camel.component.kafka.consumer.support.classic.OffsetPartitionAssignmentAdapter
- DevConsoleMetricsCollector - Interface in org.apache.camel.component.kafka.consumer.devconsole
-
Collects metrics for the dev console
- DevConsoleMetricsCollector.GroupMetadata - Record Class in org.apache.camel.component.kafka.consumer.devconsole
- DevConsoleMetricsCollector.KafkaTopicPosition - Record Class in org.apache.camel.component.kafka.consumer.devconsole
- DISCARD - Enum constant in enum class 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
- doAdd(OffsetKey<?>, Offset<?>) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- 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
- doCallJson(Map<String, Object>) - Method in class org.apache.camel.component.kafka.KafkaDevConsole
- doCallText(Map<String, Object>) - Method in class org.apache.camel.component.kafka.KafkaDevConsole
- 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.KafkaComponent
- 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
- DropField - Class in org.apache.camel.component.kafka.transform
- DropField() - Constructor for class org.apache.camel.component.kafka.transform.DropField
-
Default constructor.
- DropField(String, String) - Constructor for class org.apache.camel.component.kafka.transform.DropField
-
Constructor using fields.
E
- enabled - Variable in class org.apache.camel.component.kafka.KafkaHeaderDeserializer
- END - Enum constant in enum class org.apache.camel.component.kafka.SeekPolicy
- epoch() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.KafkaTopicPosition
-
Returns the value of the
epoch
record component. - equals(Object) - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.GroupMetadata
-
Indicates whether some other object is "equal to" this one.
- equals(Object) - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.KafkaTopicPosition
-
Indicates whether some other object is "equal to" this one.
- ERROR_HANDLER - Enum constant in enum class 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
- ExtractField - Class in org.apache.camel.component.kafka.transform
- ExtractField() - Constructor for class org.apache.camel.component.kafka.transform.ExtractField
-
Default constructor
- ExtractField(String) - Constructor for class org.apache.camel.component.kafka.transform.ExtractField
-
Constructor using field member.
F
- fetchCommitRecords() - Method in class org.apache.camel.component.kafka.consumer.devconsole.DefaultMetricsCollector
- fetchCommitRecords() - Method in interface org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector
- fetchCommitRecords() - Method in class org.apache.camel.component.kafka.consumer.devconsole.NoopMetricsCollector
- 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
- generationId() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.GroupMetadata
-
Returns the value of the
generationId
record component. - getAdapter() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- getAdditionalProperties() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- 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
- getBatchingIntervalMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- 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
- getCache() - Method in class org.apache.camel.component.kafka.consumer.support.resume.KafkaResumeAdapter
- getCacheCounter() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- getCacheSize() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- getCamelContext() - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
- getCamelContext() - Method in class org.apache.camel.component.kafka.serde.DefaultKafkaHeaderSerializer
- getCamelContext() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- getCamelContext() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- getCamelExchangePayload() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
-
Gets the Camel Exchange payload
- getCharset() - Method in class org.apache.camel.component.kafka.serde.ToStringKafkaHeaderDeserializer
- 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
- getCommitRecords() - Method in class org.apache.camel.component.kafka.consumer.devconsole.DefaultMetricsCollector
- getCommitRecords() - Method in interface org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector
- getCommitRecords() - Method in class org.apache.camel.component.kafka.consumer.devconsole.NoopMetricsCollector
- 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
-
Deprecated.
- getConsumer() - Method in class org.apache.camel.component.kafka.consumer.errorhandler.KafkaConsumerListener
- 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
- getConsumerListener() - Method in class org.apache.camel.component.kafka.KafkaConsumer
- getConsumerProperties() - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfiguration
- 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
- getDefaultHeaders() - Method in class org.apache.camel.component.kafka.producer.support.PropagatedHeadersProvider
-
Returns header values which are determined by parent exchange.
- getDeliveryTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- 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.
- 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
- getGroupId() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- getGroupInstanceId() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getGroupMetadata() - Method in class org.apache.camel.component.kafka.consumer.devconsole.DefaultMetricsCollector
- getGroupMetadata() - Method in interface org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector
- getGroupMetadata() - Method in class org.apache.camel.component.kafka.consumer.devconsole.NoopMetricsCollector
- getHeaderDeserializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getHeaderFilterStrategy() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getHeaders(Exchange, Message) - Method in class org.apache.camel.component.kafka.producer.support.PropagatedHeadersProvider
-
Create kafka header values by given Message.
- getHeaderSerializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getHeartbeatIntervalMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- 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
- getKerberosConfigLocation() - 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
- getLastOffset() - Method in class org.apache.camel.component.kafka.consumer.support.resume.KafkaResumable
- getLastRecord() - Method in class org.apache.camel.component.kafka.consumer.devconsole.DefaultMetricsCollector
- getLastRecord() - Method in interface org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector
- getLastRecord() - Method in class org.apache.camel.component.kafka.consumer.devconsole.NoopMetricsCollector
- 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
- getMaxInitializationDuration() - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfiguration
- getMaxInitializationRetries() - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfiguration
- 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
- getMetricsCollector() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
-
Gets the metrics collector for the dev console.
- getMetricsSampleWindowMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getNoOfMetricsSample() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getOffset() - Method in class org.apache.camel.component.kafka.consumer.support.ProcessingResult
- getOffsetKey() - Method in class org.apache.camel.component.kafka.consumer.support.KafkaResumable
- getOffsetKey() - Method in class org.apache.camel.component.kafka.consumer.support.resume.KafkaResumable
- 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
- getOptionType(String, boolean) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepositoryConfigurer
- 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
- getOptionValue(Object, String, boolean) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepositoryConfigurer
- getPartition() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
- getPartition() - Method in class org.apache.camel.component.kafka.consumer.support.ProcessingResult
- 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
- getPattern() - Method in class org.apache.camel.component.kafka.consumer.support.subcription.TopicInfo
- 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
- getPrintableTopic(Pattern, String) - Static method in class org.apache.camel.component.kafka.consumer.support.TopicHelper
- getPrintableTopic(Pattern, Collection<String>) - Static method in class org.apache.camel.component.kafka.consumer.support.TopicHelper
- getPrintableTopic(TopicInfo) - Static method in class org.apache.camel.component.kafka.consumer.support.TopicHelper
- 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
- getProducerProperties() - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfiguration
- getPropagatedHeaders(Exchange, Message) - Method in class org.apache.camel.component.kafka.KafkaProducer
- 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
- getResumeStrategy() - Method in class org.apache.camel.component.kafka.KafkaConsumer
- getResumeStrategyConfiguration() - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- getRetries() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getRetryBackoffMaxMs() - 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
- getServiceMetadata() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
- getServiceProtocol() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
- getServiceUrl() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
- 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
- getThreadId() - Method in class org.apache.camel.component.kafka.consumer.devconsole.DefaultMetricsCollector
- getThreadId() - Method in interface org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector
- getThreadId() - Method in class org.apache.camel.component.kafka.consumer.devconsole.NoopMetricsCollector
- getTopic() - Method in class org.apache.camel.component.kafka.consumer.support.ProcessingResult
- 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.KafkaResumeStrategyConfiguration
- getTopicName() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
- getTopics() - Method in class org.apache.camel.component.kafka.consumer.support.subcription.TopicInfo
- 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
- groupId() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.GroupMetadata
-
Returns the value of the
groupId
record component. - groupInstanceId() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.GroupMetadata
-
Returns the value of the
groupInstanceId
record component. - GroupMetadata(String, String, String, int) - Constructor for record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.GroupMetadata
-
Creates an instance of a
GroupMetadata
record class.
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.
- handlePartitionAssignment() - Method in class org.apache.camel.component.kafka.consumer.support.classic.NoOpPartitionAssignmentAdapter
- handlePartitionAssignment() - Method in class org.apache.camel.component.kafka.consumer.support.classic.OffsetPartitionAssignmentAdapter
- handlePartitionAssignment() - Method in interface org.apache.camel.component.kafka.consumer.support.classic.PartitionAssignmentAdapter
-
Callback for custom logic when partitions has been assigned.
- handlePartitionAssignment() - Method in class org.apache.camel.component.kafka.consumer.support.classic.SeekPolicyPartitionAssignmentAdapter
- hashCode() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.GroupMetadata
-
Returns a hash code value for this object.
- hashCode() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.KafkaTopicPosition
-
Returns a hash code value for this object.
- 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
- HoistField - Class in org.apache.camel.component.kafka.transform
- HoistField() - Constructor for class org.apache.camel.component.kafka.transform.HoistField
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
- InsertField - Class in org.apache.camel.component.kafka.transform
- InsertField() - Constructor for class org.apache.camel.component.kafka.transform.InsertField
-
Default constructor.
- InsertField(String, String) - Constructor for class org.apache.camel.component.kafka.transform.InsertField
-
Constructor using fields.
- isAllowManualCommit() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isAutoCommitEnable() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isBatching() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isBatchWithIndividualHeaders() - 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(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
- isKafkaPaused() - Method in class org.apache.camel.component.kafka.KafkaConsumer
-
Whether the Kafka client is currently paused
- isLenientProperties() - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
- isLenientProperties() - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
- isLong(byte[]) - Method in class org.apache.camel.component.kafka.consumer.support.interop.JMSDeserializer
- isMultipleConsumersSupported() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
- isPartitionerIgnoreKeys() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Whether the message keys should be ignored when computing the partition.
- isPattern() - Method in class org.apache.camel.component.kafka.consumer.support.subcription.TopicInfo
- isPaused() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
- isPreValidateHostAndPort() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isReachedOffsets(Consumer<K, V>, Map<TopicPartition, Long>) - Static method in class org.apache.camel.processor.idempotent.kafka.KafkaConsumerUtil
-
Tests whether the Kafka consumer reached the target offsets for all specified topic partitions.
- 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
- isStartupOnly() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- isStopping() - Method in class org.apache.camel.component.kafka.consumer.support.AbstractKafkaRecordProcessorFacade
-
Whether the the Camel consumer is stopping
- isSubscribeConsumerTopicMustExists() - Method in class org.apache.camel.component.kafka.KafkaComponent
- 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
- isUseIterator() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
J
- JMSDeserializer - Class in org.apache.camel.component.kafka.consumer.support.interop
- JMSDeserializer() - Constructor for class org.apache.camel.component.kafka.consumer.support.interop.JMSDeserializer
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_SERIALIZER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- KAFKA_RECORD_META - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- KAFKA_STRING_ENCODER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
-
Deprecated.
- KAFKA_SUBSCRIBE_ADAPTER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- 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 KafkaProducer
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 Class 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 class 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
- KafkaConsumerUtil - Class in org.apache.camel.processor.idempotent.kafka
- KafkaConsumerUtil() - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaConsumerUtil
- KafkaDevConsole - Class in org.apache.camel.component.kafka
- KafkaDevConsole() - Constructor for class org.apache.camel.component.kafka.KafkaDevConsole
- 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 - Class in org.apache.camel.component.kafka
-
Header deserializer used in Kafka source Kamelet.
- KafkaHeaderDeserializer - Interface in org.apache.camel.component.kafka.serde
-
Deserializer for kafka header value.
- KafkaHeaderDeserializer() - Constructor for class org.apache.camel.component.kafka.KafkaHeaderDeserializer
- 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.
- 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
- 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, String, int, int, String) - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- KafkaIdempotentRepository(String, String, String) - 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
- KafkaIdempotentRepository(String, Properties, Properties, int, int, String) - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- KafkaIdempotentRepository(String, Properties, Properties, String) - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
-
Deprecated.
- KafkaIdempotentRepositoryConfigurer - Class in org.apache.camel.processor.idempotent.kafka
-
Generated by camel build tools - do NOT edit this file!
- KafkaIdempotentRepositoryConfigurer() - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepositoryConfigurer
- 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 theExchange
. - 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
- 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
- KafkaRecordBatchingProcessorFacade - Class in org.apache.camel.component.kafka.consumer.support.batching
- KafkaRecordBatchingProcessorFacade(KafkaConsumer, String, CommitManager, KafkaConsumerListener) - Constructor for class org.apache.camel.component.kafka.consumer.support.batching.KafkaRecordBatchingProcessorFacade
- 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() - Constructor for class org.apache.camel.component.kafka.consumer.support.KafkaRecordProcessor
- KafkaRecordProcessorFacade - Interface in org.apache.camel.component.kafka.consumer.support
-
A processing facade that allows processing consumer records in different ways
- KafkaRecordStreamingProcessorFacade - Class in org.apache.camel.component.kafka.consumer.support.streaming
- KafkaRecordStreamingProcessorFacade(KafkaConsumer, String, CommitManager, KafkaConsumerListener) - Constructor for class org.apache.camel.component.kafka.consumer.support.streaming.KafkaRecordStreamingProcessorFacade
- KafkaResumable - Class in org.apache.camel.component.kafka.consumer.support
- KafkaResumable - Class in org.apache.camel.component.kafka.consumer.support.resume
- KafkaResumable(String, String) - Constructor for class org.apache.camel.component.kafka.consumer.support.KafkaResumable
- KafkaResumeAdapter - Class in org.apache.camel.component.kafka.consumer.support.resume
- KafkaResumeAdapter() - Constructor for class org.apache.camel.component.kafka.consumer.support.resume.KafkaResumeAdapter
- KafkaResumeStrategy - Interface in org.apache.camel.processor.resume.kafka
-
Base interface for resume strategies that publish the offsets to a Kafka topic
- KafkaResumeStrategyConfiguration - Class in org.apache.camel.processor.resume.kafka
-
A configuration suitable for using with the
KafkaResumeStrategy
and any of its implementations - KafkaResumeStrategyConfiguration() - Constructor for class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfiguration
- KafkaResumeStrategyConfigurationBuilder - Class in org.apache.camel.processor.resume.kafka
-
A configuration builder appropriate for building configurations for the
SingleNodeKafkaResumeStrategy
- KafkaResumeStrategyConfigurationBuilder(Properties, Properties) - Constructor for class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
- 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
- KafkaTopicPosition(String, int, long, int) - Constructor for record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.KafkaTopicPosition
-
Creates an instance of a
KafkaTopicPosition
record class. - 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, PropagatedHeadersProvider) - 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
- logRecord(ConsumerRecord<Object, Object>) - Method in class org.apache.camel.component.kafka.consumer.support.AbstractKafkaRecordProcessorFacade
- logRecords(ConsumerRecords<Object, Object>) - Method in class org.apache.camel.component.kafka.consumer.support.AbstractKafkaRecordProcessorFacade
-
Utility to log record information
- logRecordsInPartition(List<ConsumerRecord<Object, Object>>, TopicPartition) - Method in class org.apache.camel.component.kafka.consumer.support.AbstractKafkaRecordProcessorFacade
-
Utility to log record information along with partition
M
- MANUAL_COMMIT - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- ManualCommit - Class in org.apache.camel.component.kafka
- ManualCommit() - Constructor for class org.apache.camel.component.kafka.ManualCommit
- MaskField - Class in org.apache.camel.component.kafka.transform
- MaskField() - Constructor for class org.apache.camel.component.kafka.transform.MaskField
- memberId() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.GroupMetadata
-
Returns the value of the
memberId
record component. - MessageTimestampRouter - Class in org.apache.camel.component.kafka.transform
- MessageTimestampRouter() - Constructor for class org.apache.camel.component.kafka.transform.MessageTimestampRouter
- multiValuePrefixes() - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
N
- newBuilder() - Static method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
-
Creates the most basic builder possible
- newEmptyBuilder() - Static method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
-
Creates an empty builder
- 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
- NON_PARTITION - Static variable in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
- NoopCommitManager - Class in org.apache.camel.component.kafka.consumer
- NoopCommitManager(Consumer<?, ?>, KafkaConsumer, String, String) - Constructor for class org.apache.camel.component.kafka.consumer.NoopCommitManager
- NoopMetricsCollector - Class in org.apache.camel.component.kafka.consumer.devconsole
-
A NO-OP collector that is used if the metrics collector is disabled
- NoopMetricsCollector() - Constructor for class org.apache.camel.component.kafka.consumer.devconsole.NoopMetricsCollector
- NoOpPartitionAssignmentAdapter - Class in org.apache.camel.component.kafka.consumer.support.classic
-
A NO-OP resume strategy that does nothing (i.e.: no resume)
- NoOpPartitionAssignmentAdapter() - Constructor for class org.apache.camel.component.kafka.consumer.support.classic.NoOpPartitionAssignmentAdapter
- numericHeader(String) - Static method in class org.apache.camel.component.kafka.serde.KafkaSerdeHelper
O
- of(Exchange) - Static method in class org.apache.camel.component.kafka.consumer.support.resume.KafkaResumable
-
Creates a new resumable for Kafka
- offset() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.KafkaTopicPosition
-
Returns the value of the
offset
record component. - OFFSET - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- OffsetPartitionAssignmentAdapter - Class in org.apache.camel.component.kafka.consumer.support.classic
-
A resume strategy that uses Kafka's offset for resuming
- OffsetPartitionAssignmentAdapter(StateRepository<String, String>) - Constructor for class org.apache.camel.component.kafka.consumer.support.classic.OffsetPartitionAssignmentAdapter
- 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.classic.ClassicRebalanceListener
- onPartitionsAssigned(Collection<TopicPartition>) - Method in class org.apache.camel.component.kafka.consumer.support.resume.ResumeRebalanceListener
- onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.apache.camel.component.kafka.consumer.support.classic.ClassicRebalanceListener
- onPartitionsRevoked(Collection<TopicPartition>) - Method in class org.apache.camel.component.kafka.consumer.support.resume.ResumeRebalanceListener
- 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.devconsole - package org.apache.camel.component.kafka.consumer.devconsole
- 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.consumer.support.batching - package org.apache.camel.component.kafka.consumer.support.batching
- org.apache.camel.component.kafka.consumer.support.classic - package org.apache.camel.component.kafka.consumer.support.classic
- org.apache.camel.component.kafka.consumer.support.interop - package org.apache.camel.component.kafka.consumer.support.interop
- org.apache.camel.component.kafka.consumer.support.resume - package org.apache.camel.component.kafka.consumer.support.resume
- org.apache.camel.component.kafka.consumer.support.streaming - package org.apache.camel.component.kafka.consumer.support.streaming
- org.apache.camel.component.kafka.consumer.support.subcription - package org.apache.camel.component.kafka.consumer.support.subcription
- 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.component.kafka.transform - package org.apache.camel.component.kafka.transform
- 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() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.KafkaTopicPosition
-
Returns the value of the
partition
record component. - PARTITION - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- PARTITION_KEY - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- PartitionAssignmentAdapter - Interface in org.apache.camel.component.kafka.consumer.support.classic
-
Defines a adapters for handling resume operations.
- PARTITIONER_RANGE_ASSIGNOR - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- pause() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
- poll(Consumer<byte[], byte[]>, CountDownLatch) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- 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 Class 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(String, String, String, String, Exchange) - Method in class org.apache.camel.component.kafka.transform.MessageTimestampRouter
- process(String, String, String, Exchange) - Method in class org.apache.camel.component.kafka.transform.ReplaceField
- process(String, String, String, Exchange) - Method in class org.apache.camel.component.kafka.transform.TimestampRouter
- process(String, String, Exchange) - Method in class org.apache.camel.component.kafka.transform.MaskField
- process(String, String, Exchange) - Method in class org.apache.camel.component.kafka.transform.RegexRouter
- process(String, Exchange) - Method in class org.apache.camel.component.kafka.transform.HoistField
- process(String, Exchange) - Method in class org.apache.camel.component.kafka.transform.ValueToKey
- process(Exchange) - Method in class org.apache.camel.component.kafka.BatchManualCommit
- process(Exchange) - Method in class org.apache.camel.component.kafka.KafkaHeaderDeserializer
- process(Exchange) - Method in class org.apache.camel.component.kafka.KafkaProducer
- process(Exchange) - Method in class org.apache.camel.component.kafka.ManualCommit
- process(Exchange) - Method in class org.apache.camel.component.kafka.transform.DropField
- process(Exchange) - Method in class org.apache.camel.component.kafka.transform.ExtractField
- process(Exchange) - Method in class org.apache.camel.component.kafka.transform.InsertField
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.kafka.KafkaProducer
- ProcessingResult - Class in org.apache.camel.component.kafka.consumer.support
-
Holds the result of processing one or more consumer records
- ProcessingResult(boolean, boolean) - Constructor for class org.apache.camel.component.kafka.consumer.support.ProcessingResult
-
Constructs a new processing result
- ProcessingResult(boolean, boolean, String, int, long) - Constructor for class org.apache.camel.component.kafka.consumer.support.ProcessingResult
-
Constructs a new processing result
- processPolledRecords(ConsumerRecords<Object, Object>) - Method in class org.apache.camel.component.kafka.consumer.support.batching.KafkaRecordBatchingProcessorFacade
- processPolledRecords(ConsumerRecords<Object, Object>) - Method in interface org.apache.camel.component.kafka.consumer.support.KafkaRecordProcessorFacade
-
Sends a set of records polled from Kafka for processing
- processPolledRecords(ConsumerRecords<Object, Object>) - Method in class org.apache.camel.component.kafka.consumer.support.streaming.KafkaRecordStreamingProcessorFacade
- produce(byte[], byte[], ResumeStrategy.UpdateCallBack) - 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
- PropagatedHeadersProvider - Class in org.apache.camel.component.kafka.producer.support
-
Used to provide individual kafka header values if feature "batchWithIndividualHeaders" is enabled.
- PropagatedHeadersProvider(KafkaProducer, KafkaConfiguration, Exchange, Message) - Constructor for class org.apache.camel.component.kafka.producer.support.PropagatedHeadersProvider
- propagateHeaders(KafkaConfiguration, ConsumerRecord<Object, Object>, Exchange) - Method in class org.apache.camel.component.kafka.consumer.support.KafkaRecordProcessor
- propertyNames() - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
R
- RECONNECT - Enum constant in enum class 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
- RegexRouter - Class in org.apache.camel.component.kafka.transform
- RegexRouter() - Constructor for class org.apache.camel.component.kafka.transform.RegexRouter
- remove() - Method in class org.apache.camel.component.kafka.producer.support.KeyValueHolderIterator
- remove(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- ReplaceField - Class in org.apache.camel.component.kafka.transform
- ReplaceField() - Constructor for class org.apache.camel.component.kafka.transform.ReplaceField
- 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
- resolveStaticUri(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
- resume() - Method in class org.apache.camel.component.kafka.consumer.support.resume.KafkaResumeAdapter
- resume() - Method in class org.apache.camel.component.kafka.KafkaFetchRecords
- ResumeRebalanceListener - Class in org.apache.camel.component.kafka.consumer.support.resume
- ResumeRebalanceListener(String, KafkaConfiguration, CommitManager, Consumer<?, ?>, ResumeStrategy) - Constructor for class org.apache.camel.component.kafka.consumer.support.resume.ResumeRebalanceListener
- resumeStrategyService() - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfiguration
- RETRY - Enum constant in enum class 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
- saveStateToOffsetRepository(TopicPartition, long, StateRepository<String, String>) - Method in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
- secretPropertyNames() - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
- SeekPolicy - Enum Class in org.apache.camel.component.kafka
-
BEGINNING configures the consumer to consume from the beginning of the topic/partition.
- SeekPolicyPartitionAssignmentAdapter - Class in org.apache.camel.component.kafka.consumer.support.classic
-
A resume strategy that uses Camel's seekTo configuration for resuming
- SeekPolicyPartitionAssignmentAdapter(SeekPolicy) - Constructor for class org.apache.camel.component.kafka.consumer.support.classic.SeekPolicyPartitionAssignmentAdapter
- 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.AbstractCommitManager
- serializeOffsetKey(TopicPartition) - Static method in class org.apache.camel.component.kafka.consumer.support.classic.OffsetPartitionAssignmentAdapter
- serializeOffsetValue(long) - Static method in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
- setAdapter(ResumeAdapter) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- 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.`., e.g.: `additionalProperties.transactional.id=12345invalid input: '&additionalProperties'.schema.registry.url=http://localhost:8811/avro`.
- 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
- setBatching(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Whether to use batching for processing or streaming.
- setBatchingIntervalMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
In consumer batching mode, then this option is specifying a time in millis, to trigger batch completion eager when the current batch size has not reached the maximum size defined by maxPollRecords.
- setBatchWithIndividualHeaders(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
If this feature is enabled and a single element of a batch is an Exchange or Message, the producer will generate individual kafka header values for it by using the batch Message to determine the values.
- setBootstrapServers(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
-
Sets the bootstrap.servers property on the internal Kafka producer and consumer.
- 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.
- setCache(ResumeCache<?>) - Method in class org.apache.camel.component.kafka.consumer.support.resume.KafkaResumeAdapter
- setCamelContext(CamelContext) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
- setCamelContext(CamelContext) - Method in class org.apache.camel.component.kafka.serde.DefaultKafkaHeaderSerializer
- setCamelContext(CamelContext) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- setCamelContext(CamelContext) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- setCharset(Charset) - Method in class org.apache.camel.component.kafka.serde.ToStringKafkaHeaderDeserializer
- 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 class org.apache.camel.component.kafka.consumer.support.classic.NoOpPartitionAssignmentAdapter
- setConsumer(Consumer<?, ?>) - Method in class org.apache.camel.component.kafka.consumer.support.classic.OffsetPartitionAssignmentAdapter
- setConsumer(Consumer<?, ?>) - Method in interface org.apache.camel.component.kafka.consumer.support.classic.PartitionAssignmentAdapter
-
Sets the Kafka consumer instance for the adapter.
- setConsumer(Consumer<?, ?>) - Method in class org.apache.camel.component.kafka.consumer.support.classic.SeekPolicyPartitionAssignmentAdapter
- setConsumer(Consumer<?, ?>) - Method in class org.apache.camel.component.kafka.consumer.support.resume.KafkaResumeAdapter
- 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(String) - Method in class org.apache.camel.component.kafka.KafkaHeaderDeserializer
- setEnableIdempotence(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
When 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 enough data to immediately satisfy fetch.min.bytes
- setField(String) - Method in class org.apache.camel.component.kafka.transform.DropField
- setField(String) - Method in class org.apache.camel.component.kafka.transform.ExtractField
- setField(String) - Method in class org.apache.camel.component.kafka.transform.InsertField
- 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.
- setGroupId(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
-
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 the Camel message.
- setHeaderOutput(boolean) - Method in class org.apache.camel.component.kafka.transform.ExtractField
- setHeaderOutputName(String) - Method in class org.apache.camel.component.kafka.transform.ExtractField
- 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
andKafkaProducer
instances. - setKafkaClientFactory(KafkaClientFactory) - Method in class org.apache.camel.component.kafka.KafkaEndpoint
-
Factory to use for creating
KafkaConsumer
andKafkaProducer
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. - setKerberosBeforeReloginMinTime(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Login thread sleep time between refresh attempts.
- setKerberosConfigLocation(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Location of the kerberos config file.
- 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 the 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 the KafkaProducer's send(), partitionsFor(), initTransactions(), sendOffsetsToTransaction(), commitTransaction() and abortTransaction() methods 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.
- setMaxInitializationDuration(Duration) - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfiguration
- setMaxInitializationRetries(int) - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfiguration
- setMaxPartitionFetchBytes(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The maximum amount of data per-partition the server will return.
- setMaxPollIntervalMs(Integer) - 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 window of time a metrics sample is computed over.
- 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 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.
- setPartitionerIgnoreKeys(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- 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.
- setPreValidateHostAndPort(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Whether to eager validate that broker host:port is valid and can be DNS resolved to known host during starting this consumer.
- 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
- setResumeStrategyConfiguration(ResumeStrategyConfiguration) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- 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 that has failed to be sent due to a potentially transient error.
- setRetryBackoffMaxMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The maximum amount of time in milliseconds to wait when retrying a request to the broker that has repeatedly failed.
- setRetryBackoffMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The amount of time to wait before attempting to retry a failed request to a given topic partition.
- 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 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 should read from the beginning or the end on startup: SeekPolicy.BEGINNING: read from the 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 shut down 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 in multiple Schema registries documentation with Avro Deserializers implementation.
- 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 or the PEM key specified in sslKeystoreKey.
- 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.
- 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.
- setStartupOnly(boolean) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
-
Whether to sync on startup only, or to continue syncing while Camel is running.
- setStrictHeaderCheck(boolean) - Method in class org.apache.camel.component.kafka.transform.ExtractField
- 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.
- setSubscribeConsumerTopicMustExists(boolean) - Method in class org.apache.camel.component.kafka.KafkaComponent
-
Whether when a Camel Kafka consumer is subscribing to a Kafka broker then check whether a topic already exist on the broker, and fail if it does not.
- 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).
- setTrimField(boolean) - Method in class org.apache.camel.component.kafka.transform.ExtractField
- setupExchangeMessage(Message, ConsumerRecord<Object, Object>) - Method in class org.apache.camel.component.kafka.consumer.support.KafkaRecordProcessor
- setUseGlobalSslContextParameters(boolean) - Method in class org.apache.camel.component.kafka.KafkaComponent
-
Enable usage of global SSL context parameters.
- setUseIterator(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Sets whether sending to kafka should send the message body as a single record, or use a java.util.Iterator to send multiple records to kafka (if the message body can be iterated).
- setValue(String) - Method in class org.apache.camel.component.kafka.transform.InsertField
- 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 acknowledged the message that was sent to it fromKafkaProducer
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 acknowledged the message that was sent to it fromKafkaProducer
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 acknowledged the message that was sent to it fromKafkaProducer
using asynchronous non-blocking processing. - shouldBeFiltered(Header, Exchange, HeaderFilterStrategy) - Method in class org.apache.camel.component.kafka.consumer.support.KafkaRecordProcessor
- SingleNodeKafkaResumeStrategy - Class in org.apache.camel.processor.resume.kafka
-
A resume strategy that publishes offsets to a Kafka topic.
- SingleNodeKafkaResumeStrategy() - Constructor for class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- SingleNodeKafkaResumeStrategy(KafkaResumeStrategyConfiguration) - Constructor for class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
-
Builds an instance of this class
- SingleNodeKafkaResumeStrategy(KafkaResumeStrategyConfiguration, ExecutorService) - 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.SingleNodeKafkaResumeStrategy
- STOP - Enum constant in enum class 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
- storeLastRecord(ProcessingResult) - Method in class org.apache.camel.component.kafka.consumer.devconsole.DefaultMetricsCollector
- storeLastRecord(ProcessingResult) - Method in interface org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector
- storeLastRecord(ProcessingResult) - Method in class org.apache.camel.component.kafka.consumer.devconsole.NoopMetricsCollector
- storeMetadata(Consumer<?, ?>) - Method in class org.apache.camel.component.kafka.consumer.devconsole.DefaultMetricsCollector
- storeMetadata(Consumer<?, ?>) - Method in interface org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector
- storeMetadata(Consumer<?, ?>) - Method in class org.apache.camel.component.kafka.consumer.devconsole.NoopMetricsCollector
- strategies(KafkaFetchRecords, KafkaEndpoint, Consumer<?, ?>) - Static method in class org.apache.camel.component.kafka.consumer.errorhandler.KafkaErrorStrategies
- subscribe(Consumer<?, ?>, ConsumerRebalanceListener, TopicInfo) - Method in class org.apache.camel.component.kafka.consumer.support.subcription.DefaultSubscribeAdapter
- subscribe(Consumer<?, ?>, ConsumerRebalanceListener, TopicInfo) - Method in interface org.apache.camel.component.kafka.consumer.support.subcription.SubscribeAdapter
-
Handle the subscription to a Kafka topic
- SubscribeAdapter - Interface in org.apache.camel.component.kafka.consumer.support.subcription
-
A pluggable adapter for handling custom subscriptions
- 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
- tasks() - Method in class org.apache.camel.component.kafka.KafkaConsumer
- threadId - Variable in class org.apache.camel.component.kafka.consumer.AbstractCommitManager
- threadId - Variable in class org.apache.camel.component.kafka.consumer.KafkaManualCommitFactory.CamelExchangePayload
- threadId - Variable in class org.apache.camel.component.kafka.consumer.support.AbstractKafkaRecordProcessorFacade
- TIMESTAMP - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- TimestampRouter - Class in org.apache.camel.component.kafka.transform
- TimestampRouter() - Constructor for class org.apache.camel.component.kafka.transform.TimestampRouter
- topic() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.KafkaTopicPosition
-
Returns the value of the
topic
record component. - TOPIC - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- TopicHelper - Class in org.apache.camel.component.kafka.consumer.support
- TopicInfo - Class in org.apache.camel.component.kafka.consumer.support.subcription
-
Carries topic information
- TopicInfo(Pattern, String) - Constructor for class org.apache.camel.component.kafka.consumer.support.subcription.TopicInfo
- toString() - Method in class org.apache.camel.component.kafka.consumer.DefaultKafkaManualCommit
- toString() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.GroupMetadata
-
Returns a string representation of this record class.
- toString() - Method in record class org.apache.camel.component.kafka.consumer.devconsole.DevConsoleMetricsCollector.KafkaTopicPosition
-
Returns a string representation of this record class.
- ToStringKafkaHeaderDeserializer - Class in org.apache.camel.component.kafka.serde
- ToStringKafkaHeaderDeserializer() - Constructor for class org.apache.camel.component.kafka.serde.ToStringKafkaHeaderDeserializer
- ToStringKafkaHeaderDeserializer(Charset) - Constructor for class org.apache.camel.component.kafka.serde.ToStringKafkaHeaderDeserializer
- tryConvertToSerializedType(Exchange, Object, String) - Static method in class org.apache.camel.component.kafka.producer.support.ProducerUtil
U
- updateClassProperties(Properties) - Method in class org.apache.camel.component.kafka.KafkaEndpoint
- updateLastOffset(OffsetKey<?>, Offset<?>) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- updateLastOffset(OffsetKey<?>, Offset<?>, ResumeStrategy.UpdateCallBack) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- updateLastOffset(T) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
- updateLastOffset(T, ResumeStrategy.UpdateCallBack) - Method in class org.apache.camel.processor.resume.kafka.SingleNodeKafkaResumeStrategy
V
- valueOf(String) - Static method in enum class org.apache.camel.component.kafka.PollOnError
-
Returns the enum constant of this class with the specified name.
- valueOf(String) - Static method in enum class org.apache.camel.component.kafka.SeekPolicy
-
Returns the enum constant of this class with the specified name.
- values() - Static method in enum class org.apache.camel.component.kafka.PollOnError
-
Returns an array containing the constants of this enum class, in the order they are declared.
- values() - Static method in enum class org.apache.camel.component.kafka.SeekPolicy
-
Returns an array containing the constants of this enum class, in the order they are declared.
- ValueToKey - Class in org.apache.camel.component.kafka.transform
- ValueToKey() - Constructor for class org.apache.camel.component.kafka.transform.ValueToKey
W
- withBootstrapServers(String) - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
- withCacheFillPolicy(Cacheable.FillPolicy) - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
- withConsumerProperty(String, Object) - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
- withEnableAutoCommit(boolean) - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
- withGroupId(String) - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
- withMaxInitializationDuration(Duration) - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
- withMaxInitializationRetries(int) - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
- withProducerProperty(String, Object) - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
- withTopic(String) - Method in class org.apache.camel.processor.resume.kafka.KafkaResumeStrategyConfigurationBuilder
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
DefaultKafkaManualCommit.getCamelExchangePayload()