• poll/select源码分析


    在linux中,很多东西都需要通过fd(file description)来操作,比如字符设备,文件和socket,而在kernel中,都会给fd关联一个结构体 struct file_operations,其提供了很多函数指针用来操作fd对象。
    对于poll和select实现来说,它可以poll等待fd的数据,就是因为fd的struct file_operations提供了poll函数指针的实现,比如对于socket来说,提供了sock_poll。

    1. static const struct file_operations socket_file_ops = {
    2. .owner = THIS_MODULE,
    3. ...
    4. .poll = sock_poll,
    5. ...
    6. };
    7. SYSCALL_DEFINE3(socket, int, family, int, type, int, protocol)
    8. sock_create(family, type, protocol, &sock);
    9. sock_map_fd(sock, flags & (O_CLOEXEC | O_NONBLOCK));
    10. int fd = get_unused_fd_flags(flags);
    11. newfile = sock_alloc_file(sock, flags, NULL);
    12. file = alloc_file(&path, FMODE_READ | FMODE_WRITE, &socket_file_ops);
    13. fd_install(fd, newfile);

    下面分析下poll和select的源码实现,至于怎么使用它们,网上可以搜到很多例子

    poll

    poll系统调用在kernel中的定义,源码在 linux/fs/select.c中

    1. SYSCALL_DEFINE3(poll, struct pollfd __user *, ufds, unsigned int, nfds, int, timeout_msecs)
    2. {
    3. struct timespec end_time, *to = NULL;
    4. int ret;
    5. //将参数timeout_msecs转换到结构struct timespec
    6. if (timeout_msecs >= 0) {
    7. to = &end_time;
    8. poll_select_set_timeout(to, timeout_msecs / MSEC_PER_SEC,
    9. NSEC_PER_MSEC * (timeout_msecs % MSEC_PER_SEC));
    10. }
    11. ret = do_sys_poll(ufds, nfds, to);

    1. int do_sys_poll(struct pollfd __user *ufds, unsigned int nfds, struct timespec *end_time)
    2. //参数nfds不能大于当前进程最大文件描述符个数限制
    3. if (nfds > rlimit(RLIMIT_NOFILE))
    4. return -EINVAL;
    5. //循环将用户侧ufds拷贝到内核态,使用poll_list连接起来
    6. struct poll_list {
    7. struct poll_list *next;
    8. int len;
    9. struct pollfd entries[0];
    10. };
    11. struct pollfd {
    12. int fd;
    13. short events;
    14. short revents;
    15. };
    16. //计算数组stack_pps能存储多少个struct pollfd
    17. #define N_STACK_PPS ((sizeof(stack_pps) - sizeof(struct poll_list)) / sizeof(struct pollfd))
    18. #define FRONTEND_STACK_ALLOC 256
    19. #define POLL_STACK_ALLOC FRONTEND_STACK_ALLOC
    20. //计算一个PAGE_SIZE能存储多少个struct pollfd
    21. #define POLLFD_PER_PAGE ((PAGE_SIZE-sizeof(struct poll_list)) / sizeof(struct pollfd))
    22. /* Allocate small arguments on the stack to save memory and
    23. be faster - use long to make sure the buffer is aligned properly
    24. on 64 bit archs to avoid unaligned access */
    25. //POLL_STACK_ALLOC为256,所以数组stack_pps四个元素
    26. long stack_pps[POLL_STACK_ALLOC/sizeof(long)];
    27. //指针head指向数组stack_pps起始地址
    28. struct poll_list *const head = (struct poll_list *)stack_pps;
    29. struct poll_list *walk = head;
    30. unsigned long todo = nfds;
    31. //len取最小值
    32. len = min_t(unsigned int, nfds, N_STACK_PPS);
    33. //这里的逻辑是,首先使用栈上的数组stack_pps存储pollfd,如
    34. //果nfds小于N_STACK_PPS,只用数组stack_pps就够用,但
    35. //是如果nfds很大,就需要额外动态分配内存来存储,并使用
    36. //poll_list连接起来。
    37. for (;;) {
    38. walk->next = NULL;
    39. walk->len = len;
    40. if (!len)
    41. break;
    42. if (copy_from_user(walk->entries, ufds + nfds-todo,
    43. sizeof(struct pollfd) * walk->len))
    44. goto out_fds;
    45. todo -= walk->len;
    46. if (!todo)
    47. break;
    48. len = min(todo, POLLFD_PER_PAGE);
    49. size = sizeof(struct poll_list) + sizeof(struct pollfd) * len;
    50. walk = walk->next = kmalloc(size, GFP_KERNEL);
    51. if (!walk) {
    52. err = -ENOMEM;
    53. goto out_fds;
    54. }
    55. }
    56. //初始化table结构体,参见下面的注释a
    57. struct poll_wqueues table;
    58. poll_initwait(&table);
    59. //循环调用监听文件的poll函数,参见下面的注释b
    60. //返回值fdcount表示发生事件的fd个数
    61. fdcount = do_poll(nfds, head, &table, end_time);
    62. //释放分配的内存,并将wait从目标文件的等待队列中删除。
    63. poll_freewait(&table);
    64. //将所有监听文件拷贝到用户程序,不管有没有事件发生
    65. for (walk = head; walk; walk = walk->next) {
    66. struct pollfd *fds = walk->entries;
    67. int j;
    68. for (j = 0; j < walk->len; j++, ufds++)
    69. if (__put_user(fds[j].revents, &ufds->revents))
    70. goto out_fds;
    71. }
    72. err = fdcount;
    73. return err;

    a. poll_initwait

    1. typedef struct poll_table_struct {
    2. poll_queue_proc _qproc;
    3. unsigned long _key;
    4. } poll_table;
    5. struct poll_wqueues {
    6. poll_table pt;
    7. struct poll_table_page *table;
    8. struct task_struct *polling_task;
    9. int triggered;
    10. int error;
    11. int inline_index;
    12. struct poll_table_entry inline_entries[N_INLINE_POLL_ENTRIES];
    13. };
    14. void poll_initwait(struct poll_wqueues *pwq)
    15. {
    16. //调用目标文件poll函数时,会调用_pollwait
    17. init_poll_funcptr(&pwq->pt, __pollwait);
    18. pt->_qproc = qproc;
    19. pt->_key = ~0UL; /* all events enabled */
    20. //将当前进程描述符赋值给polling_task,
    21. pwq->polling_task = current;
    22. pwq->triggered = 0;
    23. pwq->error = 0;
    24. pwq->table = NULL;
    25. pwq->inline_index = 0;
    26. }

    b. do_poll
    遍历所有fd,并调用fd提供的poll函数,如果有事件发生,即do_pollfd返回值非0,则将count加一,
    do_poll有三层循环,内两层循环遍历所有fd,如果遍历完所有fd,没有事件发生,即count为0,则在最外层循环启动定时器,调度到其他进程执行,直到事件发生或者超时到达。

    1. static int do_poll(unsigned int nfds, struct poll_list *list,
    2. struct poll_wqueues *wait, struct timespec *end_time)
    3. //如果超时时间为0,则将time_out置为1,则不管有没有事件发
    4. //生,不会进行堵塞等待,而是立即返回
    5. /* Optimise the no-wait case */
    6. if (end_time && !end_time->tv_sec && !end_time->tv_nsec) {
    7. pt->_qproc = NULL;
    8. timed_out = 1;
    9. }
    10. for {
    11. //walk是个链表,每个链表元素包含len个fd,下面的第一个
    12. //for循环遍历链表,第二个for循环遍历当前walk的所有fd
    13. //所以需要循环两次才能遍历完所有fd
    14. for (walk = list; walk != NULL; walk = walk->next) {
    15. struct pollfd * pfd, * pfd_end;
    16. pfd = walk->entries;
    17. pfd_end = pfd + walk->len;
    18. for (; pfd != pfd_end; pfd++) {
    19. //即使只有一个fd上有事件发生,也会把pt->_qproc置为空。
    20. //因为即使只有一个fd有事件发生,此次poll调用也需要将事件返回给用户程序,
    21. //调用目标文件poll函数就没必要将等待节点插入目标文件的等待队列,只需要获取
    22. //当前发生的事件即可。
    23. //do_pollfd返回值为正,说明此fd有事件发生
    24. if (do_pollfd(pfd, pt)) {
    25. count++;
    26. pt->_qproc = NULL;
    27. }
    28. }
    29. }
    30. pt->_qproc = NULL;
    31. if (!count) {
    32. count = wait->error;
    33. //没有事件发生,但是当前进程有其他信号
    34. if (signal_pending(current))
    35. count = -EINTR;
    36. //跳出最外层循环的条件有三个:
    37. //a. 有fd事件发生
    38. //b. 当前进程有其他信号
    39. //c. 超时时间到
    40. if (count || timed_out)
    41. break;
    42. //如果所有fd都没有事件发生,并且timeout大于0,则调度
    43. //到其他进程开始等待timeout超时。如果timeout小于0,则
    44. //无限期等待事件发生
    45. if (!poll_schedule_timeout(wait, TASK_INTERRUPTIBLE, to, slack)) {
    46. timed_out = 1;
    47. }
    48. }
    49. //返回值count
    50. //如果为0,说明超时时间到,并且没有fd有事件发生
    51. //如果为正数,则说明有countfd有事件发生
    52. //如果为负数,说明有信号发生
    53. return count;
    54. }

    do_pollfd中调用fd提供的poll函数,poll函数将已发生的事件赋给mask,再将mask赋给pllfd->revents, 后面会传递给用户侧,函数最后将mask返回上层调用

    1. /*
    2. * Fish for pollable events on the pollfd->fd file descriptor. We're only
    3. * interested in events matching the pollfd->events mask, and the result
    4. * matching that mask is both recorded in pollfd->revents and returned. The
    5. * pwait poll_table will be used by the fd-provided poll handler for waiting,
    6. * if pwait->_qproc is non-NULL.
    7. */
    8. static inline unsigned int do_pollfd(struct pollfd *pollfd, poll_table *pwait, bool *can_busy_poll,
    9. unsigned int busy_flag)
    10. {
    11. unsigned int mask;
    12. int fd;
    13. mask = 0;
    14. fd = pollfd->fd;
    15. if (fd >= 0) {
    16. struct fd f = fdget(fd);
    17. mask = POLLNVAL;
    18. if (f.file) {
    19. #define DEFAULT_POLLMASK (POLLIN | POLLOUT | POLLRDNORM | POLLWRNORM)
    20. mask = DEFAULT_POLLMASK;
    21. if (f.file->f_op->poll) {
    22. pwait->_key = pollfd->events|POLLERR|POLLHUP;
    23. pwait->_key |= busy_flag;
    24. //调用目标文件的poll函数
    25. mask = f.file->f_op->poll(f.file, pwait);
    26. if (mask & busy_flag)
    27. *can_busy_poll = true;
    28. }
    29. /* Mask out unneeded events. */
    30. mask &= pollfd->events | POLLERR | POLLHUP;
    31. fdput(f);
    32. }
    33. }
    34. pollfd->revents = mask;
    35. return mask;
    36. }

    比如uio模块的poll函数为uio_poll,此函数会调用poll_wait将等待队列添加到等待队列链表中。等待队列头存储在file的私有数据中。(在uio_open中建立file私有数据和listener的关系)

    1. static unsigned int uio_poll(struct file *filep, poll_table *wait)
    2. {
    3. struct uio_listener *listener = filep->private_data;
    4. struct uio_device *idev = listener->dev;
    5. if (!idev->info->irq)
    6. return -EIO;
    7. poll_wait(filep, &idev->wait, wait);
    8. //p->_qproc为__pollwait
    9. if (p && p->_qproc && wait_address)
    10. p->_qproc(filp, wait_address, p);
    11. if (listener->event_count != atomic_read(&idev->event))
    12. return POLLIN | POLLRDNORM;
    13. return 0;
    14. }
    15. /* Add a new entry */
    16. static void __pollwait(struct file *filp, wait_queue_head_t *wait_address, poll_table *p)
    17. {
    18. struct poll_wqueues *pwq = container_of(p, struct poll_wqueues, pt);
    19. struct poll_table_entry *entry = poll_get_entry(pwq);
    20. if (!entry)
    21. return;
    22. entry->filp = get_file(filp);
    23. entry->wait_address = wait_address;
    24. entry->key = p->_key;
    25. //目标文件有事件发生时,调用pollwake唤醒poll进程
    26. init_waitqueue_func_entry(&entry->wait, pollwake);
    27. q->flags = 0;
    28. q->private = NULL;
    29. q->func = func;
    30. entry->wait.private = pwq;
    31. add_wait_queue(wait_address, &entry->wait);
    32. unsigned long flags;
    33. wait->flags &= ~WQ_FLAG_EXCLUSIVE;
    34. spin_lock_irqsave(&q->lock, flags);
    35. __add_wait_queue(q, wait);
    36. spin_unlock_irqrestore(&q->lock, flags);
    37. }

    事件触发,唤醒进程
    当有中断发生时,调用uio_event_notify

    1. igbuio_pci_irqhandler 中调用 uio_event_notify
    2. void uio_event_notify(struct uio_info *info)
    3. {
    4. struct uio_device *idev = info->uio_dev;
    5. //将中断事件加1
    6. atomic_inc(&idev->event);
    7. //idev->wait是等待队列
    8. //调用等待队列上注册的函数pollwake
    9. wake_up_interruptible(&idev->wait);
    10. kill_fasync(&idev->async_queue, SIGIO, POLL_IN);
    11. }
    12. //nr_exclusive为1,则只唤醒一个进程
    13. #define wake_up_interruptible(x) __wake_up(x, TASK_INTERRUPTIBLE, 1, NULL)
    14. void __wake_up(wait_queue_head_t *q, unsigned int mode,
    15. int nr_exclusive, void *key)
    16. {
    17. unsigned long flags;
    18. spin_lock_irqsave(&q->lock, flags);
    19. __wake_up_common(q, mode, nr_exclusive, 0, key);
    20. spin_unlock_irqrestore(&q->lock, flags);
    21. }
    22. static void __wake_up_common(wait_queue_head_t *q, unsigned int mode, int nr_exclusive, int wake_flags, void *key)
    23. {
    24. wait_queue_t *curr, *next;
    25. //遍历链表q->task_list
    26. list_for_each_entry_safe(curr, next, &q->task_list, task_list) {
    27. unsigned flags = curr->flags;
    28. //调用pollwake唤醒poll进程,成功返回1
    29. if (curr->func(curr, mode, wake_flags, key) &&
    30. (flags & WQ_FLAG_EXCLUSIVE) && !--nr_exclusive)
    31. break;
    32. }
    33. }
    34. static int pollwake(wait_queue_t *wait, unsigned mode, int sync, void *key)
    35. {
    36. struct poll_table_entry *entry;
    37. entry = container_of(wait, struct poll_table_entry, wait);
    38. //keyNULL
    39. if (key && !((unsigned long)key & entry->key))
    40. return 0;
    41. return __pollwake(wait, mode, sync, key);
    42. }
    43. static int __pollwake(wait_queue_t *wait, unsigned mode, int sync, void *key)
    44. {
    45. //通过wait->private获取poll_wqueues,
    46. //poll_wqueues->polling_task中存放的是调用poll函数进程描述符
    47. struct poll_wqueues *pwq = wait->private;
    48. DECLARE_WAITQUEUE(dummy_wait, pwq->polling_task);
    49. //唤醒调用poll的进程
    50. return default_wake_function(&dummy_wait, mode, sync, key);
    51. }

    poll进程被唤醒后,将发生的事件返回给用户程序,用户程序就可以根据发生的事件调用read或者write读取/写入数据,以uio_read为例

    1. static ssize_t uio_read(struct file *filep, char __user *buf, size_t count, loff_t *ppos)
    2. {
    3. struct uio_listener *listener = filep->private_data;
    4. struct uio_device *idev = listener->dev;
    5. DECLARE_WAITQUEUE(wait, current);
    6. ssize_t retval;
    7. s32 event_count;
    8. if (!idev->info->irq)
    9. return -EIO;
    10. if (count != sizeof(s32))
    11. return -EINVAL;
    12. add_wait_queue(&idev->wait, &wait);
    13. do {
    14. set_current_state(TASK_INTERRUPTIBLE);
    15. //idev->event为实时发生的中断计数
    16. //listener->event_count为上次中断计数
    17. //如果这俩值不相等说明有新中断发生
    18. //因为这次read是通过poll获取有事件发生后执行的,
    19. //所以肯定会走这个流程.
    20. event_count = atomic_read(&idev->event);
    21. if (event_count != listener->event_count) {
    22. //将发生中断事件变量拷贝到用户侧变量
    23. //同时返回值也为
    24. if (copy_to_user(buf, &event_count, count))
    25. retval = -EFAULT;
    26. else {
    27. listener->event_count = event_count;
    28. retval = count;
    29. }
    30. break;
    31. }
    32. //没有中断事件发生,则如果是堵塞read,则开始堵塞,
    33. //如果为非堵塞read,则返回EAGAIN
    34. if (filep->f_flags & O_NONBLOCK) {
    35. retval = -EAGAIN;
    36. break;
    37. }
    38. if (signal_pending(current)) {
    39. retval = -ERESTARTSYS;
    40. break;
    41. }
    42. schedule();
    43. } while (1);
    44. __set_current_state(TASK_RUNNING);
    45. remove_wait_queue(&idev->wait, &wait);
    46. return retval;
    47. }

    select

    select只能监听1024个文件描述符的原因?
    在用户侧代码中,会将需要监听的fd放入结构体fd_set中,其在kernel中定义如下。数组fds_bits的每一位代表一个文件描述符,而数组fds_bits由宏__FD_SETSIZE 得到,此宏定义就是1024,所以如果想支持更多文件描述符,需要重新编译内核将此宏改大。

    1. #undef __FD_SETSIZE
    2. #define __FD_SETSIZE 1024
    3. typedef struct {
    4. unsigned long fds_bits[__FD_SETSIZE / (8 * sizeof(long))];
    5. } __kernel_fd_set;
    6. typedef __kernel_fd_set fd_set;

    select系统调用在kernel中的定义

    1. SYSCALL_DEFINE5(select, int, n, fd_set __user *, inp, fd_set __user *, outp, fd_set __user *, exp, struct timeval __user *, tvp)
    2. core_sys_select(n, inp, outp, exp, to);
    3. }
    4. int core_sys_select(int n, fd_set __user *inp, fd_set __user *outp,
    5. fd_set __user *exp, struct timespec *end_time)
    6. {
    7. /* max_fds can increase, so grab it once to avoid race */
    8. rcu_read_lock();
    9. fdt = files_fdtable(current->files);
    10. max_fds = fdt->max_fds;
    11. rcu_read_unlock();
    12. //如果超出了当前进程已打开的最大文件描述符,则只使用最大描述符个数
    13. if (n > max_fds)
    14. n = max_fds;
    15. #define FDS_BITPERLONG (8*sizeof(long))
    16. #define FDS_LONGS(nr) (((nr)+FDS_BITPERLONG- 1)/FDS_BITPERLONG)
    17. #define FDS_BYTES(nr) (FDS_LONGS(nr)*sizeof(long))
    18. //size表示n个文件描述符占用多少字节
    19. size = FDS_BYTES(n);
    20. #define FRONTEND_STACK_ALLOC 256
    21. #define SELECT_STACK_ALLOC FRONTEND_STACK_ALLOC
    22. /* Allocate small arguments on the stack to save memory and be faster */
    23. long stack_fds[SELECT_STACK_ALLOC/sizeof(long)];
    24. void *bits;
    25. bits = stack_fds;
    26. //如果stack_fds大小不够用,则直接使用kmalloc分配内存
    27. if (size > sizeof(stack_fds) / 6) {
    28. bits = kmalloc(6 * size, GFP_KERNEL);
    29. }
    30. //fds.in指向bits内存首地址,占用size个字节,存放对in事件感兴趣的fd
    31. //fds.out指向bits+size的内存地址,占用size个字节,存放对out事件感兴趣的fd
    32. //fds.ex,res_in依次类推
    33. fds.in = bits;
    34. fds.out = bits + size;
    35. fds.ex = bits + 2*size;
    36. fds.res_in = bits + 3*size;
    37. fds.res_out = bits + 4*size;
    38. fds.res_ex = bits + 5*size;
    39. //in, out, exp文件描述符分别拷贝到fds.in, out, ex中
    40. if ((ret = get_fd_set(n, inp, fds.in)) ||
    41. (ret = get_fd_set(n, outp, fds.out)) ||
    42. (ret = get_fd_set(n, exp, fds.ex)))
    43. goto out;
    44. //将fds.res_in,out和ex清零,用于存放发生事件的fd
    45. zero_fd_set(n, fds.res_in);
    46. zero_fd_set(n, fds.res_out);
    47. zero_fd_set(n, fds.res_ex);
    48. //核心函数
    49. ret = do_select(n, &fds, end_time);
    50. //将结果拷贝到用户侧变量
    51. if (set_fd_set(n, inp, fds.res_in) ||
    52. set_fd_set(n, outp, fds.res_out) ||
    53. set_fd_set(n, exp, fds.res_ex))
    54. ret = -EFAULT;
    55. }
    56. int do_select(int n, fd_set_bits *fds, struct timespec *end_time)
    57. retval = max_select_fd(n, fds);
    58. poll_initwait(&table);
    59. wait = &table.pt;
    60. //如果没有超时时间为0,则time_out设置为1,不管是否有事件发生都会返回
    61. if (end_time && !end_time->tv_sec && !end_time->tv_nsec) {
    62. wait->_qproc = NULL;
    63. timed_out = 1;
    64. }
    65. //后面的逻辑和poll中的类似,遍历所有fd,调用fd中的poll函数,
    66. //在poll函数中将当前进程加入到等待队列。
    67. //如果有事件发生则返回发生事件的个数,
    68. //如果没有事件发生,并且time_out为1,则返回0.
    69. //如果没有事件发生,并且time_out为0,则调度执行其他进程,
    70. //等待事件发生或者等待超时后返回。

    缺点:

    1.每次调用 select(),都需要把 fd 集合从用户态拷贝到内核态,这个开销在 fd 很多时会很大,同时每次调用 select() 都需要在内核遍历传递进来的所有 fd,这个开销在 fd 很多时也很大。
    2.单个进程能够监视的文件描述符的数量存在最大限制,在 Linux 上一般为 1024,可以通过修改宏定义甚至重新编译内核的方式提升这一限制,但是这样也会造成效率的降低。

    1. select每次调用都会线性扫描全部的集合,导致效率呈现线性下降。
    2. 每次调用select都会调用poll_initwait将调用进程添加到目标文件等待队列中,select函数返回时调用poll_freewait从等待队列删除。

    select() 和 poll() 系统调用的本质一样,poll() 的机制与 select() 类似,与 select() 在本质上没有多大差别,管理多个描述符也是进行轮询,根据描述符的状态进行处理,但是 poll() 没有最大文件描述符数量的限制(但是数量过大后性能也是会下降)。
    poll() 和 select() 同样存在一个缺点就是,包含大量文件描述符的数组被整体复制于用户态和内核的地址空间之间,而不论这些文件描述符是否就绪,它的开销随着文件描述符数量的增加而线性增大。

    也可参考:https://www.jianshu.com/p/2332b777f84f 

  • 相关阅读:
    Unity使用Remote直接在手机上调试游戏
    Spring学习_day10
    Android开发进阶:Android Framework原理上手与掌控
    [附源码]SSM计算机毕业设计学生宿舍设备报修JAVA
    帆软报表函数
    idea常用配置 | 快捷注释
    Python基础知识从hello world 开始(第一天)
    云防火墙和传统防火墙区别是什么
    后勤事务繁杂低效?三步骤解决企业行政管理难题
    【IEEE会议】 第三届智能通信与计算国际学术会议(ICC 2023)
  • 原文地址:https://blog.csdn.net/fengcai_ke/article/details/126563983