Index

A B C D F G H I J L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

ack() - Method in interface com.google.cloud.spring.pubsub.support.BasicAcknowledgeablePubsubMessage
Acknowledge (ack) the message asynchronously.
ack(Collection<? extends AcknowledgeablePubsubMessage>) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
ack(Collection<? extends AcknowledgeablePubsubMessage>) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Acknowledge a batch of messages.
ack(Collection<? extends AcknowledgeablePubsubMessage>) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
Acknowledge messages in per-subscription batches.
AckMode - Enum Class in com.google.cloud.spring.pubsub.integration
Determines acknowledgement policy for incoming messages from Google Cloud Pub/Sub.
acknowledge(AcknowledgmentCallback.Status) - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubAcknowledgmentCallback
In AckMode.AUTO_ACK mode, nacking cannot be done through this callback.
AcknowledgeablePubsubMessage - Interface in com.google.cloud.spring.pubsub.support
An extension of BasicAcknowledgeablePubsubMessage that exposes ack ID and subscription name of the message.
addListener(Subscriber) - Method in interface com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistry
Attaches a listener to a Pub/Sub subscriber provided a HealthTracker is registered for that subscription.
addListener(Subscriber) - Method in class com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistryImpl
 
apply(Publisher.Builder, String) - Method in interface com.google.cloud.spring.pubsub.core.publisher.PublisherCustomizer
 
AUTO - Enum constant in enum class com.google.cloud.spring.pubsub.integration.AckMode
The framework acks the PubsubMessage after it is sent to the channel and processed successfully.
AUTO_ACK - Enum constant in enum class com.google.cloud.spring.pubsub.integration.AckMode
The framework acks the PubsubMessage after it is sent to the channel and processed successfully.

B

BasicAcknowledgeablePubsubMessage - Interface in com.google.cloud.spring.pubsub.support
A PubsubMessage wrapper that allows it to be acknowledged.
Batching() - Constructor for class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Batching
 
byteStringToPubSubMessage(ByteString, Map<String, String>) - Method in interface com.google.cloud.spring.pubsub.support.converter.PubSubMessageConverter
 

C

CachingPublisherFactory - Class in com.google.cloud.spring.pubsub.support
The caching implementation of the PublisherFactory.
CachingPublisherFactory(PublisherFactory) - Constructor for class com.google.cloud.spring.pubsub.support.CachingPublisherFactory
Constructs a caching PublisherFactory using the delegate.
CLIENT - Static variable in class com.google.cloud.spring.pubsub.support.GcpPubSubHeaders
The client header text.
close() - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
 
com.google.cloud.spring.pubsub - package com.google.cloud.spring.pubsub
Spring Cloud GCP Pub/Sub module.
com.google.cloud.spring.pubsub.core - package com.google.cloud.spring.pubsub.core
Core support for Pub/Sub in Spring.
com.google.cloud.spring.pubsub.core.health - package com.google.cloud.spring.pubsub.core.health
 
com.google.cloud.spring.pubsub.core.publisher - package com.google.cloud.spring.pubsub.core.publisher
Operations and template for publishing in Spring Cloud GCP Pub/Sub.
com.google.cloud.spring.pubsub.core.subscriber - package com.google.cloud.spring.pubsub.core.subscriber
Operations and template for subscribing in Spring Cloud GCP Pub/Sub.
com.google.cloud.spring.pubsub.integration - package com.google.cloud.spring.pubsub.integration
Spring Integration support in Spring Cloud GCP Pub/Sub.
com.google.cloud.spring.pubsub.integration.inbound - package com.google.cloud.spring.pubsub.integration.inbound
Inbound support classes for Spring Integration support in Spring Cloud GCP Pub/Sub.
com.google.cloud.spring.pubsub.integration.outbound - package com.google.cloud.spring.pubsub.integration.outbound
Google Cloud Pub/Sub outbound integration classes for Spring Integration.
com.google.cloud.spring.pubsub.reactive - package com.google.cloud.spring.pubsub.reactive
 
com.google.cloud.spring.pubsub.support - package com.google.cloud.spring.pubsub.support
Supporting classes for handling messages in Spring Cloud GCP Pub/Sub.
com.google.cloud.spring.pubsub.support.converter - package com.google.cloud.spring.pubsub.support.converter
Classes related to converting messages in Spring Cloud GCP Pub/Sub.
computeMaxAckExtensionPeriod(String, String) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Computes the max extension period.
computeMaxDurationPerAckExtension(String, String) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Computes the upper bound for a single mod ack extension period.
computeMinDurationPerAckExtension(String, String) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Computes the lower bound for a single mod ack extension period.
computeParallelPullCount(String, String) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Computes parallel pull count.
computePullEndpoint(String, String) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Returns the pull endpoint.
computeRetryableCodes(String, String) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Retrieves collection of retryable codes from configuration.
computeSubscriberFlowControlSettings(ProjectSubscriptionName) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Computes flow control settings to use.
computeSubscriberRetrySettings(ProjectSubscriptionName) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Computes the retry settings.
ConvertedAcknowledgeablePubsubMessage<T> - Interface in com.google.cloud.spring.pubsub.support.converter
An AcknowledgeablePubsubMessage that also contains the payload of the Pub/Sub message converted to the desired type T.
ConvertedBasicAcknowledgeablePubsubMessage<T> - Interface in com.google.cloud.spring.pubsub.support.converter
A BasicAcknowledgeablePubsubMessage that also contains the payload of the Pub/Sub message converted to the desired type T.
createPublisher(String) - Method in class com.google.cloud.spring.pubsub.support.CachingPublisherFactory
 
