@UriEndpoint(firstVersion="2.17.0", scheme="aws-kinesis", title="AWS Kinesis", syntax="aws-kinesis:streamName", consumerClass=KinesisConsumer.class, label="cloud,messaging") public class KinesisEndpoint extends org.apache.camel.impl.ScheduledPollEndpoint
Constructor and Description |
---|
KinesisEndpoint(String uri,
KinesisConfiguration configuration,
KinesisComponent component) |
Modifier and Type | Method and Description |
---|---|
org.apache.camel.Consumer |
createConsumer(org.apache.camel.Processor processor) |
org.apache.camel.Exchange |
createExchange(com.amazonaws.services.kinesis.model.Record record) |
org.apache.camel.Producer |
createProducer() |
protected void |
doStart() |
void |
doStop() |
com.amazonaws.services.kinesis.AmazonKinesis |
getClient() |
KinesisConfiguration |
getConfiguration() |
boolean |
isSingleton() |
configurePollingConsumer, configureProperties, configureScheduledPollConsumerProperties, getBackoffErrorThreshold, getBackoffIdleThreshold, getBackoffMultiplier, getDelay, getInitialDelay, getPollStrategy, getRunLoggingLevel, getScheduledExecutorService, getScheduler, getSchedulerProperties, getTimeUnit, initConsumerProperties, isGreedy, isSendEmptyMessageWhenIdle, isStartScheduler, isUseFixedDelay, setBackoffErrorThreshold, setBackoffIdleThreshold, setBackoffMultiplier, setDelay, setGreedy, setInitialDelay, setPollStrategy, setRunLoggingLevel, setScheduledExecutorService, setScheduler, setScheduler, setSchedulerProperties, setSendEmptyMessageWhenIdle, setStartScheduler, setTimeUnit, setUseFixedDelay
configureConsumer, createEndpointConfiguration, createEndpointUri, createExchange, createExchange, createExchange, createPollingConsumer, 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 KinesisEndpoint(String uri, KinesisConfiguration configuration, KinesisComponent component)
protected void doStart() throws Exception
doStart
in class org.apache.camel.impl.ScheduledPollEndpoint
Exception
public void doStop() throws Exception
doStop
in class org.apache.camel.impl.ScheduledPollEndpoint
Exception
public org.apache.camel.Consumer createConsumer(org.apache.camel.Processor processor) throws Exception
Exception
public org.apache.camel.Exchange createExchange(com.amazonaws.services.kinesis.model.Record record)
public boolean isSingleton()
public com.amazonaws.services.kinesis.AmazonKinesis getClient()
public KinesisConfiguration getConfiguration()
Apache Camel