Class GooglePubsubComponent

  • All Implemented Interfaces:
    AutoCloseable, org.apache.camel.CamelContextAware, org.apache.camel.Component, org.apache.camel.Service, org.apache.camel.ShutdownableService, org.apache.camel.StatefulService, org.apache.camel.SuspendableService

    @Component("google-pubsub")
    public class GooglePubsubComponent
    extends org.apache.camel.support.DefaultComponent
    Represents the component that manages GooglePubsubEndpoint.
    • 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
    • Method Summary

      All Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      protected org.apache.camel.Endpoint createEndpoint​(String uri, String remaining, Map<String,​Object> parameters)  
      protected void doShutdown()  
      String getEndpoint()  
      com.google.cloud.pubsub.v1.Publisher getPublisher​(String topicName)  
      int getPublisherCacheSize()  
      int getPublisherCacheTimeout()  
      int getPublisherTerminationTimeout()  
      com.google.cloud.pubsub.v1.Subscriber getSubscriber​(String subscriptionName, com.google.cloud.pubsub.v1.MessageReceiver messageReceiver)  
      com.google.cloud.pubsub.v1.stub.SubscriberStub getSubscriberStub()  
      void setEndpoint​(String endpoint)  
      void setPublisherCacheSize​(int publisherCacheSize)  
      void setPublisherCacheTimeout​(int publisherCacheTimeout)  
      void setPublisherTerminationTimeout​(int publisherTerminationTimeout)  
      • Methods inherited from class org.apache.camel.support.DefaultComponent

        afterConfiguration, createEndpoint, createEndpoint, doBuild, doInit, doStart, doStop, getAndRemoveOrResolveReferenceParameter, getAndRemoveOrResolveReferenceParameter, getAndRemoveParameter, getAndRemoveParameter, getCamelContext, getComponentPropertyConfigurer, getEndpointPropertyConfigurer, getExtension, getSupportedExtensions, ifStartsWithReturnRemainder, isAutowiredEnabled, isBridgeErrorHandler, isLazyStartProducer, registerExtension, registerExtension, resolveAndRemoveReferenceListParameter, resolveAndRemoveReferenceListParameter, resolveAndRemoveReferenceParameter, resolveAndRemoveReferenceParameter, resolveRawParameterValues, setAutowiredEnabled, setBridgeErrorHandler, setCamelContext, setLazyStartProducer, setProperties, setProperties, setProperties, useIntrospectionOnEndpoint, useRawUri, validateParameters, validateURI
      • Methods inherited from class org.apache.camel.support.service.BaseService

        build, doFail, doLifecycleChange, doResume, 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 interface org.apache.camel.Service

        build, close, init, start, stop
      • Methods inherited from interface org.apache.camel.ShutdownableService

        shutdown
      • Methods inherited from interface org.apache.camel.StatefulService

        getStatus, isRunAllowed, isStarted, isStarting, isStopped, isStopping, isSuspending
      • Methods inherited from interface org.apache.camel.SuspendableService

        isSuspended, resume, suspend
    • Constructor Detail

      • GooglePubsubComponent

        public GooglePubsubComponent()
    • Method Detail

      • createEndpoint

        protected org.apache.camel.Endpoint createEndpoint​(String uri,
                                                           String remaining,
                                                           Map<String,​Object> parameters)
                                                    throws Exception
        Specified by:
        createEndpoint in class org.apache.camel.support.DefaultComponent
        Throws:
        Exception
      • doShutdown

        protected void doShutdown()
                           throws Exception
        Overrides:
        doShutdown in class org.apache.camel.support.service.BaseService
        Throws:
        Exception
      • getSubscriber

        public com.google.cloud.pubsub.v1.Subscriber getSubscriber​(String subscriptionName,
                                                                   com.google.cloud.pubsub.v1.MessageReceiver messageReceiver)
      • getSubscriberStub

        public com.google.cloud.pubsub.v1.stub.SubscriberStub getSubscriberStub()
                                                                         throws IOException
        Throws:
        IOException
      • getEndpoint

        public String getEndpoint()
      • setEndpoint

        public void setEndpoint​(String endpoint)
      • getPublisherCacheSize

        public int getPublisherCacheSize()
      • setPublisherCacheSize

        public void setPublisherCacheSize​(int publisherCacheSize)
      • getPublisherCacheTimeout

        public int getPublisherCacheTimeout()
      • setPublisherCacheTimeout

        public void setPublisherCacheTimeout​(int publisherCacheTimeout)
      • getPublisherTerminationTimeout

        public int getPublisherTerminationTimeout()
      • setPublisherTerminationTimeout

        public void setPublisherTerminationTimeout​(int publisherTerminationTimeout)