createPublisher(String) - Method in class com.google.cloud.spring.pubsub.support.DefaultPublisherFactory
Creates a Publisher for a given topic.
createPublisher(String) - Method in interface com.google.cloud.spring.pubsub.support.PublisherFactory
Creates a Publisher for a given topic.
createPullRequest(String, Integer, Boolean) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
createPullRequest(String, Integer, Boolean) - Method in interface com.google.cloud.spring.pubsub.support.SubscriberFactory
Create a PullRequest for synchronously pulling a number of messages from a Google Cloud Pub/Sub subscription.
createSubscriber(String, MessageReceiver) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
createSubscriber(String, MessageReceiver) - Method in interface com.google.cloud.spring.pubsub.support.SubscriberFactory
Create a Subscriber for the specified subscription name and wired it up to asynchronously deliver messages to the provided MessageReceiver.
createSubscriberStub(String) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
createSubscriberStub(String) - Method in interface com.google.cloud.spring.pubsub.support.SubscriberFactory
Create a SubscriberStub that is needed to execute PullRequests.
createSubscription(Subscription.Builder) - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Create a new subscription on Google Cloud Pub/Sub.
createSubscription(String, String) - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Create a new subscription on Google Cloud Pub/Sub.
createSubscription(String, String, Integer) - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Create a new subscription on Google Cloud Pub/Sub.
createSubscription(String, String, Integer, String) - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Create a new subscription on Google Cloud Pub/Sub.
createSubscription(String, String, String) - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Create a new subscription on Google Cloud Pub/Sub.
createTopic(String) - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Create a new topic on Google Cloud Pub/Sub.

D

DEFAULT_EXECUTOR_THREADS - Static variable in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Default number of executor threads.
DefaultPublisherFactory - Class in com.google.cloud.spring.pubsub.support
The default PublisherFactory implementation.
DefaultPublisherFactory(GcpProjectIdProvider) - Constructor for class com.google.cloud.spring.pubsub.support.DefaultPublisherFactory
Create DefaultPublisherFactory instance based on the provided GcpProjectIdProvider.
DefaultSubscriberFactory - Class in com.google.cloud.spring.pubsub.support
The default SubscriberFactory implementation.
DefaultSubscriberFactory(GcpProjectIdProvider, PubSubConfiguration) - Constructor for class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Default DefaultSubscriberFactory constructor.
deleteSubscription(String) - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Delete a subscription from Google Cloud Pub/Sub.
deleteTopic(String) - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Delete a topic from Google Cloud Pub/Sub.
destroy() - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
Destroys the default executor, regardless of whether it was used.
doReceive(int) - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubMessageSource
Provides a single polled message.
doStart() - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubInboundChannelAdapter
 
doStop() - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubInboundChannelAdapter
 

F

FlowControl() - Constructor for class com.google.cloud.spring.pubsub.core.PubSubConfiguration.FlowControl
 
fromHeaders(MessageHeaders, Map<String, String>) - Method in class com.google.cloud.spring.pubsub.integration.PubSubHeaderMapper
Generate headers in PubsubMessage format from MessageHeaders.
fromPubSubMessage(PubsubMessage, Class<T>) - Method in class com.google.cloud.spring.pubsub.support.converter.JacksonPubSubMessageConverter
 
fromPubSubMessage(PubsubMessage, Class<T>) - Method in interface com.google.cloud.spring.pubsub.support.converter.PubSubMessageConverter
Convert the payload of a given PubsubMessage to a desired Java type.
fromPubSubMessage(PubsubMessage, Class<T>) - Method in class com.google.cloud.spring.pubsub.support.converter.SimplePubSubMessageConverter
 

G

GcpPubSubHeaders - Class in com.google.cloud.spring.pubsub.support
Google Cloud internal headers for Spring Messaging messages.
getAckId() - Method in interface com.google.cloud.spring.pubsub.support.AcknowledgeablePubsubMessage
Accessor for the ack ID of the Pub/Sub message.
getAckMode() - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubInboundChannelAdapter
 
getBacklogThreshold() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Health
 
getBatching() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Publisher
 
getComponentType() - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubMessageSource
 
getDefaultAckDeadline() - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Get the default ack deadline.
getDelayThresholdSeconds() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Batching
 
getDelegate() - Method in class com.google.cloud.spring.pubsub.support.CachingPublisherFactory
Returns the delegate.
getElementCountThreshold() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Batching
 
getEnabled() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Batching
 
getEnableMessageOrdering() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Publisher
 
getEndpoint() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Publisher
 
getExecutorProvider(String) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Creates ExecutorProvider.
getExecutorThreads() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Health
 
getExecutorThreads() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Publisher
 
getExecutorThreads() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
getFailedMessage() - Method in exception com.google.cloud.spring.pubsub.core.PubSubDeliveryException
 
getFlowControl() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Batching
 
getFlowControl() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
getFlowControlSettings(String) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Fetches subscriber FlowControlSettings.
getFullyQualifiedName() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
getFullyQualifiedSubscriberProperties() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Returns an immutable map of subscription properties keyed by the fully-qualified ProjectSubscriptionName.
getGlobalExecutorProvider() - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
getHealth() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
 
getInitialRetryDelaySeconds() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
getInitialRpcTimeoutSeconds() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
getJittered() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
getLagThreshold() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Health
 
getLimitExceededBehavior() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.FlowControl
 
getLookUpInterval() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Health
 
