Class 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.

    • Field Summary

      • Fields inherited from class org.apache.camel.support.service.BaseService

        BUILT, FAILED, INITIALIZED, INITIALIZING, lock, NEW, SHUTDOWN, SHUTTING_DOWN, STARTED, STARTING, status, STOPPED, STOPPING, SUSPENDED, SUSPENDING
    • Constructor Detail

      • GooglePubsubEndpoint

        public GooglePubsubEndpoint​(String uri,
                                    org.apache.camel.Component component,
                                    String remaining)
    • Method Detail

      • getComponent

        public GooglePubsubComponent getComponent()
        Overrides:
        getComponent in class org.apache.camel.support.DefaultEndpoint
      • afterPropertiesSet

        public void afterPropertiesSet()
                                throws Exception
        Throws:
        Exception
      • createProducer

        public org.apache.camel.Producer createProducer()
                                                 throws Exception
        Throws:
        Exception
      • createConsumer

        public org.apache.camel.Consumer createConsumer​(org.apache.camel.Processor processor)
                                                 throws Exception
        Throws:
        Exception
      • isSingleton

        public boolean isSingleton()
        Specified by:
        isSingleton in interface org.apache.camel.IsSingleton
        Overrides:
        isSingleton in class org.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)