Uses of Class
org.apache.pulsar.client.api.PulsarClientException
Packages that use PulsarClientException
-
Uses of PulsarClientException in org.apache.pulsar.client.api
Subclasses of PulsarClientException in org.apache.pulsar.client.apiModifier and TypeClassDescriptionstatic classAlready closed exception thrown by Pulsar client.static classAuthentication exception thrown by Pulsar client.static classAuthorization exception thrown by Pulsar client.static classBroker metadata exception thrown by Pulsar client.static classBroker persistence exception thrown by Pulsar client.static classChecksum exception thrown by Pulsar client.static classConnect exception thrown by Pulsar client.static classConsumer assign exception thrown by Pulsar client.static classConsumer busy exception thrown by Pulsar client.static classCrypto exception thrown by Pulsar client.static classNot supported exception thrown by Pulsar client.static classGetting authentication data exception thrown by Pulsar client.static classIncompatible schema exception thrown by Pulsar client.static classInvalid Configuration exception thrown by Pulsar client.static classInvalid message exception thrown by Pulsar client.static classInvalid Service URL exception thrown by Pulsar client.static classInvalid topic name exception thrown by Pulsar client.static classLookup exception thrown by Pulsar client.static classMemory buffer full error thrown by Pulsar client.static classConsumer assign exception thrown by Pulsar client.static classNot allowed exception thrown by Pulsar client.static classNot connected exception thrown by Pulsar client.static classNot Found exception thrown by Pulsar client.static classNot supported exception thrown by Pulsar client.static classProducer blocked quota exceeded error thrown by Pulsar client.static classProducer blocked quota exceeded exception thrown by Pulsar client.static classProducer busy exception thrown by Pulsar client.static classProducer fenced exception thrown by Pulsar client.static classFull producer queue error thrown by Pulsar client.static classRelates to server-side errors: ServiceUnitNotReadyException, TopicFencedException and SubscriptionFencedException.static classNot found subscription that cannot be created.static classTimeout exception thrown by Pulsar client.static classToo many requests exception thrown by Pulsar client.static classTopic does not exist and cannot be created.static classTopicMigration exception thrown by Pulsar client.static classTopic terminated exception thrown by Pulsar client.static classConsumer assign exception thrown by Pulsar client.static classstatic classUnsupported authentication exception thrown by Pulsar client.Methods in org.apache.pulsar.client.api that return PulsarClientExceptionMethods in org.apache.pulsar.client.api that throw PulsarClientExceptionModifier and TypeMethodDescriptionvoidMessageAcknowledger.acknowledge(List<MessageId> messageIdList) Acknowledge the consumption of a list of message.default voidMessageAcknowledger.acknowledge(Message<?> message) voidMessageAcknowledger.acknowledge(MessageId messageId) Acknowledge the consumption of a single message.default voidMessageAcknowledger.acknowledge(Messages<?> messages) default voidMessageAcknowledger.acknowledgeCumulative(Message<?> message) voidMessageAcknowledger.acknowledgeCumulative(MessageId messageId) Acknowledge the reception of all the messages in the stream up to (and including) the provided message.Consumer.batchReceive()Batch receiving messages.ClientBuilder.build()Construct the finalPulsarClientinstance.voidConsumer.close()Close the consumer and stop the broker to push more messages.voidProducer.close()Close the producer and releases resources allocated.voidPulsarClient.close()Close the PulsarClient and release all the resources.ProducerBuilder.create()Finalize the creation of theProducerinstance.ReaderBuilder.create()Finalize the creation of theReaderinstance.TableViewBuilder.create()Finalize the creation of theTableViewinstance.voidMessageCrypto.encrypt(Set<String> encKeys, CryptoKeyReader keyReader, Supplier<BuilderT> messageMetadataBuilderSupplier, ByteBuffer payload, ByteBuffer outBuffer) voidProducer.flush()Flush all the messages buffered in the client and wait until all messages have been successfully persisted.default AuthenticationDataProviderAuthentication.getAuthData()Deprecated.default AuthenticationDataProviderAuthentication.getAuthData(String brokerHostName) Get/Create an authentication data provider which provides the data that this client will be sent to the broker.Consumer.getLastMessageId()Deprecated.Consumer.getLastMessageIds()Get all the last message id of the topics the consumer subscribed.booleanReader.hasMessageAvailable()Check if there is any message available to read from the current position.Reader.readNext()Read the next message in the topic.Read the next message in the topic waiting for a maximum time.Consumer.receive()Receives a single message in blocking mode.Receive a single message.voidConsumer.reconsumeLater(Message<?> message, long delayTime, TimeUnit unit) reconsumeLater the consumption ofMessages.voidConsumer.reconsumeLater(Message<?> message, Map<String, String> customProperties, long delayTime, TimeUnit unit) reconsumeLater the consumption ofMessages.voidConsumer.reconsumeLater(Messages<?> messages, long delayTime, TimeUnit unit) reconsumeLater the consumption ofMessages.voidConsumer.reconsumeLaterCumulative(Message<?> message, long delayTime, TimeUnit unit) reconsumeLater the reception of all the messages in the stream up to (and including) the provided message.voidConsumer.seek(long timestamp) Reset the subscription associated with this consumer to a specific message publish time.voidReset the subscription associated with this consumer to a specific message ID or message publish time.voidReset the subscription associated with this consumer to a specific message id.voidReader.seek(long timestamp) Reset the subscription associated with this reader to a specific message publish time.voidReset the subscription associated with this consumer to a specific message ID or message publish time.voidReset the subscription associated with this reader to a specific message id.Sends a message.TypedMessageBuilder.send()Send a message synchronously.voidPulsarClient.shutdown()Perform immediate shutdown of PulsarClient.voidAuthentication.start()Initialize the authentication provider.ConsumerBuilder.subscribe()Finalize theConsumercreation by subscribing to the topic.voidConsumer.unsubscribe()Unsubscribe the consumer.voidPulsarClient.updateServiceUrl(String serviceUrl) Update the service URL this client is using.
Consumer.getLastMessageIds()instead.