一行代码引发的"血案"

昨天在使用pykafka的时候又遇到了之前我遇到过的PartitionOwnedError、ConsumerStoppedException异常,关于这个异常我之前写过一篇分析的文章(链接在这里),我自认为之前应该是把这个问题彻底解决了的,但是这次它又幽灵般的出现了,使我百思不得其解。
一、问题的出现
我在多台机器上面同时开启了多个进程来读写同一个topic,这个topic有5个partition,我想着开启5个进程来读写,这样可以提高速度。在测试过程中我发现会出现PartitionOwnedError、ConsumerStoppedException异常,这个问题之前我记得我通过参数rebalance_max_retries、rebalance_backoff_ms已经解决过了,而且我确保代码中这两个参数都没有变化过。在日志中我也发现进程确实是会重试rebalance_max_retries以后才会报出异常,下面是我摘取的部分日志:

[pykafka.balancedconsumer] [balancedconsumer.py:580] INFO: Unable to acquire partition <pykafka.partition.Partition at 0x7f9a0a5586d0 (id=4)>. Retrying
[pykafka.balancedconsumer] [balancedconsumer.py:580] INFO: Unable to acquire partition <pykafka.partition.Partition at 0x7f3320806710 (id=3)>. Retrying

但是经过rebalance_max_retries的重试以后就会抛出PartitionOwnedError异常,也就是说我这个consumer没有获取到分配给我的partition。
二、问题的排查
PartitionOwnedError异常抛出的原理性解释大家可以参考前面的文章,不再赘述。
此时我想到肯定是其它的原因导致的这个问题,但是我明明记得我对操作pykafka的代码没有做过什么改动啊,唯一的改动就是把consumer_timeout_ms这个参数改成了-1(读取永不超时),难道是这个原因导致的吗?但是我明明在之前也测试过多次啊,之前都没有发现这个问题啊,这个就让我很不理解了。
为了验证我的猜测,我还是把consumer_timeout_ms改成了5000(5s),然后问题就没有再出现了,也就是说确实是这一行代码导致的问题,但是这个还不能完全解答我另外的一个疑惑,就是为什么我之前的多次测试没有发现这个问题,偏偏是这次测试的时候出现了。
没办法,只能又开始由源码开刀了。
三、问题的真正原因
因为之前对pykafka的代码有过一些了解,所以这次读起来就相对比较简单了,我理解每次当zookeeper上面的znode状态发生变化,kafka都会执行相应的rebalance,如下的代码就是实现这个功能:

    def _set_watches(self):
        """Set watches in zookeeper that will trigger rebalances.

        Rebalances should be triggered whenever a broker, topic, or consumer
        znode is changed in zookeeper. This ensures that the balance of the
        consumer group remains up-to-date with the current state of the
        cluster.
        """
        proxy = weakref.proxy(self)
        _brokers_changed = self._build_watch_callback(BalancedConsumer._brokers_changed, proxy)
        _topics_changed = self._build_watch_callback(BalancedConsumer._topics_changed, proxy)
        _consumers_changed = self._build_watch_callback(BalancedConsumer._consumers_changed, proxy)

        self._setting_watches = True
        # Set all our watches and then rebalance
        broker_path = '/brokers/ids'
        try:
            self._broker_watcher = ChildrenWatch(
                self._zookeeper, broker_path,
                _brokers_changed
            )   
        except NoNodeException:
            raise Exception(
                'The broker_path "%s" does not exist in your '
                'ZooKeeper cluster -- is your Kafka cluster running?'
                % broker_path)

        self._topics_watcher = ChildrenWatch(
            self._zookeeper,
            '/brokers/topics',
            _topics_changed
        )   

        self._consumer_watcher = ChildrenWatch(
            self._zookeeper, self._consumer_id_path,
            _consumers_changed
        )   
        self._setting_watches = False

代码逻辑比较简单,就是设置三个watcher函数,一旦对应的znode状态发生变化就执行相应的callback,这个也是为什么当一个consumer加入以后会分配到partition的原因,当我们新增加一个consumer的时候就会触发_consumers_changed这个函数,这个函数的逻辑也很简单:

    @_catch_thread_exception
    def _consumers_changed(self, consumers):                                                                                                             
        if not self._running:
            return False  # `False` tells ChildrenWatch to disable this watch
        if self._setting_watches:
            return
        log.debug("Rebalance triggered by consumer change ({})".format(
            self._consumer_id))
        self._rebalance()