getMaxAckExtensionPeriod() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
getMaxAcknowledgementThreads() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
getMaxAttempts() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
getMaxDurationPerAckExtension() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
getMaxOutstandingElementCount() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.FlowControl
 
getMaxOutstandingRequestBytes() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.FlowControl
 
getMaxRetryDelaySeconds() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
getMaxRpcTimeoutSeconds() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
get the max RPC timeout seconds.
getMessageConverter() - Method in class com.google.cloud.spring.pubsub.core.publisher.PubSubPublisherTemplate
 
getMessageConverter() - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
getMessageConverter() - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
Get the converter used to convert a message payload to the desired type.
getMinDurationPerAckExtension() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
getOriginalMessage(Message<?>) - Static method in class com.google.cloud.spring.pubsub.support.GcpPubSubHeaders
A simple utility method for pulling the GcpPubSubHeaders.ORIGINAL_MESSAGE header out of a Message.
getParallelPullCount() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
getPayload() - Method in interface com.google.cloud.spring.pubsub.support.converter.ConvertedBasicAcknowledgeablePubsubMessage
 
getPayloadType() - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubInboundChannelAdapter
 
getProjectId() - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
getProjectId() - Method in interface com.google.cloud.spring.pubsub.support.SubscriberFactory
Method to get the project id.
getProjectSubscriptionName() - Method in interface com.google.cloud.spring.pubsub.support.BasicAcknowledgeablePubsubMessage
Accessor for the project subscription name of the Pub/Sub message.
getPublishCallback() - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
 
getPublisher() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
 
getPublisherFactory() - Method in class com.google.cloud.spring.pubsub.core.publisher.PubSubPublisherTemplate
 
getPublisherFactory() - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
getPublishTimeoutExpression() - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
 
getPubsubMessage() - Method in interface com.google.cloud.spring.pubsub.support.BasicAcknowledgeablePubsubMessage
Accessor for the wrapped PubsubMessage.
getPubSubPublisherTemplate() - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
getPubSubSubscriberTemplate() - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
getPullEndpoint() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
getRequestByteThreshold() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Batching
 
getRetry() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Publisher
 
getRetry() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
getRetryableCodes() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
getRetryableCodes(String) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
getRetryDelayMultiplier() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
getRetrySettings(String) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Creates RetrySettings, given subscriber retry properties.
getRpcTimeoutMultiplier() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
getSubscriber() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
 
getSubscriberFactory() - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
getSubscriberFactory() - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
 
getSubscription(String) - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Get the configuration of a Google Cloud Pub/Sub subscription.
getSubscriptionProperties(ProjectSubscriptionName) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Returns properties for the specified fully-qualified ProjectSubscriptionName.
getTopic(String) - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Get the configuration of a Google Cloud Pub/Sub topic.
getTopicExpression() - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
 
getTotalTimeoutSeconds() - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 

H

handleMessageInternal(Message<?>) - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
 
Health() - Constructor for class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Health
 
healthCheckEnabled() - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubInboundChannelAdapter
 
HealthTracker - Interface in com.google.cloud.spring.pubsub.core.health
Health tracker for a Pub/Sub subscription.
HealthTrackerImpl - Class in com.google.cloud.spring.pubsub.core.health
Health tracker for a Pub/Sub subscription.
HealthTrackerImpl(ProjectSubscriptionName, MetricServiceClient, Integer, Integer, Integer) - Constructor for class com.google.cloud.spring.pubsub.core.health.HealthTrackerImpl
 
HealthTrackerRegistry - Interface in com.google.cloud.spring.pubsub.core.health
A registry for the HealthTracker health trackers created per ProjectSubscriptionName.
HealthTrackerRegistryImpl - Class in com.google.cloud.spring.pubsub.core.health
A registry for the HealthTracker health trackers created per ProjectSubscriptionName.
HealthTrackerRegistryImpl(String, MetricServiceClient, Integer, Integer, Integer, ExecutorProvider) - Constructor for class com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistryImpl
 
HealthTrackerRegistryImpl(String, MetricServiceClient, Integer, Integer, Integer, ExecutorProvider, ConcurrentMap<ProjectSubscriptionName, HealthTracker>) - Constructor for class com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistryImpl
 
healthTrackers() - Method in interface com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistry
Retrieve all the health trackers registered.
healthTrackers() - Method in class com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistryImpl
 

I

initialize(String) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
Standardizes all subscription properties to be keyed by their fully qualified subscription names.
isAcknowledged() - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubAcknowledgmentCallback
 
isAutoAck() - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubAcknowledgmentCallback
 
isSync() - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
 
isTracked(ProjectSubscriptionName) - Method in interface com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistry
Check if a ProjectSubscriptionName has a HealthTracker registered.
isTracked(ProjectSubscriptionName) - Method in class com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistryImpl
 

J

JacksonPubSubMessageConverter - Class in com.google.cloud.spring.pubsub.support.converter
A converter using Jackson JSON.
JacksonPubSubMessageConverter(ObjectMapper) - Constructor for class com.google.cloud.spring.pubsub.support.converter.JacksonPubSubMessageConverter
Constructor.

L

listSubscriptions() - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Return every subscription in a project.
listTopics() - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Return every topic in a project.

M

MANUAL - Enum constant in enum class com.google.cloud.spring.pubsub.integration.AckMode
The framework does not ack / nack the message.
MAX_ACK_DEADLINE_SECONDS - Static variable in class com.google.cloud.spring.pubsub.PubSubAdmin
 
