public class PatternMultiTopicsConsumerImpl<T> extends MultiTopicsConsumerImpl<T> implements io.netty.util.TimerTask
ConsumerBase.OpBatchReceive<T>| Modifier and Type | Field and Description |
|---|---|
protected PulsarClientImpl |
client |
protected NamespaceName |
namespaceName |
protected String |
topic |
DUMMY_TOPIC_NAME_PREFIX, topicsbatchReceivePolicy, batchReceiveTimeout, conf, consumerEventListener, consumerName, INCOMING_MESSAGES_SIZE_UPDATER, incomingMessagesSize, interceptors, listener, listenerExecutor, maxReceiverQueueSize, pendingBatchReceives, pendingReceives, reentrantLock, schema, subscribeFuture, subscription, unAckedChunckedMessageIdSequenceMap| 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() |
protected boolean |
changeToRegisteringSchemaState() |
CompletableFuture<Void> |
closeAsync() |
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) |
completeOpBatchReceive, createPartitionedConsumer, doAcknowledge, doAcknowledge, doReconsumeLater, getAvailablePermits, getConsumers, getLastDisconnectedTimestamp, getLastMessageIdAsync, getPartitionedTopics, getPartitionsAutoUpdateTimeout, getStats, getTopics, getUnAckedMessageTracker, hasMessageAvailable, hasMessageAvailableAsync, hasReachedEndOfTopic, internalBatchReceive, internalBatchReceiveAsync, internalReceive, internalReceive, internalReceiveAsync, isConnected, isIllegalMultiTopicsMessageId, messageProcessed, negativeAcknowledge, numMessagesInQueue, pause, redeliverUnacknowledgedMessages, redeliverUnacknowledgedMessages, removeConsumerAsync, resume, seek, seek, seekAsync, seekAsync, subscribeAsync, tryAcknowledgeMessage, unsubscribeAsync, unsubscribeAsyncacknowledge, acknowledge, acknowledge, acknowledge, acknowledgeAsync, acknowledgeAsync, acknowledgeAsync, acknowledgeAsync, acknowledgeAsync, acknowledgeCumulative, acknowledgeCumulative, acknowledgeCumulativeAsync, acknowledgeCumulativeAsync, acknowledgeCumulativeAsync, batchReceive, batchReceiveAsync, beforeConsume, canEnqueueMessage, close, completePendingBatchReceive, completePendingReceive, doAcknowledgeWithTxn, doAcknowledgeWithTxn, enqueueMessageAndCheckBatchReceive, failPendingBatchReceives, failPendingReceives, getConsumerName, getLastMessageId, getNewMessagesImpl, getSubscription, getSubType, getTopic, hasEnoughMessagesForBatchReceive, hasPendingBatchReceive, negativeAcknowledge, negativeAcknowledge, notifyPendingBatchReceivedCallBack, notifyPendingBatchReceivedCallBack, onAcknowledge, onAcknowledgeCumulative, onAckTimeoutSend, onNegativeAcksSend, peekPendingReceive, pollPendingReceive, receive, receive, receiveAsync, reconsumeLater, reconsumeLater, reconsumeLaterAsync, reconsumeLaterAsync, reconsumeLaterCumulative, reconsumeLaterCumulativeAsync, setMaxReceiverQueueSize, subscribeFuture, toString, unsubscribeprotected NamespaceName namespaceName
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.TimerTaskExceptionpublic Pattern getPattern()
public static List<String> topicsListsMinus(List<String> list1, List<String> list2)
public CompletableFuture<Void> closeAsync()
closeAsync in interface Consumer<T>closeAsync in class MultiTopicsConsumerImpl<T>protected boolean changeToReadyState()
protected boolean changeToRegisteringSchemaState()
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–2020 Apache Software Foundation. All rights reserved.