@UriEndpoint(scheme="kafka", title="Kafka", syntax="kafka:brokers", consumerClass=KafkaConsumer.class, label="messaging") public class KafkaEndpoint extends org.apache.camel.impl.DefaultEndpoint implements org.apache.camel.MultipleConsumersSupport
Constructor and Description |
---|
KafkaEndpoint() |
KafkaEndpoint(String endpointUri,
KafkaComponent component) |
configureConsumer, configurePollingConsumer, configureProperties, createEndpointConfiguration, createEndpointUri, createExchange, createExchange, createExchange, createPollingConsumer, doStart, doStop, equals, getCamelContext, getComponent, getConsumerProperties, getEndpointConfiguration, getEndpointKey, getEndpointUri, getExceptionHandler, getExchangePattern, getId, getPollingConsumerBlockTimeout, getPollingConsumerQueueSize, hashCode, isBridgeErrorHandler, isLenientProperties, isPollingConsumerBlockWhenFull, isSynchronous, setBridgeErrorHandler, setCamelContext, setConsumerProperties, setEndpointConfiguration, setEndpointUri, setEndpointUriIfNotSpecified, setExceptionHandler, setExchangePattern, setPollingConsumerBlockTimeout, setPollingConsumerBlockWhenFull, setPollingConsumerQueueSize, setProperties, setSynchronous, toString
doResume, doShutdown, doSuspend, getStatus, getVersion, isRunAllowed, isStarted, isStarting, isStopped, isStopping, isStoppingOrStopped, isSuspended, isSuspending, isSuspendingOrSuspended, resume, shutdown, start, stop, suspend
public KafkaEndpoint()
public KafkaEndpoint(String endpointUri, KafkaComponent component)
public KafkaConfiguration getConfiguration()
public void setConfiguration(KafkaConfiguration configuration)
protected KafkaConfiguration createConfiguration()
public org.apache.camel.Consumer createConsumer(org.apache.camel.Processor processor) throws Exception
createConsumer
in interface org.apache.camel.Endpoint
Exception
public org.apache.camel.Producer createProducer() throws Exception
createProducer
in interface org.apache.camel.Endpoint
Exception
public boolean isSingleton()
isSingleton
in interface org.apache.camel.IsSingleton
public boolean isMultipleConsumersSupported()
isMultipleConsumersSupported
in interface org.apache.camel.MultipleConsumersSupport
public void updateClassProperties(Properties props)
public ExecutorService createExecutor()
public ExecutorService createProducerExecutor()
public org.apache.camel.Exchange createKafkaExchange(org.apache.kafka.clients.consumer.ConsumerRecord record)
protected KafkaProducer createProducer(KafkaEndpoint endpoint)
public Properties createProducerProperties()
public void setValueDeserializer(String valueDeserializer)
public void setRequestTimeoutMs(Integer requestTimeoutMs)
public void setProducerBatchSize(Integer producerBatchSize)
public void setRetryBackoffMs(Integer retryBackoffMs)
public void setNoOfMetricsSample(Integer noOfMetricsSample)
public String getMetricReporters()
public void setSslKeystoreType(String sslKeystoreType)
public void setSslCipherSuites(String sslCipherSuites)
public void setClientId(String clientId)
public void setMetricsSampleWindowMs(Integer metricsSampleWindowMs)
public String getKeyDeserializer()
public int getConsumersCount()
public String getSslKeyPassword()
public void setSendBufferBytes(Integer sendBufferBytes)
public Boolean isAutoCommitEnable()
public Integer getMaxBlockMs()
public String getConsumerId()
public void setSslProtocol(String sslProtocol)
public void setReceiveBufferBytes(Integer receiveBufferBytes)
public Boolean getCheckCrcs()
public void setGroupId(String groupId)
public String getCompressionCodec()
public String getGroupId()
public void setSslTruststoreLocation(String sslTruststoreLocation)
public String getKerberosInitCmd()
public String getAutoOffsetReset()
public void setAutoCommitEnable(Boolean autoCommitEnable)
public void setSerializerClass(String serializerClass)
public Integer getQueueBufferingMaxMessages()
public void setSslEndpointAlgorithm(String sslEndpointAlgorithm)
public void setRetries(Integer retries)
public void setAutoOffsetReset(String autoOffsetReset)
public Integer getSessionTimeoutMs()
public Integer getBufferMemorySize()
public String getKeySerializerClass()
public void setSslProvider(String sslProvider)
public void setFetchMinBytes(Integer fetchMinBytes)
public Integer getAutoCommitIntervalMs()
public void setKeySerializerClass(String keySerializerClass)
public Integer getConnectionMaxIdleMs()
public Integer getReceiveBufferBytes()
public void setBrokers(String brokers)
public String getValueDeserializer()
public String getPartitioner()
public String getSslTruststoreLocation()
public void setBarrierAwaitTimeoutMs(int barrierAwaitTimeoutMs)
public String getSslProvider()
public void setMetricReporters(String metricReporters)
public void setSslTruststorePassword(String sslTruststorePassword)
public void setMaxInFlightRequest(Integer maxInFlightRequest)
public String getTopic()
public int getBarrierAwaitTimeoutMs()
public Integer getFetchMinBytes()
public Integer getHeartbeatIntervalMs()
public void setKeyDeserializer(String keyDeserializer)
public Integer getMaxRequestSize()
public void setMetadataMaxAgeMs(Integer metadataMaxAgeMs)
public String getSslKeystoreType()
public void setKerberosRenewWindowFactor(Double kerberosRenewWindowFactor)
public Integer getKerberosBeforeReloginMinTime()
public String getSslEnabledProtocols()
public Integer getMaxInFlightRequest()
public Integer getProducerBatchSize()
public void setSslKeystorePassword(String sslKeystorePassword)
public void setCheckCrcs(Boolean checkCrcs)
public int getConsumerStreams()
public void setConsumersCount(int consumersCount)
public int getBatchSize()
public void setAutoCommitIntervalMs(Integer autoCommitIntervalMs)
public void setSslTruststoreType(String sslTruststoreType)
public Integer getConsumerRequestTimeoutMs()
public String getSslKeystorePassword()
public void setSslKeyPassword(String sslKeyPassword)
public String getRequestRequiredAcks()
public Double getKerberosRenewWindowFactor()
public void setKerberosInitCmd(String kerberosInitCmd)
public Integer getRetryBackoffMs()
public void setSslTrustmanagerAlgorithm(String sslTrustmanagerAlgorithm)
public void setConsumerRequestTimeoutMs(Integer consumerRequestTimeoutMs)
public void setReconnectBackoffMs(Integer reconnectBackoffMs)
public void setKerberosRenewJitter(Double kerberosRenewJitter)
public String getSslKeystoreLocation()
public Integer getNoOfMetricsSample()
public String getSslKeymanagerAlgorithm()
public void setConsumerId(String consumerId)
public String getClientId()
public void setFetchWaitMaxMs(Integer fetchWaitMaxMs)
public String getSslCipherSuites()
public void setRequestRequiredAcks(String requestRequiredAcks)
public void setConnectionMaxIdleMs(Integer connectionMaxIdleMs)
public String getSslTrustmanagerAlgorithm()
public String getSslTruststorePassword()
public void setConsumerStreams(int consumerStreams)
public String getSslTruststoreType()
public String getSecurityProtocol()
public void setBufferMemorySize(Integer bufferMemorySize)
public void setSaslKerberosServiceName(String saslKerberosServiceName)
public void setCompressionCodec(String compressionCodec)
public void setKerberosBeforeReloginMinTime(Integer kerberosBeforeReloginMinTime)
public Integer getMetadataMaxAgeMs()
public String getSerializerClass()
public void setSslKeymanagerAlgorithm(String sslKeymanagerAlgorithm)
public void setMaxRequestSize(Integer maxRequestSize)
public Double getKerberosRenewJitter()
public String getPartitionAssignor()
public void setSecurityProtocol(String securityProtocol)
public void setQueueBufferingMaxMessages(Integer queueBufferingMaxMessages)
public String getSaslKerberosServiceName()
public void setBatchSize(int batchSize)
public Integer getLingerMs()
public Integer getRetries()
public Integer getMaxPartitionFetchBytes()
public String getSslEndpointAlgorithm()
public Integer getReconnectBackoffMs()
public void setLingerMs(Integer lingerMs)
public void setPartitionAssignor(String partitionAssignor)
public Integer getRequestTimeoutMs()
public Properties createConsumerProperties()
public void setTopic(String topic)
public Integer getFetchWaitMaxMs()
public void setSessionTimeoutMs(Integer sessionTimeoutMs)
public void setSslEnabledProtocols(String sslEnabledProtocols)
public void setHeartbeatIntervalMs(Integer heartbeatIntervalMs)
public void setMaxBlockMs(Integer maxBlockMs)
public void setSslKeystoreLocation(String sslKeystoreLocation)
public void setMaxPartitionFetchBytes(Integer maxPartitionFetchBytes)
public void setPartitioner(String partitioner)
public String getBrokers()
public Integer getMetricsSampleWindowMs()
public Integer getSendBufferBytes()
public String getSslProtocol()
public boolean isBridgeEndpoint()
public void setBridgeEndpoint(boolean bridgeEndpoint)
public void setWorkerPool(ExecutorService workerPool)
public void setWorkerPoolMaxSize(Integer workerPoolMaxSize)
public Integer getWorkerPoolMaxSize()
public Integer getWorkerPoolCoreSize()
public ExecutorService getWorkerPool()
public void setWorkerPoolCoreSize(Integer workerPoolCoreSize)
Apache Camel