Uses of Class
org.apache.pulsar.client.impl.PulsarClientImpl
Packages that use PulsarClientImpl
Package
Description
Pulsar Client implementation.
Transaction client implementation.
-
Uses of PulsarClientImpl in org.apache.pulsar.client.impl
Fields in org.apache.pulsar.client.impl declared as PulsarClientImplModifier and TypeFieldDescriptionprotected final PulsarClientImplHandlerState.clientprotected final PulsarClientImplHandlerState.clientprotected final PulsarClientImplHandlerState.clientprotected final PulsarClientImplHandlerState.clientprotected final PulsarClientImplHandlerState.clientprotected final PulsarClientImplHandlerState.clientprotected final PulsarClientImplHandlerState.clientprotected final PulsarClientImplHandlerState.clientprotected final PulsarClientImplHandlerState.clientprotected final PulsarClientImplHandlerState.clientMethods in org.apache.pulsar.client.impl with parameters of type PulsarClientImplModifier and TypeMethodDescriptionstatic <T> MultiTopicsConsumerImpl<T> MultiTopicsConsumerImpl.createPartitionedConsumer(PulsarClientImpl client, ConsumerConfigurationData<T> conf, ExecutorProvider executorProvider, CompletableFuture<Consumer<T>> subscribeFuture, int numPartitions, Schema<T> schema, ConsumerInterceptors<T> interceptors) protected <T> CompletableFuture<Schema<T>> PulsarClientImpl.preProcessSchemaBeforeSubscribe(PulsarClientImpl pulsarClientImpl, Schema<T> schema, String topicName) Constructors in org.apache.pulsar.client.impl with parameters of type PulsarClientImplModifierConstructorDescriptionBinaryProtoLookupService(PulsarClientImpl client, String serviceUrl, boolean useTls, ExecutorService executor) BinaryProtoLookupService(PulsarClientImpl client, String serviceUrl, String listenerName, boolean useTls, ExecutorService executor) protectedConsumerBase(PulsarClientImpl client, String topic, ConsumerConfigurationData<T> conf, int receiverQueueSize, ExecutorProvider executorProvider, CompletableFuture<Consumer<T>> subscribeFuture, Schema<T> schema, ConsumerInterceptors interceptors) ConsumerBuilderImpl(PulsarClientImpl client, Schema<T> schema) protectedConsumerImpl(PulsarClientImpl client, String topic, ConsumerConfigurationData<T> conf, ExecutorProvider executorProvider, int partitionIndex, boolean hasParentConsumer, boolean parentConsumerHasListener, CompletableFuture<Consumer<T>> subscribeFuture, MessageId startMessageId, long startMessageRollbackDurationInSec, Schema<T> schema, ConsumerInterceptors<T> interceptors, boolean createTopicIfDoesNotExist) ConsumerStatsRecorderImpl(PulsarClientImpl pulsarClient, ConsumerConfigurationData<?> conf, Consumer<?> consumer) MultiTopicConsumerStatsRecorderImpl(PulsarClientImpl pulsarClient, ConsumerConfigurationData<?> conf, Consumer<?> consumer) MultiTopicsReaderImpl(PulsarClientImpl client, ReaderConfigurationData<T> readerConfiguration, ExecutorProvider executorProvider, CompletableFuture<Consumer<T>> consumerFuture, Schema<T> schema) PartitionedProducerImpl(PulsarClientImpl client, String topic, ProducerConfigurationData conf, int numPartitions, CompletableFuture<Producer<T>> producerCreatedFuture, Schema<T> schema, ProducerInterceptors interceptors) PatternMultiTopicsConsumerImpl(com.google.re2j.Pattern topicsPattern, String topicsHash, PulsarClientImpl client, ConsumerConfigurationData<T> conf, ExecutorProvider executorProvider, CompletableFuture<Consumer<T>> subscribeFuture, Schema<T> schema, CommandGetTopicsOfNamespace.Mode subscriptionMode, ConsumerInterceptors<T> interceptors) protectedProducerBase(PulsarClientImpl client, String topic, ProducerConfigurationData conf, CompletableFuture<Producer<T>> producerCreatedFuture, Schema<T> schema, ProducerInterceptors interceptors) ProducerBuilderImpl(PulsarClientImpl client, Schema<T> schema) ProducerImpl(PulsarClientImpl client, String topic, ProducerConfigurationData conf, CompletableFuture<Producer<T>> producerCreatedFuture, int partitionIndex, Schema<T> schema, ProducerInterceptors interceptors, Optional<String> overrideProducerName) ProducerStatsRecorderImpl(PulsarClientImpl pulsarClient, ProducerConfigurationData conf, ProducerImpl<?> producer) ReaderBuilderImpl(PulsarClientImpl client, Schema<T> schema) ReaderImpl(PulsarClientImpl client, ReaderConfigurationData<T> readerConfiguration, ExecutorProvider executorProvider, CompletableFuture<Consumer<T>> consumerFuture, Schema<T> schema) TopicListWatcher(PatternConsumerUpdateQueue patternConsumerUpdateQueue, PulsarClientImpl client, com.google.re2j.Pattern topicsPattern, long watcherId, NamespaceName namespace, String topicsHash, CompletableFuture<TopicListWatcher> watcherFuture, Runnable recheckTopicsChangeAfterReconnect) TransactionMetaStoreHandler(long transactionCoordinatorId, PulsarClientImpl pulsarClient, String topic, CompletableFuture<Void> connectFuture) UnAckedMessageRedeliveryTracker(PulsarClientImpl client, ConsumerBase<?> consumerBase, ConsumerConfigurationData<?> conf) UnAckedMessageTracker(PulsarClientImpl client, ConsumerBase<?> consumerBase, ConsumerConfigurationData<?> conf) UnAckedTopicMessageRedeliveryTracker(PulsarClientImpl client, ConsumerBase<?> consumerBase, ConsumerConfigurationData<?> conf) UnAckedTopicMessageTracker(PulsarClientImpl client, ConsumerBase<?> consumerBase, ConsumerConfigurationData<?> conf) ZeroQueueConsumerImpl(PulsarClientImpl client, String topic, ConsumerConfigurationData<T> conf, ExecutorProvider executorProvider, int partitionIndex, boolean hasParentConsumer, CompletableFuture<Consumer<T>> subscribeFuture, MessageId startMessageId, Schema<T> schema, ConsumerInterceptors<T> interceptors, boolean createTopicIfDoesNotExist) -
Uses of PulsarClientImpl in org.apache.pulsar.client.impl.schema.generic
Methods in org.apache.pulsar.client.impl.schema.generic that return PulsarClientImplConstructors in org.apache.pulsar.client.impl.schema.generic with parameters of type PulsarClientImplModifierConstructorDescriptionMultiVersionSchemaInfoProvider(TopicName topicName, PulsarClientImpl pulsarClient) -
Uses of PulsarClientImpl in org.apache.pulsar.client.impl.transaction
Constructors in org.apache.pulsar.client.impl.transaction with parameters of type PulsarClientImplModifierConstructorDescriptionTransactionBuilderImpl(PulsarClientImpl client, TransactionCoordinatorClientImpl tcClient)