Skip to content

Commit

Permalink
[refactor][client] Remove useless locks in batch receiving.
Browse files Browse the repository at this point in the history
  • Loading branch information
shibd committed Oct 11, 2022
1 parent 3680685 commit ef25f87
Showing 1 changed file with 1 addition and 10 deletions.
Expand Up @@ -38,8 +38,6 @@
import java.util.concurrent.atomic.AtomicBoolean;
import java.util.concurrent.atomic.AtomicIntegerFieldUpdater;
import java.util.concurrent.atomic.AtomicLongFieldUpdater;
import java.util.concurrent.locks.Lock;
import java.util.concurrent.locks.ReentrantLock;
import lombok.Getter;
import lombok.Setter;
import org.apache.pulsar.client.api.BatchReceivePolicy;
Expand Down Expand Up @@ -95,7 +93,6 @@ public abstract class ConsumerBase<T> extends HandlerState implements Consumer<T
.newUpdater(ConsumerBase.class, "incomingMessagesSize");
protected volatile long incomingMessagesSize = 0;
protected volatile Timeout batchReceiveTimeout = null;
protected final Lock reentrantLock = new ReentrantLock();

protected static final AtomicLongFieldUpdater<ConsumerBase> CONSUMER_EPOCH =
AtomicLongFieldUpdater.newUpdater(ConsumerBase.class, "consumerEpoch");
Expand Down Expand Up @@ -910,13 +907,7 @@ protected void notifyPendingBatchReceivedCallBack() {
if (opBatchReceive == null) {
return;
}

reentrantLock.lock();
try {
notifyPendingBatchReceivedCallBack(opBatchReceive.future);
} finally {
reentrantLock.unlock();
}
notifyPendingBatchReceivedCallBack(opBatchReceive.future);
}

private boolean hasNextBatchReceive() {
Expand Down

0 comments on commit ef25f87

Please sign in to comment.