Class GooglePubsubEndpoint
- java.lang.Object
-
- org.apache.camel.support.service.BaseService
-
- org.apache.camel.support.service.ServiceSupport
-
- org.apache.camel.support.DefaultEndpoint
-
- org.apache.camel.component.google.pubsub.GooglePubsubEndpoint
-
- All Implemented Interfaces:
AutoCloseable
,org.apache.camel.CamelContextAware
,org.apache.camel.Endpoint
,org.apache.camel.IsSingleton
,org.apache.camel.Service
,org.apache.camel.ShutdownableService
,org.apache.camel.spi.HasId
,org.apache.camel.StatefulService
,org.apache.camel.SuspendableService
@UriEndpoint(firstVersion="2.19.0", scheme="google-pubsub", title="Google Pubsub", syntax="google-pubsub:projectId:destinationName", category={CLOUD,MESSAGING}) public class GooglePubsubEndpoint extends org.apache.camel.support.DefaultEndpoint
Send and receive messages to/from Google Cloud Platform PubSub Service. Built on top of the Google Cloud Pub/Sub libraries.
-
-
Constructor Summary
Constructors Constructor Description GooglePubsubEndpoint(String uri, org.apache.camel.Component component, String remaining)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
afterPropertiesSet()
org.apache.camel.Consumer
createConsumer(org.apache.camel.Processor processor)
ExecutorService
createExecutor()
org.apache.camel.Producer
createProducer()
GooglePubsubConstants.AckMode
getAckMode()
GooglePubsubComponent
getComponent()
Integer
getConcurrentConsumers()
String
getDestinationName()
String
getLoggerId()
Integer
getMaxMessagesPerPoll()
String
getProjectId()
GooglePubsubSerializer
getSerializer()
boolean
isSingleton()
boolean
isSynchronousPull()
void
setAckMode(GooglePubsubConstants.AckMode ackMode)
void
setConcurrentConsumers(Integer concurrentConsumers)
void
setDestinationName(String destinationName)
void
setLoggerId(String loggerId)
void
setMaxMessagesPerPoll(Integer maxMessagesPerPoll)
void
setProjectId(String projectId)
void
setSerializer(GooglePubsubSerializer serializer)
void
setSynchronousPull(Boolean synchronousPull)
-
Methods inherited from class org.apache.camel.support.DefaultEndpoint
configureConsumer, configurePollingConsumer, configureProperties, createAsyncProducer, createEndpointUri, createExchange, createExchange, createPollingConsumer, doInit, doStart, doStop, equals, getCamelContext, getEndpointKey, getEndpointUri, getExceptionHandler, getExchangePattern, getId, getPollingConsumerBlockTimeout, getPollingConsumerQueueSize, hashCode, isAutowiredEnabled, isBridgeErrorHandler, isLazyStartProducer, isLenientProperties, isPollingConsumerBlockWhenFull, isSynchronous, setAutowiredEnabled, setBridgeErrorHandler, setCamelContext, setComponent, setEndpointUri, setEndpointUriIfNotSpecified, setExceptionHandler, setExchangePattern, setLazyStartProducer, setPollingConsumerBlockTimeout, setPollingConsumerBlockWhenFull, setPollingConsumerQueueSize, setProperties, setSynchronous, toString
-
Methods inherited from class org.apache.camel.support.service.BaseService
build, doBuild, doFail, doLifecycleChange, doResume, doShutdown, doSuspend, fail, getStatus, init, isBuild, isInit, isNew, isRunAllowed, isShutdown, isStarted, isStarting, isStartingOrStarted, isStopped, isStopping, isStoppingOrStopped, isSuspended, isSuspending, isSuspendingOrSuspended, resume, shutdown, start, stop, suspend
-
Methods inherited from class java.lang.Object
clone, finalize, getClass, notify, notifyAll, wait, wait, wait
-
-
-
-
Method Detail
-
getComponent
public GooglePubsubComponent getComponent()
- Overrides:
getComponent
in classorg.apache.camel.support.DefaultEndpoint
-
createConsumer
public org.apache.camel.Consumer createConsumer(org.apache.camel.Processor processor) throws Exception
- Throws:
Exception
-
createExecutor
public ExecutorService createExecutor()
-
isSingleton
public boolean isSingleton()
- Specified by:
isSingleton
in interfaceorg.apache.camel.IsSingleton
- Overrides:
isSingleton
in classorg.apache.camel.support.DefaultEndpoint
-
getProjectId
public String getProjectId()
-
setProjectId
public void setProjectId(String projectId)
-
getLoggerId
public String getLoggerId()
-
setLoggerId
public void setLoggerId(String loggerId)
-
getDestinationName
public String getDestinationName()
-
setDestinationName
public void setDestinationName(String destinationName)
-
getConcurrentConsumers
public Integer getConcurrentConsumers()
-
setConcurrentConsumers
public void setConcurrentConsumers(Integer concurrentConsumers)
-
getMaxMessagesPerPoll
public Integer getMaxMessagesPerPoll()
-
setMaxMessagesPerPoll
public void setMaxMessagesPerPoll(Integer maxMessagesPerPoll)
-
isSynchronousPull
public boolean isSynchronousPull()
-
setSynchronousPull
public void setSynchronousPull(Boolean synchronousPull)
-
getAckMode
public GooglePubsubConstants.AckMode getAckMode()
-
setAckMode
public void setAckMode(GooglePubsubConstants.AckMode ackMode)
-
getSerializer
public GooglePubsubSerializer getSerializer()
-
setSerializer
public void setSerializer(GooglePubsubSerializer serializer)
-
-