Uses of Class
com.google.cloud.pubsublite.internal.CheckedApiException
-
-
Uses of CheckedApiException in com.google.cloud.pubsublite.cloudpubsub.internal
Methods in com.google.cloud.pubsublite.cloudpubsub.internal with parameters of type CheckedApiException Modifier and Type Method Description protected void
AckSetTrackerImpl. handlePermanentError(CheckedApiException error)
protected void
AssigningSubscriber. handlePermanentError(CheckedApiException error)
protected void
SinglePartitionSubscriber. handlePermanentError(CheckedApiException error)
Methods in com.google.cloud.pubsublite.cloudpubsub.internal that throw CheckedApiException Modifier and Type Method Description Subscriber
PartitionSubscriberFactory. newSubscriber(Partition partition)
protected void
AckSetTrackerImpl. start()
protected void
SinglePartitionSubscriber. start()
protected void
AckSetTrackerImpl. stop()
Runnable
AckSetTrackerImpl. track(SequencedMessage message)
void
AckSetTrackerImpl. waitUntilCommitted()
-
Uses of CheckedApiException in com.google.cloud.pubsublite.internal
Methods in com.google.cloud.pubsublite.internal that return CheckedApiException Modifier and Type Method Description static CheckedApiException
ExtractStatus. toCanonical(Throwable t)
Methods in com.google.cloud.pubsublite.internal that return types with arguments of type CheckedApiException Modifier and Type Method Description static Optional<CheckedApiException>
ExtractStatus. extract(Throwable t)
Methods in com.google.cloud.pubsublite.internal with parameters of type CheckedApiException Modifier and Type Method Description static String
ExtractStatus. getErrorInfoReason(CheckedApiException error)
protected void
ProxyService. handlePermanentError(CheckedApiException error)
protected void
ProxyService. onPermanentError(CheckedApiException error)
Method parameters in com.google.cloud.pubsublite.internal with type arguments of type CheckedApiException Modifier and Type Method Description static void
ExtractStatus. addFailureHandler(com.google.api.core.ApiFuture<?> future, Consumer<CheckedApiException> consumer)
Methods in com.google.cloud.pubsublite.internal that throw CheckedApiException Modifier and Type Method Description void
ExtractStatus.StatusBiconsumer. apply(K key, V value)
void
ExtractStatus.StatusConsumer. apply(I input)
O
ExtractStatus.StatusFunction. apply(I input)
static void
CheckedApiPreconditions. checkArgument(boolean test)
static void
CheckedApiPreconditions. checkArgument(boolean test, String description)
static void
CheckedApiPreconditions. checkArgument(boolean test, String descriptionFormat, Object... args)
static void
CheckedApiPreconditions. checkState(boolean test)
static void
CheckedApiPreconditions. checkState(boolean test, String description)
static void
CheckedApiPreconditions. checkState(boolean test, String descriptionFormat, Object... args)
Optional<SequencedMessage>
BlockingPullSubscriber. messageIfAvailable()
Pull messages if there is any ready to deliver.Optional<SequencedMessage>
BlockingPullSubscriberImpl. messageIfAvailable()
List<SequencedMessage>
BufferingPullSubscriber. pull()
List<T>
PullSubscriber. pull()
Partition
RoutingPolicy. route(PubSubMessage messageKey)
protected void
ProxyService. start()
protected void
ProxyService. stop()
Constructors in com.google.cloud.pubsublite.internal that throw CheckedApiException Constructor Description BlockingPullSubscriberImpl(SubscriberFactory factory, FlowControlSettings settings)
BufferingPullSubscriber(SubscriberFactory factory, FlowControlSettings settings)
-
Uses of CheckedApiException in com.google.cloud.pubsublite.internal.testing
Methods in com.google.cloud.pubsublite.internal.testing that return CheckedApiException Modifier and Type Method Description static CheckedApiException
TestResetSignal. newCheckedException()
-
Uses of CheckedApiException in com.google.cloud.pubsublite.internal.wire
Methods in com.google.cloud.pubsublite.internal.wire with parameters of type CheckedApiException Modifier and Type Method Description protected void
CommitterImpl. handlePermanentError(CheckedApiException error)
protected void
PartitionCountWatchingPublisher. handlePermanentError(CheckedApiException error)
protected void
PublisherImpl. handlePermanentError(CheckedApiException error)
protected void
SubscriberImpl. handlePermanentError(CheckedApiException error)
static boolean
ResetSignal. isResetSignal(CheckedApiException checkedApiException)
protected void
SingleConnection. setError(CheckedApiException error)
void
AssignerImpl. triggerReinitialize(CheckedApiException streamError)
void
CommitterImpl. triggerReinitialize(CheckedApiException streamError)
void
PublisherImpl. triggerReinitialize(CheckedApiException streamError)
void
RetryingConnectionObserver. triggerReinitialize(CheckedApiException streamError)
void
SubscriberImpl. triggerReinitialize(CheckedApiException streamError)
Methods in com.google.cloud.pubsublite.internal.wire that throw CheckedApiException Modifier and Type Method Description void
Subscriber. allowFlow(FlowControlRequest request)
void
SubscriberImpl. allowFlow(FlowControlRequest clientRequest)
boolean
SubscriberResetHandler. handleReset()
protected void
ConnectedAssignerImpl. handleStreamResponse(PartitionAssignment response)
protected void
ConnectedCommitterImpl. handleStreamResponse(StreamingCommitCursorResponse response)
protected abstract void
SingleConnection. handleStreamResponse(StreamResponseT response)
void
AssignerImpl. onClientResponse(PartitionAssignment value)
void
CommitterImpl. onClientResponse(SequencedCommitCursorResponse value)
void
PublisherImpl. onClientResponse(MessagePublishResponse publishResponse)
void
RetryingConnectionObserver. onClientResponse(ClientResponseT value)
void
SubscriberImpl. onClientResponse(List<SequencedMessage> messages)
void
BatchingCommitter. waitUntilEmpty()
void
Committer. waitUntilEmpty()
void
CommitterImpl. waitUntilEmpty()
-