Package | Description |
---|---|
com.google.cloud.spring.pubsub.core |
Core support for Pub/Sub in Spring.
|
com.google.cloud.spring.pubsub.core.subscriber |
Operations and template for subscribing in Spring Cloud GCP Pub/Sub.
|
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.reactive | |
com.google.cloud.spring.pubsub.support.converter |
Classes related to converting messages in Spring Cloud GCP Pub/Sub.
|
Modifier and Type | Method and Description |
---|---|
List<AcknowledgeablePubsubMessage> |
PubSubTemplate.pull(String subscription,
Integer maxMessages,
Boolean returnImmediately) |
org.springframework.util.concurrent.ListenableFuture<List<AcknowledgeablePubsubMessage>> |
PubSubTemplate.pullAsync(String subscription,
Integer maxMessages,
Boolean returnImmediately) |
Modifier and Type | Method and Description |
---|---|
org.springframework.util.concurrent.ListenableFuture<Void> |
PubSubTemplate.ack(Collection<? extends AcknowledgeablePubsubMessage> acknowledgeablePubsubMessages) |
org.springframework.util.concurrent.ListenableFuture<Void> |
PubSubTemplate.modifyAckDeadline(Collection<? extends AcknowledgeablePubsubMessage> acknowledgeablePubsubMessages,
int ackDeadlineSeconds) |
org.springframework.util.concurrent.ListenableFuture<Void> |
PubSubTemplate.nack(Collection<? extends AcknowledgeablePubsubMessage> acknowledgeablePubsubMessages) |
Modifier and Type | Method and Description |
---|---|
List<AcknowledgeablePubsubMessage> |
PubSubSubscriberOperations.pull(String subscription,
Integer maxMessages,
Boolean returnImmediately)
Pull a number of messages from a Google Cloud Pub/Sub subscription.
|
List<AcknowledgeablePubsubMessage> |
PubSubSubscriberTemplate.pull(String subscription,
Integer maxMessages,
Boolean returnImmediately) |
org.springframework.util.concurrent.ListenableFuture<List<AcknowledgeablePubsubMessage>> |
PubSubSubscriberOperations.pullAsync(String subscription,
Integer maxMessages,
Boolean returnImmediately)
Asynchronously pull a number of messages from a Google Cloud Pub/Sub subscription.
|
org.springframework.util.concurrent.ListenableFuture<List<AcknowledgeablePubsubMessage>> |
PubSubSubscriberTemplate.pullAsync(String subscription,
Integer maxMessages,
Boolean returnImmediately) |
Modifier and Type | Method and Description |
---|---|
org.springframework.util.concurrent.ListenableFuture<Void> |
PubSubSubscriberOperations.ack(Collection<? extends AcknowledgeablePubsubMessage> acknowledgeablePubsubMessages)
Acknowledge a batch of messages.
|
org.springframework.util.concurrent.ListenableFuture<Void> |
PubSubSubscriberTemplate.ack(Collection<? extends AcknowledgeablePubsubMessage> acknowledgeablePubsubMessages)
Acknowledge messages in per-subscription batches.
|
org.springframework.util.concurrent.ListenableFuture<Void> |
PubSubSubscriberOperations.modifyAckDeadline(Collection<? extends AcknowledgeablePubsubMessage> acknowledgeablePubsubMessages,
int ackDeadlineSeconds)
Modify the ack deadline of a batch of messages.
|
org.springframework.util.concurrent.ListenableFuture<Void> |
PubSubSubscriberTemplate.modifyAckDeadline(Collection<? extends AcknowledgeablePubsubMessage> acknowledgeablePubsubMessages,
int ackDeadlineSeconds)
Modify multiple messages' ack deadline in per-subscription batches.
|
org.springframework.util.concurrent.ListenableFuture<Void> |
PubSubSubscriberOperations.nack(Collection<? extends AcknowledgeablePubsubMessage> acknowledgeablePubsubMessages)
Negatively acknowledge a batch of messages.
|
org.springframework.util.concurrent.ListenableFuture<Void> |
PubSubSubscriberTemplate.nack(Collection<? extends AcknowledgeablePubsubMessage> acknowledgeablePubsubMessages)
Nack messages in per-subscription batches.
|
Constructor and Description |
---|
PubSubAcknowledgmentCallback(AcknowledgeablePubsubMessage message,
AckMode ackMode) |
Modifier and Type | Method and Description |
---|---|
reactor.core.publisher.Flux<AcknowledgeablePubsubMessage> |
PubSubReactiveFactory.poll(String subscriptionName,
long pollingPeriodMs)
Create an infinite stream
Flux of AcknowledgeablePubsubMessage objects. |
Modifier and Type | Interface and Description |
---|---|
interface |
ConvertedAcknowledgeablePubsubMessage<T>
An
AcknowledgeablePubsubMessage that also contains the payload of the Pub/Sub
message converted to the desired type T . |
Copyright © 2021. All rights reserved.