public class PatternMultiTopicsConsumerImpl<T> extends MultiTopicsConsumerImpl<T> implements io.netty.util.TimerTask
Modifier and Type | Field and Description |
---|---|
protected PulsarClientImpl |
client |
protected String |
topic |
namespaceName, topics
conf, consumerEventListener, consumerName, interceptors, listener, listenerExecutor, maxReceiverQueueSize, pendingReceives, schema, subscribeFuture, subscription
Constructor and Description |
---|
PatternMultiTopicsConsumerImpl(Pattern topicsPattern,
PulsarClientImpl client,
ConsumerConfigurationData<T> conf,
ExecutorService listenerExecutor,
CompletableFuture<Consumer<T>> subscribeFuture,
Schema<T> schema,
PulsarApi.CommandGetTopicsOfNamespace.Mode subscriptionMode,
ConsumerInterceptors<T> interceptors) |
Modifier and Type | Method and Description |
---|---|
protected boolean |
changeToReadyState() |
CompletableFuture<Void> |
closeAsync()
Asynchronously close the consumer and stop the broker to push more messages
|
protected org.apache.pulsar.client.impl.HandlerState.State |
getAndUpdateState(UnaryOperator<org.apache.pulsar.client.impl.HandlerState.State> updater) |
PulsarClientImpl |
getClient() |
static NamespaceName |
getNameSpaceFromPattern(Pattern pattern) |
Pattern |
getPattern() |
protected org.apache.pulsar.client.impl.HandlerState.State |
getState() |
void |
run(io.netty.util.Timeout timeout) |
protected void |
setState(org.apache.pulsar.client.impl.HandlerState.State s) |
static List<String> |
topicsListsMinus(List<String> list1,
List<String> list2) |
createPartitionedConsumer, doAcknowledge, getAvailablePermits, getConsumers, getPartitionedTopics, getStats, getTopics, getUnAckedMessageTracker, hasReachedEndOfTopic, internalReceive, internalReceive, internalReceiveAsync, isConnected, numMessagesInQueue, redeliverUnacknowledgedMessages, redeliverUnacknowledgedMessages, seek, seekAsync, subscribeAsync, unsubscribeAsync, unsubscribeAsync
acknowledge, acknowledge, acknowledgeAsync, acknowledgeAsync, acknowledgeCumulative, acknowledgeCumulative, acknowledgeCumulativeAsync, acknowledgeCumulativeAsync, beforeConsume, close, getConsumerName, getSubscription, getSubType, getTopic, onAcknowledge, onAcknowledgeCumulative, receive, receive, receiveAsync, setMaxReceiverQueueSize, subscribeFuture, toString, unsubscribe
protected final PulsarClientImpl client
protected final String topic
public PatternMultiTopicsConsumerImpl(Pattern topicsPattern, PulsarClientImpl client, ConsumerConfigurationData<T> conf, ExecutorService listenerExecutor, CompletableFuture<Consumer<T>> subscribeFuture, Schema<T> schema, PulsarApi.CommandGetTopicsOfNamespace.Mode subscriptionMode, ConsumerInterceptors<T> interceptors)
public static NamespaceName getNameSpaceFromPattern(Pattern pattern)
public void run(io.netty.util.Timeout timeout) throws Exception
run
in interface io.netty.util.TimerTask
Exception
public Pattern getPattern()
public static List<String> topicsListsMinus(List<String> list1, List<String> list2)
public CompletableFuture<Void> closeAsync()
Consumer
closeAsync
in interface Consumer<T>
closeAsync
in class MultiTopicsConsumerImpl<T>
protected boolean changeToReadyState()
protected org.apache.pulsar.client.impl.HandlerState.State getState()
protected void setState(org.apache.pulsar.client.impl.HandlerState.State s)
protected org.apache.pulsar.client.impl.HandlerState.State getAndUpdateState(UnaryOperator<org.apache.pulsar.client.impl.HandlerState.State> updater)
public PulsarClientImpl getClient()
Copyright © 2017–2018 Apache Software Foundation. All rights reserved.