messagesOverThreshold() - Method in interface com.google.cloud.spring.pubsub.core.health.HealthTracker
If messages have been processed recently returns zero.
messagesOverThreshold() - Method in class com.google.cloud.spring.pubsub.core.health.HealthTrackerImpl
 
MIN_ACK_DEADLINE_SECONDS - Static variable in class com.google.cloud.spring.pubsub.PubSubAdmin
 
modifyAckDeadline(int) - Method in interface com.google.cloud.spring.pubsub.support.AcknowledgeablePubsubMessage
Modify the ack deadline of the message.
modifyAckDeadline(Collection<? extends AcknowledgeablePubsubMessage>, int) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
modifyAckDeadline(Collection<? extends AcknowledgeablePubsubMessage>, int) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Modify the ack deadline of a batch of messages.
modifyAckDeadline(Collection<? extends AcknowledgeablePubsubMessage>, int) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
Modify multiple messages' ack deadline in per-subscription batches.

N

nack() - Method in interface com.google.cloud.spring.pubsub.support.BasicAcknowledgeablePubsubMessage
Negatatively achnowledge (nack) the message asynchronously.
nack(Collection<? extends AcknowledgeablePubsubMessage>) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
nack(Collection<? extends AcknowledgeablePubsubMessage>) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Negatively acknowledge a batch of messages.
nack(Collection<? extends AcknowledgeablePubsubMessage>) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
Nack messages in per-subscription batches.

O

onFailure(Throwable, Message<?>) - Method in interface com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler.FailureCallback
 
onInit() - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
 
onSuccess(String, Message<?>) - Method in interface com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler.SuccessCallback
 
ORDERING_KEY - Static variable in class com.google.cloud.spring.pubsub.support.GcpPubSubHeaders
The Pub/Sub message ordering key.
ORIGINAL_MESSAGE - Static variable in class com.google.cloud.spring.pubsub.support.GcpPubSubHeaders
The original message header text.

P

poll(String, long) - Method in class com.google.cloud.spring.pubsub.reactive.PubSubReactiveFactory
Create an infinite stream Flux of AcknowledgeablePubsubMessage objects.
processedMessage() - Method in interface com.google.cloud.spring.pubsub.core.health.HealthTracker
Record that a message has been processed.
processedMessage() - Method in class com.google.cloud.spring.pubsub.core.health.HealthTrackerImpl
 
processedMessage(ProjectSubscriptionName) - Method in interface com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistry
Propagate that a message has been processed to the corresponding HealthTracker if registered.
processedMessage(ProjectSubscriptionName) - Method in class com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistryImpl
 
publish(String, PubsubMessage) - Method in interface com.google.cloud.spring.pubsub.core.publisher.PubSubPublisherOperations
Send a message to Pub/Sub.
publish(String, PubsubMessage) - Method in class com.google.cloud.spring.pubsub.core.publisher.PubSubPublisherTemplate
 
publish(String, PubsubMessage) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
publish(String, T) - Method in interface com.google.cloud.spring.pubsub.core.publisher.PubSubPublisherOperations
Send a message to Pub/Sub.
publish(String, T) - Method in class com.google.cloud.spring.pubsub.core.publisher.PubSubPublisherTemplate
 
publish(String, T) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
publish(String, T, Map<String, String>) - Method in interface com.google.cloud.spring.pubsub.core.publisher.PubSubPublisherOperations
Send a message to Pub/Sub.
publish(String, T, Map<String, String>) - Method in class com.google.cloud.spring.pubsub.core.publisher.PubSubPublisherTemplate
Uses the configured message converter to first convert the payload and headers to a PubsubMessage and then publish it.
publish(String, T, Map<String, String>) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
Uses the configured message converter to first convert the payload and headers to a PubsubMessage and then publish it.
Publisher() - Constructor for class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Publisher
 
PublisherCustomizer - Interface in com.google.cloud.spring.pubsub.core.publisher
A customizer of Publisher.Builder objects.
PublisherFactory - Interface in com.google.cloud.spring.pubsub.support
The publisher factory interface that can create publishers.
PubSubAcknowledgmentCallback - Class in com.google.cloud.spring.pubsub.integration.inbound
Pub/Sub specific implementation of AcknowledgmentCallback.
PubSubAcknowledgmentCallback(AcknowledgeablePubsubMessage, AckMode) - Constructor for class com.google.cloud.spring.pubsub.integration.inbound.PubSubAcknowledgmentCallback
Instantiates a callback for a given message and acknowledgement mode.
PubSubAdmin - Class in com.google.cloud.spring.pubsub
Pub/Sub admin utility that creates new topics and subscriptions on Google Cloud Pub/Sub.
PubSubAdmin(GcpProjectIdProvider, CredentialsProvider) - Constructor for class com.google.cloud.spring.pubsub.PubSubAdmin
This constructor instantiates TopicAdminClient and SubscriptionAdminClient with all their defaults and the provided credentials provider.
PubSubAdmin(GcpProjectIdProvider, TopicAdminClient, SubscriptionAdminClient) - Constructor for class com.google.cloud.spring.pubsub.PubSubAdmin
Instantiates PubSubAdmin with provided topic/subscription client.
PubSubConfiguration - Class in com.google.cloud.spring.pubsub.core
Properties for Publisher or Subscriber specific configurations.
PubSubConfiguration() - Constructor for class com.google.cloud.spring.pubsub.core.PubSubConfiguration
 
