@UriEndpoint(firstVersion="2.19.0",
scheme="google-pubsub",
title="Google Pubsub",
syntax="google-pubsub:projectId:destinationName",
label="messaging")
public class GooglePubsubEndpoint
extends org.apache.camel.impl.DefaultEndpoint
Constructor and Description |
---|
GooglePubsubEndpoint(String uri,
org.apache.camel.Component component,
String remaining) |
configureConsumer, configurePollingConsumer, configureProperties, createEndpointConfiguration, createEndpointUri, createExchange, createExchange, createExchange, createPollingConsumer, doStart, doStop, equals, getCamelContext, 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 GooglePubsubComponent getComponent()
getComponent
in class org.apache.camel.impl.DefaultEndpoint
public org.apache.camel.Consumer createConsumer(org.apache.camel.Processor processor) throws Exception
Exception
public ExecutorService createExecutor()
public boolean isSingleton()
public String getProjectId()
public void setProjectId(String projectId)
public String getLoggerId()
public void setLoggerId(String loggerId)
public String getDestinationName()
public void setDestinationName(String destinationName)
public Integer getConcurrentConsumers()
public void setConcurrentConsumers(Integer concurrentConsumers)
public Integer getMaxMessagesPerPoll()
public void setMaxMessagesPerPoll(Integer maxMessagesPerPoll)
public GooglePubsubConstants.AckMode getAckMode()
public void setAckMode(GooglePubsubConstants.AckMode ackMode)
public com.google.api.services.pubsub.Pubsub getPubsub()
public GooglePubsubConnectionFactory getConnectionFactory()
public void setConnectionFactory(GooglePubsubConnectionFactory connectionFactory)
Apache Camel