A B C D E G H I K L M N O P R S T U V
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- add(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
B
- buildUri(String, Map<String, Object>, boolean) - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
C
- clear() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- commitOffset(StateRepository<String, String>, TopicPartition, long) - Method in class org.apache.camel.component.kafka.DefaultKafkaManualCommit
- commitSync() - Method in class org.apache.camel.component.kafka.DefaultKafkaManualCommit
- commitSync() - Method in interface org.apache.camel.component.kafka.KafkaManualCommit
-
Commit synchronously.
- configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.component.kafka.KafkaComponentConfigurer
- configure(CamelContext, Object, String, Object, boolean) - Method in class org.apache.camel.component.kafka.KafkaEndpointConfigurer
- confirm(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- 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
- createConsumer(Processor) - Method in class org.apache.camel.component.kafka.KafkaEndpoint
- createConsumerProperties() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- createEndpoint(String, String, Map<String, Object>) - Method in class org.apache.camel.component.kafka.KafkaComponent
- createExecutor() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
- 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
- createRecorder(Exchange) - 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
- DefaultKafkaManualCommit - Class in org.apache.camel.component.kafka
- DefaultKafkaManualCommit(KafkaConsumer, String, String, StateRepository<String, String>, TopicPartition, long) - Constructor for class org.apache.camel.component.kafka.DefaultKafkaManualCommit
- DefaultKafkaManualCommitFactory - Class in org.apache.camel.component.kafka
- DefaultKafkaManualCommitFactory() - Constructor for class org.apache.camel.component.kafka.DefaultKafkaManualCommitFactory
- DefaultPollExceptionStrategy - Class in org.apache.camel.component.kafka
- DefaultPollExceptionStrategy() - Constructor for class org.apache.camel.component.kafka.DefaultPollExceptionStrategy
- DefaultPollExceptionStrategy(PollOnError) - Constructor for class org.apache.camel.component.kafka.DefaultPollExceptionStrategy
- deserialize(String, byte[]) - Method in class org.apache.camel.component.kafka.serde.DefaultKafkaHeaderDeserializer
- deserialize(String, byte[]) - Method in interface org.apache.camel.component.kafka.serde.KafkaHeaderDeserializer
- deserializeOffsetValue(String) - Method in class org.apache.camel.component.kafka.KafkaConsumer
- DISCARD - org.apache.camel.component.kafka.PollOnError
- doBuild() - Method in class org.apache.camel.component.kafka.KafkaConsumer
- doBuild() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
- 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
E
- ERROR_HANDLER - org.apache.camel.component.kafka.PollOnError
- executor - Variable in class org.apache.camel.component.kafka.KafkaConsumer
G
- 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
- getAutoCommitOnStop() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getAutoOffsetReset() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getAutowiredNames() - Method in class org.apache.camel.component.kafka.KafkaComponentConfigurer
- getBootstrapServers() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- getBrokers() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getBrokers(KafkaConfiguration) - Method in class org.apache.camel.component.kafka.DefaultKafkaClientFactory
- getBrokers(KafkaConfiguration) - Method in interface org.apache.camel.component.kafka.KafkaClientFactory
-
URL of the Kafka brokers to use.
- getBufferMemorySize() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getCamelContext() - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
- getCamelContext() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- getCheckCrcs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getClientId() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- 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
- 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.DefaultKafkaManualCommit
- 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
KafkaConsumer
class. - getConsumerConfig() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- getConsumerRequestTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getConsumersCount() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getConsumerStreams() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getDeliveryTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getDuplicateCount() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- getEndpoint() - Method in class org.apache.camel.component.kafka.KafkaConsumer
- getFetchMaxBytes() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The maximum amount of data the server should return for a fetch request This is not an absolute maximum, if the first message in the first non-empty partition of the fetch is larger than this value, the message will still be returned to ensure that the consumer can make progress.
- getFetchMinBytes() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getFetchWaitMaxMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getGroupId() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getGroupInstanceId() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getHeaderDeserializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getHeaderFilterStrategy() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getHeaderSerializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getHeartbeatIntervalMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getInterceptorClasses() - 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
- getKafkaProducer() - Method in class org.apache.camel.component.kafka.KafkaProducer
- getKerberosBeforeReloginMinTime() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getKerberosInitCmd() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getKerberosPrincipalToLocalRules() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getKerberosRenewJitter() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getKerberosRenewWindowFactor() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getKey() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getKeyDeserializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getKeySerializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getLingerMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getMaxBlockMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getMaxCacheSize() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- getMaxInFlightRequest() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getMaxPartitionFetchBytes() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getMaxPollIntervalMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getMaxPollRecords() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getMaxRequestSize() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getMetadataMaxAgeMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getMetricReporters() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getMetricsSampleWindowMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getNoOfMetricsSample() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getOffsetRepository() - Method in class org.apache.camel.component.kafka.DefaultKafkaManualCommit
- getOffsetRepository() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getOptionType(String, boolean) - Method in class org.apache.camel.component.kafka.KafkaComponentConfigurer
- getOptionType(String, boolean) - Method in class org.apache.camel.component.kafka.KafkaEndpointConfigurer
- getOptionValue(Object, String, boolean) - Method in class org.apache.camel.component.kafka.KafkaComponentConfigurer
- getOptionValue(Object, String, boolean) - Method in class org.apache.camel.component.kafka.KafkaEndpointConfigurer
- getPartition() - Method in class org.apache.camel.component.kafka.DefaultKafkaManualCommit
- getPartitionAssignor() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getPartitioner() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getPartitionKey() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getPollDurationMs() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- getPollExceptionStrategy() - Method in class org.apache.camel.component.kafka.KafkaComponent
- getPollOnError() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getPollTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getProducer(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
KafkaProducer
class. - getProducerBatchSize() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getProducerConfig() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- 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
- getRecordOffset() - Method in class org.apache.camel.component.kafka.DefaultKafkaManualCommit
- getRequestRequiredAcks() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getRequestTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getRetries() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getRetryBackoffMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSaslJaasConfig() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSaslKerberosServiceName() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSaslMechanism() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSchemaRegistryURL() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getScheme() - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
- getSecurityProtocol() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSeekTo() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSendBufferBytes() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSessionTimeoutMs() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getShutdownTimeout() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslCipherSuites() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslContextParameters() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslEnabledProtocols() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslEndpointAlgorithm() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslKeymanagerAlgorithm() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslKeyPassword() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslKeystoreLocation() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslKeystorePassword() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslKeystoreType() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslProtocol() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslProvider() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslTrustmanagerAlgorithm() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslTruststoreLocation() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslTruststorePassword() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getSslTruststoreType() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getThreadId() - Method in class org.apache.camel.component.kafka.DefaultKafkaManualCommit
- getTopic() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getTopic() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- getTopicName() - Method in class org.apache.camel.component.kafka.DefaultKafkaManualCommit
- getValueDeserializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getValueSerializer() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getWorkerPool() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getWorkerPool() - Method in class org.apache.camel.component.kafka.KafkaProducer
- getWorkerPoolCoreSize() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- getWorkerPoolMaxSize() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
H
- handleException(Exception) - Method in class org.apache.camel.component.kafka.DefaultPollExceptionStrategy
- handleException(Exception) - Method in interface org.apache.camel.component.kafka.PollExceptionStrategy
-
Controls how to handle the exception while polling from Kafka.
- HEADERS - Static variable in class org.apache.camel.component.kafka.KafkaConstants
I
- initialize() - Method in class org.apache.camel.component.kafka.KafkaHeaderFilterStrategy
- isAllowManualCommit() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isAutoCommitEnable() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isBreakOnFirstError() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isEnabled(String) - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
- isEnableIdempotence() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isLenientProperties() - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
- isLenientProperties() - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
- isMultipleConsumersSupported() - Method in class org.apache.camel.component.kafka.KafkaEndpoint
- isPollerRunning() - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- isRecordMetadata() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isSpecificAvroReader() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isSynchronous() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isTopicIsPattern() - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- isUseGlobalSslContextParameters() - Method in class org.apache.camel.component.kafka.KafkaComponent
K
- KAFKA_DEFAULT_DESERIALIZER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- KAFKA_DEFAULT_ENCODER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
-
Deprecated.
- KAFKA_DEFAULT_PARTITIONER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- KAFKA_DEFAULT_SERIALIZER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- KAFKA_RECORDMETA - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- KAFKA_STRING_ENCODER - Static variable in class org.apache.camel.component.kafka.KafkaConstants
-
Deprecated.
- KafkaClientFactory - Interface in org.apache.camel.component.kafka
-
Factory to create a new
KafkaConsumer
andKafkaProducer
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 - Class in org.apache.camel.component.kafka
- KafkaConsumer(KafkaEndpoint, Processor) - Constructor for class org.apache.camel.component.kafka.KafkaConsumer
- 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
- KafkaHeaderDeserializer - Interface in org.apache.camel.component.kafka.serde
-
Deserializer for kafka header value.
- KafkaHeaderFilterStrategy - Class in org.apache.camel.component.kafka
- KafkaHeaderFilterStrategy() - Constructor for class org.apache.camel.component.kafka.KafkaHeaderFilterStrategy
- KafkaHeaderSerializer - Interface in org.apache.camel.component.kafka.serde
-
Serializer for kafka header value.
- KafkaIdempotentRepository - Class in org.apache.camel.processor.idempotent.kafka
-
A Kafka topic-based implementation of
IdempotentRepository
. - KafkaIdempotentRepository() - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
-
No-op constructor for XML/property-based object initialisation.
- KafkaIdempotentRepository(String, String) - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- KafkaIdempotentRepository(String, String, int, int) - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- KafkaIdempotentRepository(String, Properties, Properties) - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- KafkaIdempotentRepository(String, Properties, Properties, int, int) - Constructor for class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- KafkaManualCommit - Interface in org.apache.camel.component.kafka
-
Can be used for forcing manual offset commit when using Kafka consumer.
- KafkaManualCommitFactory - Interface in org.apache.camel.component.kafka
-
Factory to create a new
KafkaManualCommit
to store on theExchange
. - KafkaProducer - Class in org.apache.camel.component.kafka
- KafkaProducer(KafkaEndpoint) - Constructor for class org.apache.camel.component.kafka.KafkaProducer
- 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
- KEY - Static variable in class org.apache.camel.component.kafka.KafkaConstants
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
M
- MANUAL_COMMIT - Static variable in class org.apache.camel.component.kafka.KafkaConstants
N
- newInstance(Exchange, KafkaConsumer, String, String, StateRepository<String, String>, TopicPartition, long) - Method in class org.apache.camel.component.kafka.DefaultKafkaManualCommitFactory
- newInstance(Exchange, KafkaConsumer, String, String, StateRepository<String, String>, TopicPartition, long) - Method in interface org.apache.camel.component.kafka.KafkaManualCommitFactory
-
Creates a new instance
O
- OFFSET - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- org.apache.camel.component.kafka - package org.apache.camel.component.kafka
- org.apache.camel.component.kafka.serde - package org.apache.camel.component.kafka.serde
- org.apache.camel.processor.idempotent.kafka - package org.apache.camel.processor.idempotent.kafka
- 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 - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- PARTITION_KEY - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- PARTITIONER_RANGE_ASSIGNOR - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- PollExceptionStrategy - Interface in org.apache.camel.component.kafka
-
Strategy to decide when a Kafka exception was thrown during polling, how to handle this.
- PollOnError - Enum in org.apache.camel.component.kafka
-
DISCARD will discard the message and continue to poll next message.
- prepare(Exchange, String, String) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
- process(Exchange) - Method in class org.apache.camel.component.kafka.KafkaProducer
- process(Exchange, AsyncCallback) - Method in class org.apache.camel.component.kafka.KafkaProducer
- propertyNames() - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
R
- RECONNECT - org.apache.camel.component.kafka.PollOnError
- remove(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- resolveStaticUri(Exchange, SendDynamicAware.DynamicAwareEntry) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
- RETRY - org.apache.camel.component.kafka.PollOnError
S
- secretPropertyNames() - Method in class org.apache.camel.component.kafka.KafkaEndpointUriFactory
- 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) - Method in class org.apache.camel.component.kafka.DefaultKafkaManualCommit
- serializeOffsetKey(TopicPartition) - Method in class org.apache.camel.component.kafka.KafkaConsumer
- serializeOffsetValue(long) - Method in class org.apache.camel.component.kafka.DefaultKafkaManualCommit
- serializeOffsetValue(long) - Method in class org.apache.camel.component.kafka.KafkaConsumer
- setAdditionalProperties(Map<String, Object>) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Sets additional properties for either kafka consumer or kafka producer in case they can't be set directly on the camel configurations (e.g: new Kafka properties that are not reflected yet in Camel configurations), the properties have to be prefixed with `additionalProperties.`.
- setAllowManualCommit(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Whether to allow doing manual commits via
KafkaManualCommit
. - setAutoCommitEnable(Boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
If true, periodically commit to ZooKeeper the offset of messages already fetched by the consumer.
- setAutoCommitIntervalMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The frequency in ms that the consumer offsets are committed to zookeeper.
- setAutoCommitOnStop(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Whether to perform an explicit auto commit when the consumer stops to ensure the broker has a commit from the last consumed message.
- setAutoOffsetReset(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
What to do when there is no initial offset in ZooKeeper or if an offset is out of range: earliest : automatically reset the offset to the earliest offset latest : automatically reset the offset to the latest offset fail: throw exception to the consumer
- setBootstrapServers(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
-
Sets the
- setBreakOnFirstError(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
This options controls what happens when a consumer is processing an exchange and it fails.
- setBrokers(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
URL of the Kafka brokers to use.
- setBufferMemorySize(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The total bytes of memory the producer can use to buffer records waiting to be sent to the server.
- setCamelContext(CamelContext) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
- setCamelContext(CamelContext) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
- setCheckCrcs(Boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Automatically check the CRC32 of the records consumed.
- setClientId(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The client id is a user-specified string sent in each request to help trace calls.
- 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
- setConnectionMaxIdleMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Close idle connections after the number of milliseconds specified by this config.
- setConsumerConfig(Properties) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
-
Sets the properties that will be used by the Kafka consumer.
- 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
- setConsumerStreams(int) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Number of concurrent consumers on the consumer
- 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.
- setEnableIdempotence(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
If set to 'true' the producer will ensure that exactly one copy of each message is written in the stream.
- setFetchMaxBytes(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- setFetchMinBytes(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The minimum amount of data the server should return for a fetch request.
- setFetchWaitMaxMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The maximum amount of time the server will block before answering the fetch request if there isn't sufficient data to immediately satisfy fetch.min.bytes
- setGroupId(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
A string that uniquely identifies the group of consumer processes to which this consumer belongs.
- setGroupInstanceId(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
A unique identifier of the consumer instance provided by the end user.
- setHeaderDeserializer(KafkaHeaderDeserializer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Sets custom KafkaHeaderDeserializer for deserialization kafka headers values to camel headers values.
- setHeaderFilterStrategy(HeaderFilterStrategy) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
To use a custom HeaderFilterStrategy to filter header to and from Camel message.
- setHeaderSerializer(KafkaHeaderSerializer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Sets custom KafkaHeaderDeserializer for serialization camel headers values to kafka headers values.
- setHeartbeatIntervalMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The expected time between heartbeats to the consumer coordinator when using Kafka's group management facilities.
- setInterceptorClasses(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Sets interceptors for producer or consumers.
- setKafkaClientFactory(KafkaClientFactory) - Method in class org.apache.camel.component.kafka.KafkaComponent
-
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. - setKafkaProducer(KafkaProducer) - 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.
- setKerberosInitCmd(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Kerberos kinit command path.
- setKerberosPrincipalToLocalRules(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
A list of rules for mapping from principal names to short names (typically operating system usernames).
- setKerberosRenewJitter(Double) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Percentage of random jitter added to the renewal time.
- setKerberosRenewWindowFactor(Double) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Login thread will sleep until the specified window factor of time from last refresh to ticket's expiry has been reached, at which time it will try to renew the ticket.
- setKey(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The record key (or null if no key is specified).
- setKeyDeserializer(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Deserializer class for key that implements the Deserializer interface.
- setKeySerializer(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The serializer class for keys (defaults to the same as for messages if nothing is given).
- setLingerMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The producer groups together any records that arrive in between request transmissions into a single batched request.
- setMaxBlockMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The configuration controls how long sending to kafka will block.
- setMaxCacheSize(int) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
-
Sets the maximum size of the local key cache.
- setMaxInFlightRequest(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The maximum number of unacknowledged requests the client will send on a single connection before blocking.
- setMaxPartitionFetchBytes(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The maximum amount of data per-partition the server will return.
- setMaxPollIntervalMs(Long) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The maximum delay between invocations of poll() when using consumer group management.
- setMaxPollRecords(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The maximum number of records returned in a single call to poll()
- setMaxRequestSize(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The maximum size of a request.
- setMetadataMaxAgeMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The period of time in milliseconds after which we force a refresh of metadata even if we haven't seen any partition leadership changes to proactively discover any new brokers or partitions.
- setMetricReporters(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
A list of classes to use as metrics reporters.
- setMetricsSampleWindowMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The number of samples maintained to compute metrics.
- setNoOfMetricsSample(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The number of samples maintained to compute metrics.
- setOffsetRepository(StateRepository<String, String>) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The offset repository to use in order to locally store the offset of each partition of the topic.
- setPartitionAssignor(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The class name of the partition assignment strategy that the client will use to distribute partition ownership amongst consumer instances when group management is used
- setPartitioner(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The partitioner class for partitioning messages amongst sub-topics.
- setPartitionKey(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The partition to which the record will be sent (or null if no partition was specified).
- setPollDurationMs(int) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
-
Sets the poll duration of the Kafka consumer.
- setPollExceptionStrategy(PollExceptionStrategy) - Method in class org.apache.camel.component.kafka.KafkaComponent
-
To use a custom strategy with the consumer to control how to handle exceptions thrown from the Kafka broker while pooling messages.
- setPollOnError(PollOnError) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
What to do if kafka threw an exception while polling for new messages.
- setPollTimeoutMs(Long) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The timeout used when polling the KafkaConsumer.
- setProducerBatchSize(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The producer will attempt to batch records together into fewer requests whenever multiple records are being sent to the same partition.
- setProducerConfig(Properties) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
-
Sets the properties that will be used by the Kafka producer.
- setQueueBufferingMaxMessages(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The maximum number of unsent messages that can be queued up the producer when using async mode before either the producer must be blocked or data must be dropped.
- setReceiveBufferBytes(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The size of the TCP receive buffer (SO_RCVBUF) to use when reading data.
- 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. - 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.
- setRetries(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Setting a value greater than zero will cause the client to resend any record whose send fails with a potentially transient error.
- setRetryBackoffMs(Integer) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Before each retry, the producer refreshes the metadata of relevant topics to see if a new leader has been elected.
- setSaslJaasConfig(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Expose the kafka sasl.jaas.config parameter Example: org.apache.kafka.common.security.plain.PlainLoginModule required username="USERNAME" password="PASSWORD";
- setSaslKerberosServiceName(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The Kerberos principal name that Kafka runs as.
- setSaslMechanism(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The Simple Authentication and Security Layer (SASL) Mechanism used.
- setSchemaRegistryURL(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
URL of the Confluent Platform schema registry servers to use.
- setScheme(String) - Method in class org.apache.camel.component.kafka.KafkaSendDynamicAware
- setSecurityProtocol(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Protocol used to communicate with brokers.
- setSeekTo(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Set if KafkaConsumer will read from beginning or end on startup: beginning : read from beginning end : read from end This is replacing the earlier property seekToBeginning
- 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 milli seconds to wait gracefully for the consumer or producer to shutdown and terminate its worker threads.
- setSpecificAvroReader(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
This enables the use of a specific Avro reader for use with the Confluent Platform schema registry and the io.confluent.kafka.serializers.KafkaAvroDeserializer.
- setSslCipherSuites(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
A list of cipher suites.
- setSslContextParameters(SSLContextParameters) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
SSL configuration using a Camel
SSLContextParameters
object. - setSslEnabledProtocols(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The list of protocols enabled for SSL connections.
- setSslEndpointAlgorithm(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The endpoint identification algorithm to validate server hostname using server certificate.
- setSslKeymanagerAlgorithm(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The algorithm used by key manager factory for SSL connections.
- setSslKeyPassword(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The password of the private key in the key store file.
- setSslKeystoreLocation(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The location of the key store file.
- setSslKeystorePassword(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The store password for the key store file.This is optional for client and only needed if ssl.keystore.location is configured.
- setSslKeystoreType(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The file format of the key store file.
- setSslProtocol(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The SSL protocol used to generate the SSLContext.
- setSslProvider(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The name of the security provider used for SSL connections.
- setSslTrustmanagerAlgorithm(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The algorithm used by trust manager factory for SSL connections.
- setSslTruststoreLocation(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The location of the trust store file.
- setSslTruststorePassword(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The password for the trust store file.
- setSslTruststoreType(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The file format of the trust store file.
- setSynchronous(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
- setTopic(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Name of the topic to use.
- setTopic(String) - Method in class org.apache.camel.processor.idempotent.kafka.KafkaIdempotentRepository
-
Sets the name of the Kafka topic used by this idempotent repository.
- setTopicIsPattern(boolean) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Whether the topic is a pattern (regular expression).
- setUseGlobalSslContextParameters(boolean) - Method in class org.apache.camel.component.kafka.KafkaComponent
-
Enable usage of global SSL context parameters.
- setValueDeserializer(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
Deserializer class for value that implements the Deserializer interface.
- setValueSerializer(String) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
The serializer class for messages.
- setWorkerPool(ExecutorService) - Method in class org.apache.camel.component.kafka.KafkaConfiguration
-
To use a custom worker pool for continue routing
Exchange
after kafka server has acknowledge the message that was sent to it 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 acknowledge 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 acknowledge the message that was sent to it fromKafkaProducer
using asynchronous non-blocking processing. - STOP - org.apache.camel.component.kafka.PollOnError
T
- TIMESTAMP - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- TOPIC - Static variable in class org.apache.camel.component.kafka.KafkaConstants
- tryConvertToSerializedType(Exchange, Object, String) - Method in class org.apache.camel.component.kafka.KafkaProducer
-
Attempts to convert the object to the same type as the value serializer specified
U
- updateClassProperties(Properties) - Method in class org.apache.camel.component.kafka.KafkaEndpoint
V
- valueOf(String) - Static method in enum org.apache.camel.component.kafka.PollOnError
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum org.apache.camel.component.kafka.PollOnError
-
Returns an array containing the constants of this enum type, in the order they are declared.
All Classes All Packages