PubSubConfiguration.Batching - Class in com.google.cloud.spring.pubsub.core
Batching settings.
PubSubConfiguration.FlowControl - Class in com.google.cloud.spring.pubsub.core
flow control settings.
PubSubConfiguration.Health - Class in com.google.cloud.spring.pubsub.core
Health Check settings.
PubSubConfiguration.Publisher - Class in com.google.cloud.spring.pubsub.core
Publisher settings.
PubSubConfiguration.Retry - Class in com.google.cloud.spring.pubsub.core
Retry settings.
PubSubConfiguration.Subscriber - Class in com.google.cloud.spring.pubsub.core
Subscriber settings.
PubSubDeliveryException - Exception in com.google.cloud.spring.pubsub.core
The Spring Google Cloud Pub/Sub specific PubSubException.
PubSubDeliveryException(PubsubMessage, String, Throwable) - Constructor for exception com.google.cloud.spring.pubsub.core.PubSubDeliveryException
 
PubSubException - Exception in com.google.cloud.spring.pubsub.core
The Spring Google Cloud Pub/Sub specific NestedRuntimeException.
PubSubException(String) - Constructor for exception com.google.cloud.spring.pubsub.core.PubSubException
 
PubSubException(String, Throwable) - Constructor for exception com.google.cloud.spring.pubsub.core.PubSubException
 
PubSubHeaderMapper - Class in com.google.cloud.spring.pubsub.integration
Maps headers from PubsubMessages to Messages and vice-versa.
PubSubHeaderMapper() - Constructor for class com.google.cloud.spring.pubsub.integration.PubSubHeaderMapper
 
PubSubInboundChannelAdapter - Class in com.google.cloud.spring.pubsub.integration.inbound
Converts from GCP Pub/Sub message to Spring message and sends the Spring message to the attached channels.
PubSubInboundChannelAdapter(PubSubSubscriberOperations, String) - Constructor for class com.google.cloud.spring.pubsub.integration.inbound.PubSubInboundChannelAdapter
Instantiates a streaming Pub/Sub subscription adapter.
PubSubMessageConversionException - Exception in com.google.cloud.spring.pubsub.support.converter
An exception raised when conversion to or from a PubsubMessage fails.
PubSubMessageConversionException(String) - Constructor for exception com.google.cloud.spring.pubsub.support.converter.PubSubMessageConversionException
 
PubSubMessageConversionException(String, Throwable) - Constructor for exception com.google.cloud.spring.pubsub.support.converter.PubSubMessageConversionException
 
PubSubMessageConverter - Interface in com.google.cloud.spring.pubsub.support.converter
Interface for converters that can convert POJOs to and from Pub/Sub messages.
PubSubMessageHandler - Class in com.google.cloud.spring.pubsub.integration.outbound
Outbound channel adapter to publish messages to Google Cloud Pub/Sub.
PubSubMessageHandler(PubSubPublisherOperations, String) - Constructor for class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
Instantiates an outbound adapter for publishing messages to a topic.
PubSubMessageHandler.FailureCallback - Interface in com.google.cloud.spring.pubsub.integration.outbound
Implement this callback to post-process a message that failed to publish to Cloud Pub/Sub.
PubSubMessageHandler.SuccessCallback - Interface in com.google.cloud.spring.pubsub.integration.outbound
Implement this callback to post-process a successfully published message.
PubSubMessageSource - Class in com.google.cloud.spring.pubsub.integration.inbound
A PubSub Synchronous pull implementation of AbstractMessageSource.
PubSubMessageSource(PubSubSubscriberOperations, String) - Constructor for class com.google.cloud.spring.pubsub.integration.inbound.PubSubMessageSource
Instantiates a Pub/Sub inbound message adapter to poll a given subscription for messages.
PubSubOperations - Interface in com.google.cloud.spring.pubsub.core
An abstraction for Google Cloud Pub/Sub for publish and subscribe / pull methods.
PubSubPublisherOperations - Interface in com.google.cloud.spring.pubsub.core.publisher
An abstraction for Google Cloud Pub/Sub publisher operations.
PubSubPublisherTemplate - Class in com.google.cloud.spring.pubsub.core.publisher
Default implementation of PubSubPublisherOperations.
PubSubPublisherTemplate(PublisherFactory) - Constructor for class com.google.cloud.spring.pubsub.core.publisher.PubSubPublisherTemplate
Default PubSubPublisherTemplate constructor that uses SimplePubSubMessageConverter to serialize and deserialize payloads.
PubSubReactiveFactory - Class in com.google.cloud.spring.pubsub.reactive
A factory for procuring Flux instances backed by GCP Pub/Sub Subscriptions.
PubSubReactiveFactory(PubSubSubscriberOperations, Scheduler) - Constructor for class com.google.cloud.spring.pubsub.reactive.PubSubReactiveFactory
Instantiate `PubSubReactiveFactory` capable of generating subscription-based streams.
PubSubReactiveFactory(PubSubSubscriberOperations, Scheduler, int) - Constructor for class com.google.cloud.spring.pubsub.reactive.PubSubReactiveFactory
Instantiate `PubSubReactiveFactory` capable of generating subscription-based streams.
PubSubSubscriberOperations - Interface in com.google.cloud.spring.pubsub.core.subscriber
An abstraction for Google Cloud Pub/Sub subscription / pulling operations.
PubSubSubscriberTemplate - Class in com.google.cloud.spring.pubsub.core.subscriber
Default implementation of PubSubSubscriberOperations.
PubSubSubscriberTemplate(SubscriberFactory) - Constructor for class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
Default PubSubSubscriberTemplate constructor.
PubSubSubscriptionUtils - Class in com.google.cloud.spring.pubsub.support
Various utility methods for dealing with Pub/Sub subscriptions.
PubSubTemplate - Class in com.google.cloud.spring.pubsub.core
Default implementation of PubSubOperations.
PubSubTemplate(PubSubPublisherTemplate, PubSubSubscriberTemplate) - Constructor for class com.google.cloud.spring.pubsub.core.PubSubTemplate
Default PubSubTemplate constructor that uses a PubSubPublisherTemplate and a PubSubSubscriberTemplate.
PubSubTemplate(PublisherFactory, SubscriberFactory) - Constructor for class com.google.cloud.spring.pubsub.core.PubSubTemplate
Default PubSubTemplate constructor.
PubSubTopicUtils - Class in com.google.cloud.spring.pubsub.support
Various utility methods for dealing with Pub/Sub topics.
pull(String, Integer, Boolean) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
pull(String, Integer, Boolean) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Pull a number of messages from a Google Cloud Pub/Sub subscription.
pull(String, Integer, Boolean) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
 