就是执行_rebalance()函数,也就是触发了kafka的rebalance过程。
代码读到这里的时候我们能够发现很有可能就是之前开启的consumer进程没有执行rebalance过程,导致后面新加入的consumer进程一直获取不到partition,接着我们到_rebalance()函数一看究竟:


    def _rebalance(self):                                                                                                                                
        """Start the rebalancing process for this consumer

        This method is called whenever a zookeeper watch is triggered.
        """
        if self._consumer is not None:
            self.commit_offsets()
        # this is necessary because we can't stop() while the lock is held
        # (it's not an RLock)
        with self._rebalancing_lock:
            if not self._running:
                raise ConsumerStoppedException
            log.info('Rebalancing consumer "%s" for topic "%s".' % (
                self._consumer_id, self._topic.name))
            self._update_member_assignment()

函数逻辑也比较简单,之前的文章其实也分析过这个调用过程,真正的rebalance是在_update_member_assignment()函数中执行的,但是在这个函数之前有一行with self._rebalancing_lock,也就是执行rebalance之前要获得_rebalancing_lock锁,此时我能确认就是这个锁没有获取到导致的问题,也就是说其它地方把这个锁一直acquire了,没有释放,那么接下来就看看还有其它哪些函数会用到这个锁呢。
grep一遍源码你马上就会发现consume()函数会用到这个锁,代码如下:

    def consume(self, block=True):
        """Get one message from the consumer

        :param block: Whether to block while waiting for a message
        :type block: bool
        """

        def consumer_timed_out():
            """Indicates whether the consumer has received messages recently"""
            if self._consumer_timeout_ms == -1:
                return False
            disp = (time.time() - self._last_message_time) * 1000.0
            return disp > self._consumer_timeout_ms
        message = None
        self._last_message_time = time.time()
        while message is None and not consumer_timed_out():
            self._raise_worker_exceptions()
            try:
                # acquire the lock to ensure that we don't start trying to consume from
                # a _consumer that might soon be replaced by an in-progress rebalance
                with self._rebalancing_lock:                                                                                                             
                    message = self._consumer.consume(block=block)
            except (ConsumerStoppedException, AttributeError):
                if not self._running:
                    raise ConsumerStoppedException
                continue
            if message:
                self._last_message_time = time.time()
            if not block:
                return message
        return message

函数里面定义了一个超时函数consumer_timed_out()之前我代码是把_consumer_timeout_ms设置成了-1,那么这个函数就会返回False,此时就会进入while循环中获取到了_rebalancing_lock锁,接着就开始消费队列,self._consumer本质是一个SimpleConsumerorRdKafkaSimpleConsumer(如果设置了use_rdkafka参数),我们在BalanceConsumer构造函数中传入的consumer_timeout_ms也会传给对应的SimpleConsumer,所以如果我们设置的是-1(永不超时)那么这代码就会一直不返回,除非有消费到数据。
到这一步就基本解释了前面的疑惑,如果设置consumer_timeout_ms = -1那么consume()就会一直占有_rebalancing_lock锁,当新的consumer加入的时候之前的consumer本来应该执行rebalance操作的,但是又因为_rebalancing_lock锁一直没有获取到,所以就一直阻塞在那里,等到新加入的consumer重试了rebalance_max_retries次以后就会因为获取不到partition而抛出PartitionOwnedError异常。
这里也解释了为什么我之前没法遇到这个问题,因为我之前的队列一直都有数据,所以consume()每次都能及时的返回然后释放_rebalancing_lock锁。
四、如何解决问题
找到原因要解决就好办了,最简单的方式就是把consumer_timeout_ms设置成一个非-1的值,如我之前设置的5000ms。
但是我觉得这应该算是pykafka的一个bug,我已经在github提了一个issue。

  • 2
    点赞
  • 1
    收藏
    觉得还不错? 一键收藏
  • 0
    评论

“相关推荐”对你有帮助么?

  • 非常没帮助
  • 没帮助
  • 一般
  • 有帮助
  • 非常有帮助
提交
评论
添加红包

请填写红包祝福语或标题

红包个数最小为10个

红包金额最低5元

当前余额3.43前往充值 >
需支付:10.00
成就一亿技术人!
领取后你会自动成为博主和红包主的粉丝 规则
hope_wisdom
发出的红包
实付
使用余额支付
点击重新获取
扫码支付
钱包余额 0

抵扣说明:

1.余额是钱包充值的虚拟货币,按照1:1的比例进行支付金额的抵扣。
2.余额无法直接购买下载,可以购买VIP、付费专栏及课程。

余额充值