Uses of Class
org.apache.pulsar.client.api.PulsarClientException
-
Packages that use PulsarClientException Package Description org.apache.pulsar.client.api Pulsar Client API. -
-
Uses of PulsarClientException in org.apache.pulsar.client.api
Subclasses of PulsarClientException in org.apache.pulsar.client.api Modifier and Type Class Description static class
PulsarClientException.AlreadyClosedException
Already closed exception thrown by Pulsar client.static class
PulsarClientException.AuthenticationException
Authentication exception thrown by Pulsar client.static class
PulsarClientException.AuthorizationException
Authorization exception thrown by Pulsar client.static class
PulsarClientException.BrokerMetadataException
Broker metadata exception thrown by Pulsar client.static class
PulsarClientException.BrokerPersistenceException
Broker persistence exception thrown by Pulsar client.static class
PulsarClientException.ChecksumException
Checksum exception thrown by Pulsar client.static class
PulsarClientException.ConnectException
Connect exception thrown by Pulsar client.static class
PulsarClientException.ConsumerAssignException
Consumer assign exception thrown by Pulsar client.static class
PulsarClientException.ConsumerBusyException
Consumer busy exception thrown by Pulsar client.static class
PulsarClientException.CryptoException
Crypto exception thrown by Pulsar client.static class
PulsarClientException.GettingAuthenticationDataException
Getting authentication data exception thrown by Pulsar client.static class
PulsarClientException.IncompatibleSchemaException
Incompatible schema exception thrown by Pulsar client.static class
PulsarClientException.InvalidConfigurationException
Invalid Configuration exception thrown by Pulsar client.static class
PulsarClientException.InvalidMessageException
Invalid message exception thrown by Pulsar client.static class
PulsarClientException.InvalidServiceURL
Invalid Service URL exception thrown by Pulsar client.static class
PulsarClientException.InvalidTopicNameException
Invalid topic name exception thrown by Pulsar client.static class
PulsarClientException.LookupException
Lookup exception thrown by Pulsar client.static class
PulsarClientException.MemoryBufferIsFullError
Memory buffer full error thrown by Pulsar client.static class
PulsarClientException.MessageAcknowledgeException
Consumer assign exception thrown by Pulsar client.static class
PulsarClientException.NotAllowedException
Not allowed exception thrown by Pulsar client.static class
PulsarClientException.NotConnectedException
Not connected exception thrown by Pulsar client.static class
PulsarClientException.NotFoundException
Not Found exception thrown by Pulsar client.static class
PulsarClientException.NotSupportedException
Not supported exception thrown by Pulsar client.static class
PulsarClientException.ProducerBlockedQuotaExceededError
Producer blocked quota exceeded error thrown by Pulsar client.static class
PulsarClientException.ProducerBlockedQuotaExceededException
Producer blocked quota exceeded exception thrown by Pulsar client.static class
PulsarClientException.ProducerBusyException
Producer busy exception thrown by Pulsar client.static class
PulsarClientException.ProducerFencedException
Producer fenced exception thrown by Pulsar client.static class
PulsarClientException.ProducerQueueIsFullError
Full producer queue error thrown by Pulsar client.static class
PulsarClientException.TimeoutException
Timeout exception thrown by Pulsar client.static class
PulsarClientException.TooManyRequestsException
Too many requests exception thrown by Pulsar client.static class
PulsarClientException.TopicDoesNotExistException
Topic does not exist and cannot be created.static class
PulsarClientException.TopicTerminatedException
Topic terminated exception thrown by Pulsar client.static class
PulsarClientException.TransactionConflictException
Consumer assign exception thrown by Pulsar client.static class
PulsarClientException.UnsupportedAuthenticationException
Unsupported authentication exception thrown by Pulsar client.Methods in org.apache.pulsar.client.api that return PulsarClientException Modifier and Type Method Description static PulsarClientException
PulsarClientException. unwrap(java.lang.Throwable t)
Methods in org.apache.pulsar.client.api that throw PulsarClientException Modifier and Type Method Description void
Consumer. acknowledge(java.util.List<MessageId> messageIdList)
Acknowledge the consumption of a list of message.void
Consumer. acknowledge(Message<?> message)
Acknowledge the consumption of a single message.void
Consumer. acknowledge(MessageId messageId)
Acknowledge the consumption of a single message, identified by itsMessageId
.void
Consumer. acknowledge(Messages<?> messages)
Acknowledge the consumption ofMessages
.void
Consumer. acknowledgeCumulative(Message<?> message)
Acknowledge the reception of all the messages in the stream up to (and including) the provided message.void
Consumer. acknowledgeCumulative(MessageId messageId)
Acknowledge the reception of all the messages in the stream up to (and including) the provided message.Messages<T>
Consumer. batchReceive()
Batch receiving messages.PulsarClient
ClientBuilder. build()
Construct the finalPulsarClient
instance.void
Consumer. close()
Close the consumer and stop the broker to push more messages.void
Producer. close()
Close the producer and releases resources allocated.void
PulsarClient. close()
Close the PulsarClient and release all the resources.Producer<T>
ProducerBuilder. create()
Finalize the creation of theProducer
instance.Reader<T>
ReaderBuilder. create()
Finalize the creation of theReader
instance.void
MessageCrypto. encrypt(java.util.Set<java.lang.String> encKeys, CryptoKeyReader keyReader, java.util.function.Supplier<BuilderT> messageMetadataBuilderSupplier, java.nio.ByteBuffer payload, java.nio.ByteBuffer outBuffer)
void
Producer. flush()
Flush all the messages buffered in the client and wait until all messages have been successfully persisted.default AuthenticationDataProvider
Authentication. getAuthData()
default AuthenticationDataProvider
Authentication. getAuthData(java.lang.String brokerHostName)
Get/Create an authentication data provider which provides the data that this client will be sent to the broker.MessageId
Consumer. getLastMessageId()
Get the last message id available for consume.boolean
Reader. hasMessageAvailable()
Check if there is any message available to read from the current position.TransactionBuilder
PulsarClient. newTransaction()
Create a transaction builder that can be used to configure and construct a transaction.Message<T>
Reader. readNext()
Read the next message in the topic.Message<T>
Reader. readNext(int timeout, java.util.concurrent.TimeUnit unit)
Read the next message in the topic waiting for a maximum time.Message<T>
Consumer. receive()
Receives a single message.Message<T>
Consumer. receive(int timeout, java.util.concurrent.TimeUnit unit)
Receive a single message.void
Consumer. reconsumeLater(Message<?> message, long delayTime, java.util.concurrent.TimeUnit unit)
reconsumeLater the consumption ofMessages
.void
Consumer. reconsumeLater(Messages<?> messages, long delayTime, java.util.concurrent.TimeUnit unit)
reconsumeLater the consumption ofMessages
.void
Consumer. reconsumeLaterCumulative(Message<?> message, long delayTime, java.util.concurrent.TimeUnit unit)
reconsumeLater the reception of all the messages in the stream up to (and including) the provided message.void
Consumer. seek(long timestamp)
Reset the subscription associated with this consumer to a specific message publish time.void
Consumer. seek(java.util.function.Function<java.lang.String,java.lang.Object> function)
Reset the subscription associated with this consumer to a specific message ID or message publish time.void
Consumer. seek(MessageId messageId)
Reset the subscription associated with this consumer to a specific message id.void
Reader. seek(long timestamp)
Reset the subscription associated with this reader to a specific message publish time.void
Reader. seek(java.util.function.Function<java.lang.String,java.lang.Object> function)
Reset the subscription associated with this consumer to a specific message ID or message publish time.void
Reader. seek(MessageId messageId)
Reset the subscription associated with this reader to a specific message id.MessageId
Producer. send(T message)
Sends a message.MessageId
TypedMessageBuilder. send()
Send a message synchronously.void
PulsarClient. shutdown()
Perform immediate shutdown of PulsarClient.void
Authentication. start()
Initialize the authentication provider.Consumer<T>
ConsumerBuilder. subscribe()
Finalize theConsumer
creation by subscribing to the topic.void
Consumer. unsubscribe()
Unsubscribe the consumer.void
PulsarClient. updateServiceUrl(java.lang.String serviceUrl)
Update the service URL this client is using.
-