pullAndAck(String, Integer, Boolean) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
pullAndAck(String, Integer, Boolean) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Pull and auto-acknowledge a number of messages from a Google Cloud Pub/Sub subscription.
pullAndAck(String, Integer, Boolean) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
 
pullAndAckAsync(String, Integer, Boolean) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
pullAndAckAsync(String, Integer, Boolean) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Asynchronously pull and auto-acknowledge a number of messages from a Google Cloud Pub/Sub subscription.
pullAndAckAsync(String, Integer, Boolean) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
 
pullAndConvert(String, Integer, Boolean, Class<T>) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
pullAndConvert(String, Integer, Boolean, Class<T>) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Pull a number of messages from a Google Cloud Pub/Sub subscription and convert them to Spring messages with the desired payload type.
pullAndConvert(String, Integer, Boolean, Class<T>) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
 
pullAndConvertAsync(String, Integer, Boolean, Class<T>) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
pullAndConvertAsync(String, Integer, Boolean, Class<T>) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Asynchronously pull a number of messages from a Google Cloud Pub/Sub subscription and convert them to Spring messages with the desired payload type.
pullAndConvertAsync(String, Integer, Boolean, Class<T>) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
 
pullAsync(String, Integer, Boolean) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
pullAsync(String, Integer, Boolean) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Asynchronously pull a number of messages from a Google Cloud Pub/Sub subscription.
pullAsync(String, Integer, Boolean) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
 
pullNext(String) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
pullNext(String) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Pull and auto-acknowledge a message from a Google Cloud Pub/Sub subscription.
pullNext(String) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
 
pullNextAsync(String) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
pullNextAsync(String) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Asynchronously pull and auto-acknowledge a message from a Google Cloud Pub/Sub subscription.
pullNextAsync(String) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
 

R

registerTracker(ProjectSubscriptionName) - Method in interface com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistry
Create a tracker for given ProjectSubscriptionName and add tracker to registry.
registerTracker(ProjectSubscriptionName) - Method in class com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistryImpl
 
registerTracker(String) - Method in interface com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistry
Create a tracker for given subscription name and add tracker to registry.
registerTracker(String) - Method in class com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistryImpl
 
Retry() - Constructor for class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 

S

setAckExecutor(Executor) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
Sets the Executor to control per-subscription batch parallelization in acknowledgement and deadline operations.
setAckMode(AckMode) - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubInboundChannelAdapter
 
setAckMode(AckMode) - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubMessageSource
 
setApiClock(ApiClock) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the clock to use for the retry logic in synchronous pulling.
setAsyncPullExecutor(Executor) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
Set a custom Executor to control the threads that process the responses of the asynchronous pull callback operations.
setBacklogThreshold(Integer) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Health
 
setBatchingSettings(BatchingSettings) - Method in class com.google.cloud.spring.pubsub.support.DefaultPublisherFactory
Set the API call batching configuration.
setBlockOnPull(boolean) - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubMessageSource
Instructs synchronous pull to wait until at least one message is available.
setChannelProvider(TransportChannelProvider) - Method in class com.google.cloud.spring.pubsub.support.DefaultPublisherFactory
Set the provider for the channel to be used by the publisher.
setChannelProvider(TransportChannelProvider) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the provider for the subscribers' transport channel.
setCredentialsProvider(CredentialsProvider) - Method in class com.google.cloud.spring.pubsub.support.DefaultPublisherFactory
Set the provider for the GCP credentials to be used by the publisher on every API calls it makes.
setCredentialsProvider(CredentialsProvider) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the provider for the GCP credentials to be used by the subscribers' API calls.
setCustomizers(List<PublisherCustomizer>) - Method in class com.google.cloud.spring.pubsub.support.DefaultPublisherFactory
Accepts a list of Publisher.Builder customizers.
setDefaultAckDeadline(int) - Method in class com.google.cloud.spring.pubsub.PubSubAdmin
Set the default acknowledgement deadline value.
setDelayThresholdSeconds(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Batching
 
setElementCountThreshold(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Batching
 
setEnabled(Boolean) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Batching
 
setEnableMessageOrdering(Boolean) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Publisher
 
setEnableMessageOrdering(Boolean) - Method in class com.google.cloud.spring.pubsub.support.DefaultPublisherFactory
Set whether message ordering should be enabled on the publisher.
setEndpoint(String) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Publisher
 
setEndpoint(String) - Method in class com.google.cloud.spring.pubsub.support.DefaultPublisherFactory
Set the publisher endpoint.
setExecutorProvider(ExecutorProvider) - Method in class com.google.cloud.spring.pubsub.support.DefaultPublisherFactory
Set the provider for the executor that will be used by the publisher.
setExecutorProvider(ExecutorProvider) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the provider for the subscribers' executor.
setExecutorProviderMap(Map<ProjectSubscriptionName, ExecutorProvider>) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
setExecutorThreads(int) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Health
 
setExecutorThreads(int) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Publisher
 
setExecutorThreads(int) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
Set the number of executor threads.
setFailureCallback(PubSubMessageHandler.FailureCallback) - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
Set callback (can be a lambda) for processing the root cause exception and the original Message in case of failure.
setFlowControlSettings(FlowControlSettings) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the flow control for the subscribers, including the behaviour for when the flow limits are hit.
setFlowControlSettingsMap(Map<ProjectSubscriptionName, FlowControlSettings>) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
setFullyQualifiedName(String) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
setGlobalExecutorProvider(ExecutorProvider) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
setGlobalFlowControlSettings(FlowControlSettings) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
setGlobalRetrySettings(RetrySettings) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
setHeaderMapper(HeaderMapper<Map<String, String>>) - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubInboundChannelAdapter
Set the header mapper to map headers from incoming PubsubMessage into Message.
setHeaderMapper(HeaderMapper<Map<String, String>>) - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubMessageSource
 
setHeaderMapper(HeaderMapper<Map<String, String>>) - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
Set the header mapper to map headers from Message into outbound PubsubMessage.
setHeaderProvider(HeaderProvider) - Method in class com.google.cloud.spring.pubsub.support.DefaultPublisherFactory
Set the provider for the HTTP headers to be used in the Pub/Sub REST API requests.
setHeaderProvider(HeaderProvider) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the provider for the HTTP headers to be added to the subscribers' REST API calls.
setHealthTrackerRegistry(HealthTrackerRegistry) - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubInboundChannelAdapter
 
setHealthTrackerRegistry(HealthTrackerRegistry) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the health tracker chain for the generated subscriptions.
setInboundHeaderPatterns(String...) - Method in class com.google.cloud.spring.pubsub.integration.PubSubHeaderMapper
Set the patterns of the headers to be mapped in PubSubHeaderMapper.toHeaders(Map).
setInitialRetryDelaySeconds(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
setInitialRpcTimeoutSeconds(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
setJittered(Boolean) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
setLagThreshold(Integer) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Health
 
setLimitExceededBehavior(FlowController.LimitExceededBehavior) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.FlowControl
 
setLookUpInterval(Integer) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Health
 
setMaxAckExtensionPeriod(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
setMaxAckExtensionPeriod(Duration) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the maximum period the ack timeout is extended by.
setMaxAcknowledgementThreads(int) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
setMaxAttempts(Integer) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
setMaxDurationPerAckExtension(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
setMaxDurationPerAckExtension(Duration) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Sets the max duration per ack extension override for all subscriptions.
setMaxOutstandingElementCount(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.FlowControl
 
setMaxOutstandingRequestBytes(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.FlowControl
 
setMaxRetryDelaySeconds(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
setMaxRpcTimeoutSeconds(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
setMessageConverter(PubSubMessageConverter) - Method in class com.google.cloud.spring.pubsub.core.publisher.PubSubPublisherTemplate
 
setMessageConverter(PubSubMessageConverter) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
setMessageConverter(PubSubMessageConverter) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
Set the converter used to convert a message payload to the desired type.
setMinDurationPerAckExtension(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
setMinDurationPerAckExtension(Duration) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Sets the min duration per ack extension override for all subscriptions.
setOutboundHeaderPatterns(String...) - Method in class com.google.cloud.spring.pubsub.integration.PubSubHeaderMapper
Set the patterns of the headers to be mapped in PubSubHeaderMapper.fromHeaders(MessageHeaders, Map).
setParallelPullCount(Integer) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
setParallelPullCount(Integer) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the number of pull workers.
setPayloadType(Class<?>) - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubInboundChannelAdapter
Set the desired type of the payload of the Message constructed by converting the incoming Pub/Sub message.
setPayloadType(Class<?>) - Method in class com.google.cloud.spring.pubsub.integration.inbound.PubSubMessageSource
 
setPublishTimeout(long) - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
Set the timeout in milliseconds for a synchronous publish call to Google Cloud Pub/Sub.
setPublishTimeoutExpression(Expression) - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
Set the SpEL expression to evaluate a timeout in milliseconds for a synchronous publish call to Google Cloud Pub/Sub.
setPublishTimeoutExpressionString(String) - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
Set the SpEL expression to evaluate a timeout in milliseconds for a synchronous publish call to Google Cloud Pub/Sub from a string.
setPullEndpoint(String) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
setPullEndpoint(String) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the endpoint for pulling messages.
setRequestByteThreshold(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Batching
 
setRetryableCodes(StatusCode.Code[]) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
setRetryableCodes(StatusCode.Code[]) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the retryable codes for subscriber pull settings.
setRetryDelayMultiplier(Double) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
setRetrySettings(RetrySettings) - Method in class com.google.cloud.spring.pubsub.support.DefaultPublisherFactory
Set the API call retry configuration.
setRetrySettingsMap(Map<ProjectSubscriptionName, RetrySettings>) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
 
setRpcTimeoutMultiplier(Double) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
setSubscriberStubRetrySettings(RetrySettings) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the retry settings for the generated subscriber stubs.
setSubscription(Map<String, PubSubConfiguration.Subscriber>) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration
This method will be called by Spring Framework when binding user properties.
setSuccessCallback(PubSubMessageHandler.SuccessCallback) - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
Set callback (can be a lambda) for processing the published message ID and the original Message after the message was successfully published.
setSync(boolean) - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
Set publish method to be synchronous or asynchronous.
setSystemExecutorProvider(ExecutorProvider) - Method in class com.google.cloud.spring.pubsub.support.DefaultSubscriberFactory
Set the provider for the system executor, to poll and manage lease extensions.
setTopic(String) - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
Set the topic where this adapter sends messages to.
setTopicExpression(Expression) - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
Set the SpEL expression for the topic this adapter sends messages to.
setTopicExpressionString(String) - Method in class com.google.cloud.spring.pubsub.integration.outbound.PubSubMessageHandler
Set the topic expression string that is evaluated into an actual expression.
setTotalTimeoutSeconds(Long) - Method in class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Retry
 
shutdown() - Method in class com.google.cloud.spring.pubsub.support.CachingPublisherFactory
Shutdown all cached Publisher gracefully.
SimplePubSubMessageConverter - Class in com.google.cloud.spring.pubsub.support.converter
A simple PubSubMessageConverter that directly maps payloads of type byte[], ByteString, ByteBuffer, and String to Pub/Sub messages.
SimplePubSubMessageConverter() - Constructor for class com.google.cloud.spring.pubsub.support.converter.SimplePubSubMessageConverter
 
SimplePubSubMessageConverter(Charset) - Constructor for class com.google.cloud.spring.pubsub.support.converter.SimplePubSubMessageConverter
 
subscribe(String, Consumer<BasicAcknowledgeablePubsubMessage>) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
subscribe(String, Consumer<BasicAcknowledgeablePubsubMessage>) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Add a callback method to an existing subscription.
subscribe(String, Consumer<BasicAcknowledgeablePubsubMessage>) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
 
subscribeAndConvert(String, Consumer<ConvertedBasicAcknowledgeablePubsubMessage<T>>, Class<T>) - Method in class com.google.cloud.spring.pubsub.core.PubSubTemplate
 
subscribeAndConvert(String, Consumer<ConvertedBasicAcknowledgeablePubsubMessage<T>>, Class<T>) - Method in interface com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberOperations
Add a callback method to an existing subscription that receives Pub/Sub messages converted to the requested payload type.
subscribeAndConvert(String, Consumer<ConvertedBasicAcknowledgeablePubsubMessage<T>>, Class<T>) - Method in class com.google.cloud.spring.pubsub.core.subscriber.PubSubSubscriberTemplate
 
Subscriber() - Constructor for class com.google.cloud.spring.pubsub.core.PubSubConfiguration.Subscriber
 
SubscriberFactory - Interface in com.google.cloud.spring.pubsub.support
Interface used by the PubSubTemplate to create supporting objects for consuming messages from Pub/Sub subscriptions.
subscription() - Method in interface com.google.cloud.spring.pubsub.core.health.HealthTracker
Accessor for the Subscription being monitored by the tracker.
subscription() - Method in class com.google.cloud.spring.pubsub.core.health.HealthTrackerImpl
 

T

toHeaders(Map<String, String>) - Method in class com.google.cloud.spring.pubsub.integration.PubSubHeaderMapper
Generate headers in Message format from Map<String, String>.
TOPIC - Static variable in class com.google.cloud.spring.pubsub.support.GcpPubSubHeaders
The topic header text.
toProjectSubscriptionName(String, String) - Static method in class com.google.cloud.spring.pubsub.support.PubSubSubscriptionUtils
Create a ProjectSubscriptionName based on a subscription name within a project or the fully-qualified subscription name.
toProjectTopicName(String, String) - Static method in class com.google.cloud.spring.pubsub.support.PubSubTopicUtils
Create a ProjectTopicName based on a topic name within a project or the fully-qualified topic name.
toPubSubMessage(Object, Map<String, String>) - Method in class com.google.cloud.spring.pubsub.support.converter.JacksonPubSubMessageConverter
 
toPubSubMessage(Object, Map<String, String>) - Method in interface com.google.cloud.spring.pubsub.support.converter.PubSubMessageConverter
Create a PubsubMessage given an object for the payload and a map of headers.
toPubSubMessage(Object, Map<String, String>) - Method in class com.google.cloud.spring.pubsub.support.converter.SimplePubSubMessageConverter
 
toTopicName(String, String) - Static method in class com.google.cloud.spring.pubsub.support.PubSubTopicUtils
Create a TopicName based on a topic name within a project or the fully-qualified topic name.

U

UNDELIVERED_FILTER_TEMPLATE - Static variable in interface com.google.cloud.spring.pubsub.core.health.HealthTracker
Template for undelivered messages filter.
undeliveredFilter(String) - Method in interface com.google.cloud.spring.pubsub.core.health.HealthTracker
Creates a GCP Monitoring filter to query the message backlog of a Pub/Sub subscription.

V

valueOf(String) - Static method in enum class com.google.cloud.spring.pubsub.integration.AckMode
Returns the enum constant of this class with the specified name.
values() - Static method in enum class com.google.cloud.spring.pubsub.integration.AckMode
Returns an array containing the constants of this enum class, in the order they are declared.

W

wrap(ProjectSubscriptionName, MessageReceiver) - Method in interface com.google.cloud.spring.pubsub.core.health.HealthTrackerRegistry
Wrap a message receiver for a ProjectSubscriptionName.
A B C D F G H I J L M N O P R S T U V W 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form