ip_vs实现分析(2)

本文档的Copyleft归yfydz所有,使用GPL发布,可以自由拷贝,转载,转载时请保持文档的完整性,严禁用于任何商业用途。
msn: yfydz_no1@hotmail.com
来源:http://yfydz.cublog.cn


4. 模块初始化

初始化函数先初始化ipvs的各种处理机制,然后将ipvs的处理函数挂接到netfilter架构中。

/* net/ipv4/ipvs/ip_vs_core.c */
static int __init ip_vs_init(void)
{
 int ret;
// ioctl初始化
 ret = ip_vs_control_init();
 if (ret < 0) {
  IP_VS_ERR("can't setup control.\n");
  goto cleanup_nothing;
 }
// 协议初始化
 ip_vs_protocol_init();
// 应用层辅助协议初始化
 ret = ip_vs_app_init();
 if (ret < 0) {
  IP_VS_ERR("can't setup application helper.\n");
  goto cleanup_protocol;
 }
// ipvs连接初始化
 ret = ip_vs_conn_init();
 if (ret < 0) {
  IP_VS_ERR("can't setup connection table.\n");
  goto cleanup_app;
 }
// 下面分别挂接各个处理点到netfilter架构中
 ret = nf_register_hook(&ip_vs_in_ops);
 if (ret < 0) {
  IP_VS_ERR("can't register in hook.\n");
  goto cleanup_conn;
 }
ret = nf_register_hook(&ip_vs_out_ops);
 if (ret < 0) {
  IP_VS_ERR("can't register out hook.\n");
  goto cleanup_inops;
 }
 ret = nf_register_hook(&ip_vs_post_routing_ops);
 if (ret < 0) {
  IP_VS_ERR("can't register post_routing hook.\n");
  goto cleanup_outops;
 }
 ret = nf_register_hook(&ip_vs_forward_icmp_ops);
 if (ret < 0) {
  IP_VS_ERR("can't register forward_icmp hook.\n");
  goto cleanup_postroutingops;
 }
IP_VS_INFO("ipvs loaded.\n");
 return ret;
// 以下是如果初始化出现失败时依次进行释放
  cleanup_postroutingops:
 nf_unregister_hook(&ip_vs_post_routing_ops);
  cleanup_outops:
 nf_unregister_hook(&ip_vs_out_ops);
  cleanup_inops:
 nf_unregister_hook(&ip_vs_in_ops);
  cleanup_conn:
 ip_vs_conn_cleanup();
  cleanup_app:
 ip_vs_app_cleanup();
  cleanup_protocol:
 ip_vs_protocol_cleanup();
 ip_vs_control_cleanup();
  cleanup_nothing:
 return ret;
}

4.1 ip_vs_control_init
/* net/ipv4/ipvs/ip_vs_ctl.c */
int ip_vs_control_init(void)
{
 int ret;
 int idx;
EnterFunction(2);
// 登记ipvs的sockopt控制,这样用户空间可通过setsockopt函数来和ipvs进行通信
 ret = nf_register_sockopt(&ip_vs_sockopts);
 if (ret) {
  IP_VS_ERR("cannot register sockopt.\n");
  return ret;
 }
// 建立/proc/net/ip_vs和/proc/net/ip_vs_stats只读项
 proc_net_fops_create("ip_vs", 0, &ip_vs_info_fops);
 proc_net_fops_create("ip_vs_stats",0, &ip_vs_stats_fops);
// 建立/proc/sys/net/ipv4/vs目录下的各可读写控制参数
 sysctl_header = register_sysctl_table(vs_root_table, 0);
// 初始化各种双向链表
// svc_table是根据协议地址端口等信息进行服务结构struct ip_vs_service查找的HASH表
// svc_fwm_table是根据数据包的nfmark信息进行服务结构struct ip_vs_service查找的HASH表
 /* Initialize ip_vs_svc_table, ip_vs_svc_fwm_table, ip_vs_rtable */
 for(idx = 0; idx < IP_VS_SVC_TAB_SIZE; idx++)  {
  INIT_LIST_HEAD(&ip_vs_svc_table[idx]);
  INIT_LIST_HEAD(&ip_vs_svc_fwm_table[idx]);
 }
// rtable是目的结构struct ip_vs_dest的HASH链表
 for(idx = 0; idx < IP_VS_RTAB_SIZE; idx++)  {
  INIT_LIST_HEAD(&ip_vs_rtable[idx]);
 }
// ipvs统计信息
 memset(&ip_vs_stats, 0, sizeof(ip_vs_stats));
// 统计锁
 spin_lock_init(&ip_vs_stats.lock);
// 对当前统计信息建立一个预估器,可用于计算服务器的性能参数
 ip_vs_new_estimator(&ip_vs_stats);
/* Hook the defense timer */
// 挂一个定时操作,根据系统当前负载情况定时调整系统参数
 schedule_delayed_work(&defense_work, DEFENSE_TIMER_PERIOD);
LeaveFunction(2);
 return 0;
}

4.2 ip_vs_protocol_init

/* net/ipv4/ipvs/ip_vs_proto.c */
int ip_vs_protocol_init(void)
{
// 挂接ipvs能进行均衡处理的各种协议,目前支持TCP/UDP/AH/ESP
// 最好还要增加GRE,在PPTP服务器中使用
 char protocols[64];
#define REGISTER_PROTOCOL(p)   \
 do {     \
  register_ip_vs_protocol(p); \
  strcat(protocols, ", "); \
  strcat(protocols, (p)->name); \
 } while (0)
// 0,1字符是给", "预留的
 protocols[0] = '\0';
 protocols[2] = '\0';
// 登记各种协议
#ifdef CONFIG_IP_VS_PROTO_TCP
 REGISTER_PROTOCOL(&ip_vs_protocol_tcp);
#endif
#ifdef CONFIG_IP_VS_PROTO_UDP
 REGISTER_PROTOCOL(&ip_vs_protocol_udp);
#endif
#ifdef CONFIG_IP_VS_PROTO_AH
 REGISTER_PROTOCOL(&ip_vs_protocol_ah);
#endif
#ifdef CONFIG_IP_VS_PROTO_ESP
 REGISTER_PROTOCOL(&ip_vs_protocol_esp);
#endif
// 第0,1字符分别为逗号','和空格' ',从第2字符起才是真正数据串
 IP_VS_INFO("Registered protocols (%s)\n", &protocols[2]);
return 0;
}
register_ip_vs_protocol()函数就是把ip_vs_protocol结构挂接到协议HASH表中,不过其实没几个协议,没必要用HASH,直接数组就行了,Linux内核中缺省好象也只支持32种IP协议。
/*
 * register an ipvs protocol
 */
static int register_ip_vs_protocol(struct ip_vs_protocol *pp)
{
 unsigned hash = IP_VS_PROTO_HASH(pp->protocol);
// 把新协议节点挂接到HASH链表头
 pp->next = ip_vs_proto_table[hash];
 ip_vs_proto_table[hash] = pp;
// 调用该协议的初始化函数
 if (pp->init != NULL)
  pp->init(pp);
return 0;
}

4.3 ip_vs_app_init
IPVS应用初始化
/* net/ipv4/ipvs/ip_vs_app.c */
int ip_vs_app_init(void)
{
 /* we will replace it with proc_net_ipvs_create() soon */
// 该函数就是建立一个/proc/net/ip_vs_app项
 proc_net_fops_create("ip_vs_app", 0, &ip_vs_app_fops);
 return 0;
}

4.4 ip_vs_conn_init
IPVS连接初始化
/* net/ipv4/ipvs/ip_vs_conn.c */
int ip_vs_conn_init(void)
{
 int idx;
/*
  * Allocate the connection hash table and initialize its list heads
  */
// ipvs连接HASH表
 ip_vs_conn_tab = vmalloc(IP_VS_CONN_TAB_SIZE*sizeof(struct list_head));
 if (!ip_vs_conn_tab)
  return -ENOMEM;
/* Allocate ip_vs_conn slab cache */
// ipvs连接cache,由于使用cache在内存块释放时并不真正释放,而是cache起来,
// 因此重新分配时速度更快
 ip_vs_conn_cachep = kmem_cache_create("ip_vs_conn",
           sizeof(struct ip_vs_conn), 0,
           SLAB_HWCACHE_ALIGN, NULL, NULL);
 if (!ip_vs_conn_cachep) {
  vfree(ip_vs_conn_tab);
  return -ENOMEM;
 }
IP_VS_INFO("Connection hash table configured "
     "(size=%d, memory=%ldKbytes)\n",
     IP_VS_CONN_TAB_SIZE,
     (long)(IP_VS_CONN_TAB_SIZE*sizeof(struct list_head))/1024);
 IP_VS_DBG(0, "Each connection entry needs %Zd bytes at least\n",
    sizeof(struct ip_vs_conn));
// 初始化各HASH链表头
 for (idx = 0; idx < IP_VS_CONN_TAB_SIZE; idx++) {
  INIT_LIST_HEAD(&ip_vs_conn_tab[idx]);
 }
// 初始化各读写锁
 for (idx = 0; idx < CT_LOCKARRAY_SIZE; idx++)  {
  rwlock_init(&__ip_vs_conntbl_lock_array[idx].l);
 }
// 建立/proc/net/ip_vs_conn项
 proc_net_fops_create("ip_vs_conn", 0, &ip_vs_conn_fops);
/* calculate the random value for connection hash */
// 初始随机数
 get_random_bytes(&ip_vs_conn_rnd, sizeof(ip_vs_conn_rnd));
return 0;
}

4.5 netfilter挂接点

nf_hook_ops分别在FORWARD点挂2个, INPUT点和POST_ROUTING点各挂一个

/* net/ipv4/ipvs/ip_vs_core.c */
4.5.1 ip_vs_in_ops

/* After packet filtering, forward packet through VS/DR, VS/TUN,
   or VS/NAT(change destination), so that filtering rules can be
   applied to IPVS. */
static struct nf_hook_ops ip_vs_in_ops = {
 .hook  = ip_vs_in,
 .owner  = THIS_MODULE,
 .pf  = PF_INET,
// INPUT点
 .hooknum        = NF_IP_LOCAL_IN,
// 此优先级低于filter
 .priority       = 100,
};

ip_vs_in()这个函数对进入本机的包进行处理.
/* net/ipv4/ipvs/ip_vs_core.c */
/*
 * Check if it's for virtual services, look it up,
 * and send it on its way...
 */
static unsigned int
ip_vs_in(unsigned int hooknum, struct sk_buff **pskb,
  const struct net_device *in, const struct net_device *out,
  int (*okfn)(struct sk_buff *))
{
 struct sk_buff *skb = *pskb;
 struct iphdr *iph;
 struct ip_vs_protocol *pp;
 struct ip_vs_conn *cp;
 int ret, restart;
 int ihl;
/*
  * Big tappo: only PACKET_HOST (neither loopback nor mcasts)
  * ... don't know why 1st test DOES NOT include 2nd (?)
  */
 if (unlikely(skb->pkt_type != PACKET_HOST
       || skb->dev == &loopback_dev || skb->sk)) {
// input不处理目的非本机的包
  IP_VS_DBG(12, "packet type=%d proto=%d daddr=%d.%d.%d.%d ignored\n",
     skb->pkt_type,
     skb->nh.iph->protocol,
     NIPQUAD(skb->nh.iph->daddr));
  return NF_ACCEPT;
 }
iph = skb->nh.iph;
 if (unlikely(iph->protocol == IPPROTO_ICMP)) {
// 如果是ICMP,可能是指示连接错误的ICMP信息,调用ip_vs_in_icmp进行检查
// 是否是相关的ICMP信息
  int related, verdict = ip_vs_in_icmp(pskb, &related, hooknum);
if (related)
   return verdict;
// 非相关ICMP,恢复处理流程
// 但其实ipvs是不均衡ICMP信息的,后面就返回了
  skb = *pskb;
  iph = skb->nh.iph;
 }
/* Protocol supported? */
// 获取协议支持模块,由于只支持TCP、UDP、AH和ESP,如果是ICMP,返回为NULL
 pp = ip_vs_proto_get(iph->protocol);
 if (unlikely(!pp))
  return NF_ACCEPT;
ihl = iph->ihl << 2;
/*
  * Check if the packet belongs to an existing connection entry
  */
// 找到和该skb相关的ipvs连接,类似netfilter的根据tuple查找连接,
// 不过sk_buff结构中没有增加nfct那样能直接指向连接的成员
// 对TCP协议来说是tcp_conn_in_get()
 cp = pp->conn_in_get(skb, pp, iph, ihl, 0);
if (unlikely(!cp)) {
  int v;
// 如果没有连接, 表明是新连接, 调用IPVS连接的conn_schedule调度连接分配和处理
// 连接调度要根据调度算法选择一个真实目的服务器,然后建立新的IPVS连接
// 对TCP协议来说是tcp_conn_schedule()
  if (!pp->conn_schedule(skb, pp, &v, &cp))
   return v;
 }
if (unlikely(!cp)) {
// 这种情况主要是没内存空间了,IPVS没提供主动删除连接的机制
  /* sorry, all this trouble for a no-hit :) */
  IP_VS_DBG_PKT(12, pp, skb, 0,
         "packet continues traversal as normal");
  return NF_ACCEPT;
 }
IP_VS_DBG_PKT(11, pp, skb, 0, "Incoming packet");
/* Check the server status */
 if (cp->dest && !(cp->dest->flags & IP_VS_DEST_F_AVAILABLE)) {
  /* the destination server is not available */
// 对于目的服务器失效的包丢弃
  if (sysctl_ip_vs_expire_nodest_conn) {
   /* try to expire the connection immediately */
   ip_vs_conn_expire_now(cp);
  }
  /* don't restart its timer, and silently
     drop the packet. */
  __ip_vs_conn_put(cp);
  return NF_DROP;
 }
// 连接信息统计
 ip_vs_in_stats(cp, skb);
// 进行连接状态的迁移, restart这个参数其实没用
// 对TCP协议来说是调用tcp_state_transition
 restart = ip_vs_set_state(cp, IP_VS_DIR_INPUT, skb, pp);
if (cp->packet_xmit)
// 将包发送出去, 具体xmit的实现在ip_vs_xmit.c中实现,
// NAT模式下为 ip_vs_nat_xmit;
// 通道模式下为 ip_vs_tunnel_xmit;
// 直接路由模式下为:  ip_vs_dr_xmit;
// 本机数据为: ip_vs_null_xmit;
// 旁路模式下为: ip_vs_bypass_xmit;
// 函数成功时基本都返回NF_STOLEN使netfilter不再处理该包
// 所以对于NAT模式,应该是不需要配置DNAT规则的,请求方向数据也不经过FORWARD链
  ret = cp->packet_xmit(skb, cp, pp);
  /* do not touch skb anymore */
 else {
  IP_VS_DBG_RL("warning: packet_xmit is null");
  ret = NF_ACCEPT;
 }
/* increase its packet counter and check if it is needed
    to be synchronized */
 atomic_inc(&cp->in_pkts);
// 在进行均衡器热备时将连接信息要从MASTER传递到SLAVE,使系统切换时
// 连接不丢弃,但还是要有一定条件才进行同步
 if ((ip_vs_sync_state & IP_VS_STATE_MASTER) &&
// 同步状态类型为主机
     (cp->protocol != IPPROTO_TCP ||
      cp->state == IP_VS_TCP_S_ESTABLISHED) &&
// 非TCP连接或是已经建立的连接
     (atomic_read(&cp->in_pkts) % sysctl_ip_vs_sync_threshold[1]
      == sysctl_ip_vs_sync_threshold[0]))
// 当前连接的包数为N*thres[1]+thres[0]时
// 进行连接的同步
  ip_vs_sync_conn(cp);
// 调整连接超时,释放连接计数
 ip_vs_conn_put(cp);
 return ret;
}

4.5.2 ip_vs_out_ops

/* After packet filtering, change source only for VS/NAT */
static struct nf_hook_ops ip_vs_out_ops = {
 .hook  = ip_vs_out,
 .owner  = THIS_MODULE,
 .pf  = PF_INET,
// FORWARD点
 .hooknum        = NF_IP_FORWARD,
// 此优先级低于filter
 .priority       = 100,
};
ip_vs_out()这个函数对转发包进行处理, 只用在NAT模式的均衡处理,TUNNEL和DR方式下都是直接发送了,实际处理的只是服务器返回的回应包,而客户端请求的包是不经过这里的,但如果设置了DNAT规则,数据包在PREROUTING点进行了目的地址修改,这样就不会再进入INPUT点而是直接转到FORWARD点处理,这时时针对该包的IPVS连接是没有建立的。

/* net/ipv4/ipvs/ip_vs_core.c */
/*
 * It is hooked at the NF_IP_FORWARD chain, used only for VS/NAT.
 * Check if outgoing packet belongs to the established ip_vs_conn,
 *      rewrite addresses of the packet and send it on its way...
 */
static unsigned int
ip_vs_out(unsigned int hooknum, struct sk_buff **pskb,
   const struct net_device *in, const struct net_device *out,
   int (*okfn)(struct sk_buff *))
{
 struct sk_buff  *skb = *pskb;
 struct iphdr *iph;
 struct ip_vs_protocol *pp;
 struct ip_vs_conn *cp;
 int ihl;
EnterFunction(11);
// 这个标志只占一位
// 标志设上就是已经经过IPVS处理了,直接返回
 if (skb->ipvs_property)
  return NF_ACCEPT;
iph = skb->nh.iph;
 if (unlikely(iph->protocol == IPPROTO_ICMP)) {
// 处理可能的连接相关ICMP错误信息,如地址端口不可达等
  int related, verdict = ip_vs_out_icmp(pskb, &related);
if (related)
   return verdict;
  skb = *pskb;
  iph = skb->nh.iph;
 }
// 取得IPVS协议, tcp/udp/ah/esp之一
 pp = ip_vs_proto_get(iph->protocol);
 if (unlikely(!pp))
  return NF_ACCEPT;
/* reassemble IP fragments */
 if (unlikely(iph->frag_off & __constant_htons(IP_MF|IP_OFFSET) &&
       !pp->dont_defrag)) {
// 如果是碎片包进行重组,基本不可能,因为数据包进入netfilter时就要进行碎片重组
  skb = ip_vs_gather_frags(skb, IP_DEFRAG_VS_OUT);
  if (!skb)
   return NF_STOLEN;
  iph = skb->nh.iph;
  *pskb = skb;
 }
ihl = iph->ihl << 2;
/*
  * Check if the packet belongs to an existing entry
  */
// 查找IPVS连接
 cp = pp->conn_out_get(skb, pp, iph, ihl, 0);
if (unlikely(!cp)) {
// 没找到IPVS连接,可能是请求方向的包经过DNAT过来的
  if (sysctl_ip_vs_nat_icmp_send &&
      (pp->protocol == IPPROTO_TCP ||
       pp->protocol == IPPROTO_UDP)) {
   __u16 _ports[2], *pptr;
pptr = skb_header_pointer(skb, ihl,
        sizeof(_ports), _ports);
   if (pptr == NULL)
    return NF_ACCEPT; /* Not for me */
// 用源地址,源端口来查真实服务器结构,如果是请求方向是找不到的
// 这种情况下数据包就不再被IPVS处理
   if (ip_vs_lookup_real_service(iph->protocol,
            iph->saddr, pptr[0])) {
    /*
     * Notify the real server: there is no
     * existing entry if it is not RST
     * packet or not TCP packet.
     */
    if (iph->protocol != IPPROTO_TCP
        || !is_tcp_reset(skb)) {
     icmp_send(skb,ICMP_DEST_UNREACH,
        ICMP_PORT_UNREACH, 0);
     return NF_DROP;
    }
   }
  }
  IP_VS_DBG_PKT(12, pp, skb, 0,
         "packet continues traversal as normal");
  return NF_ACCEPT;
 }
// 找到连接,该包是服务器的回应包
 IP_VS_DBG_PKT(11, pp, skb, 0, "Outgoing packet");
// skb数据包要求是可写的
 if (!ip_vs_make_skb_writable(pskb, ihl))
  goto drop;
/* mangle the packet */
// 修改协议部分信息,如TCP、UDP的端口
 if (pp->snat_handler && !pp->snat_handler(pskb, pp, cp))
  goto drop;
// 修改源地址, 由于是服务器的返回包,只修改源地址
 skb = *pskb;
 skb->nh.iph->saddr = cp->vaddr;
 ip_send_check(skb->nh.iph);
IP_VS_DBG_PKT(10, pp, skb, 0, "After SNAT");
// IPVS输出统计
 ip_vs_out_stats(cp, skb);
 ip_vs_set_state(cp, IP_VS_DIR_OUTPUT, skb, pp);
 ip_vs_conn_put(cp);
// 对该包设置标志表示IPVS处理过了
 skb->ipvs_property = 1;
LeaveFunction(11);
 return NF_ACCEPT;
drop:
 ip_vs_conn_put(cp);
 kfree_skb(*pskb);
 return NF_STOLEN;
}

4.5.3 ip_vs_post_routing_ops

/* Before the netfilter connection tracking, exit from POST_ROUTING */
static struct nf_hook_ops ip_vs_post_routing_ops = {
 .hook  = ip_vs_post_routing,
 .owner  = THIS_MODULE,
 .pf  = PF_INET,
// POSTROUTING点
 .hooknum        = NF_IP_POST_ROUTING,
// 在源NAT之前进行
 .priority       = NF_IP_PRI_NAT_SRC-1,
};

ip_vs_post_routing()这个函数对最后要发出的包进行检查,这个包是经过FORWARD链的,源地址已经被IPVS修改过了,不用再被netfilter进行修改。如果是IPVS处理过的包,直接跳出POSTROUTING点, 不再继续可能的该点的更低优先级的hook点操作,即不用进行netfilter标准的SNAT操作。

/* net/ipv4/ipvs/ip_vs_core.c */
/*
 *      It is hooked before NF_IP_PRI_NAT_SRC at the NF_IP_POST_ROUTING
 *      chain, and is used for VS/NAT.
 *      It detects packets for VS/NAT connections and sends the packets
 *      immediately. This can avoid that iptable_nat mangles the packets
 *      for VS/NAT.
 */
static unsigned int ip_vs_post_routing(unsigned int hooknum,
           struct sk_buff **pskb,
           const struct net_device *in,
           const struct net_device *out,
           int (*okfn)(struct sk_buff *))
{
// 如果没被IPVS处理过,继续后续hook点操作
 if (!((*pskb)->ipvs_property))
  return NF_ACCEPT;
 /* The packet was sent from IPVS, exit this chain */
// NF_STOP和NF_ACCEPT的区别就是STOP就不继续后面的低优先级的hook_ops的操作了
 return NF_STOP;
}

4.5.4 ip_vs_forward_icmp_ops

/* After packet filtering (but before ip_vs_out_icmp), catch icmp
   destined for 0.0.0.0/0, which is for incoming IPVS connections */
static struct nf_hook_ops ip_vs_forward_icmp_ops = {
 .hook  = ip_vs_forward_icmp,
 .owner  = THIS_MODULE,
 .pf  = PF_INET,
// FORWARD点
 .hooknum        = NF_IP_FORWARD,
// 在ip_vs_out_ops之前进行
 .priority       = 99,
};
ip_vs_forward_icmp()这个函数对转发的ICMP包进行处理, 处理由于服务器失效而引起的网络或端口不可达的ICMP信息,其他和服务器无关的ICMP信息不处理

/* net/ipv4/ipvs/ip_vs_core.c */
/*
 * It is hooked at the NF_IP_FORWARD chain, in order to catch ICMP
 *      related packets destined for 0.0.0.0/0.
 *      When fwmark-based virtual service is used, such as transparent
 *      cache cluster, TCP packets can be marked and routed to ip_vs_in,
 *      but ICMP destined for 0.0.0.0/0 cannot not be easily marked and
 *      sent to ip_vs_in_icmp. So, catch them at the NF_IP_FORWARD chain
 *      and send them to ip_vs_in_icmp.
 */
static unsigned int
ip_vs_forward_icmp(unsigned int hooknum, struct sk_buff **pskb,
     const struct net_device *in, const struct net_device *out,
     int (*okfn)(struct sk_buff *))
{
 int r;
if ((*pskb)->nh.iph->protocol != IPPROTO_ICMP)
  return NF_ACCEPT;
// 实际调用ip_vs_in_icmp()来处理数据包
 return ip_vs_in_icmp(pskb, &r, hooknum);
}

/*
 * Handle ICMP messages in the outside-to-inside direction (incoming).
 * Find any that might be relevant, check against existing connections,
 * forward to the right destination host if relevant.
 * Currently handles error types - unreachable, quench, ttl exceeded.
 */
static int 
ip_vs_in_icmp(struct sk_buff **pskb, int *related, unsigned int hooknum)
{
 struct sk_buff *skb = *pskb;
 struct iphdr *iph;
 struct icmphdr _icmph, *ic;
 struct iphdr _ciph, *cih; /* The ip header contained within the ICMP */
 struct ip_vs_conn *cp;
 struct ip_vs_protocol *pp;
 unsigned int offset, ihl, verdict;
// 这个参数指示该ICMP包是否和IPVS的连接相关
 *related = 1;
/* reassemble IP fragments */
 if (skb->nh.iph->frag_off & __constant_htons(IP_MF|IP_OFFSET)) {
// 进行碎片重组
  skb = ip_vs_gather_frags(skb,
                           hooknum == NF_IP_LOCAL_IN ?
      IP_DEFRAG_VS_IN : IP_DEFRAG_VS_FWD);
  if (!skb)
   return NF_STOLEN;
  *pskb = skb;
 }
iph = skb->nh.iph;
 offset = ihl = iph->ihl * 4;
 ic = skb_header_pointer(skb, offset, sizeof(_icmph), &_icmph);
 if (ic == NULL)
  return NF_DROP;
IP_VS_DBG(12, "Incoming ICMP (%d,%d) %u.%u.%u.%u->%u.%u.%u.%u\n",
    ic->type, ntohs(icmp_id(ic)),
    NIPQUAD(iph->saddr), NIPQUAD(iph->daddr));
/*
  * Work through seeing if this is for us.
  * These checks are supposed to be in an order that means easy
  * things are checked first to speed up processing.... however
  * this means that some packets will manage to get a long way
  * down this stack and then be rejected, but that's life.
  */
 if ((ic->type != ICMP_DEST_UNREACH) &&
     (ic->type != ICMP_SOURCE_QUENCH) &&
     (ic->type != ICMP_TIME_EXCEEDED)) {
// 如果不是这三种ICMP信息,则该skb与IPVS无关
  *related = 0;
  return NF_ACCEPT;
 }
/* Now find the contained IP header */
 offset += sizeof(_icmph);
 cih = skb_header_pointer(skb, offset, sizeof(_ciph), &_ciph);
 if (cih == NULL)
  return NF_ACCEPT; /* The packet looks wrong, ignore */
// 找的是ICMP信息中包含的原始包中的协议,而不是ICMP
 pp = ip_vs_proto_get(cih->protocol);
 if (!pp)
  return NF_ACCEPT;
/* Is the embedded protocol header present? */
// 如果是碎片不处理直接返回
 if (unlikely(cih->frag_off & __constant_htons(IP_OFFSET) &&
       pp->dont_defrag))
  return NF_ACCEPT;
IP_VS_DBG_PKT(11, pp, skb, offset, "Checking incoming ICMP for");
offset += cih->ihl * 4;
/* The embedded headers contain source and dest in reverse order */
// 查找IPVS连接
 cp = pp->conn_in_get(skb, pp, cih, offset, 1);
 if (!cp)
  return NF_ACCEPT;
// 缺省的裁定结果是丢弃包
 verdict = NF_DROP;
/* Ensure the checksum is correct */
 if (skb->ip_summed != CHECKSUM_UNNECESSARY &&
// 检查一下IP头的校验和
     ip_vs_checksum_complete(skb, ihl)) {
  /* Failed checksum! */
  IP_VS_DBG(1, "Incoming ICMP: failed checksum from %d.%d.%d.%d!\n",
     NIPQUAD(iph->saddr));
  goto out;
 }
/* do the statistics and put it back */
// 进行输入统计
 ip_vs_in_stats(cp, skb);
// 如果内部协议是TCP/UDP,发送偏移量要包括前4个字节: 源端口和目的端口
 if (IPPROTO_TCP == cih->protocol || IPPROTO_UDP == cih->protocol)
  offset += 2 * sizeof(__u16);
// 发送ICMP
 verdict = ip_vs_icmp_xmit(skb, cp, pp, offset);
 /* do not touch skb anymore */
out:
 __ip_vs_conn_put(cp);
return verdict;
}
/* net/ipv4/ipvs/ip_vs_xmit.c */
/*
 * ICMP packet transmitter
 * called by the ip_vs_in_icmp
 */
int
ip_vs_icmp_xmit(struct sk_buff *skb, struct ip_vs_conn *cp,
  struct ip_vs_protocol *pp, int offset)
{
 struct rtable *rt; /* Route to the other host */
 int mtu;
 int rc;
EnterFunction(10);
/* The ICMP packet for VS/TUN, VS/DR and LOCALNODE will be
    forwarded directly here, because there is no need to
    translate address/port back */
 if (IP_VS_FWD_METHOD(cp) != IP_VS_CONN_F_MASQ) {
// 如果不是NAT情况的IPVS连接, 即是TUNNEL或DR,直接调用连接的发送函数发送
  if (cp->packet_xmit)
   rc = cp->packet_xmit(skb, cp, pp);
  else
   rc = NF_ACCEPT;
  /* do not touch skb anymore */
  atomic_inc(&cp->in_pkts);
  goto out;
 }
/*
  * mangle and send the packet here (only for VS/NAT)
  */
// 查找路由
 if (!(rt = __ip_vs_get_out_rt(cp, RT_TOS(skb->nh.iph->tos))))
  goto tx_error_icmp;
/* MTU checking */
 mtu = dst_mtu(&rt->u.dst);
 if ((skb->len > mtu) && (skb->nh.iph->frag_off&__constant_htons(IP_DF))) {
// 数据包过长超过MTU,但又是不允许分片的,发送ICMP出错包
  ip_rt_put(rt);
  icmp_send(skb, ICMP_DEST_UNREACH, ICMP_FRAG_NEEDED, htonl(mtu));
  IP_VS_DBG_RL("ip_vs_in_icmp(): frag needed\n");
  goto tx_error;
 }
/* copy-on-write the packet before mangling it */
// 让skb可写
 if (!ip_vs_make_skb_writable(&skb, offset))
  goto tx_error_put;
// skb留出足够的硬件头空间
 if (skb_cow(skb, rt->u.dst.dev->hard_header_len))
  goto tx_error_put;
/* drop the old route when skb is not shared */
 dst_release(skb->dst);
 skb->dst = &rt->u.dst;
// 修改ICMP包
 ip_vs_nat_icmp(skb, pp, cp, 0);
/* Another hack: avoid icmp_send in ip_fragment */
 skb->local_df = 1;
// 将该包用OUTPUT点的hook_ops进行处理
 IP_VS_XMIT(skb, rt);
// NF_STOLEN表示该skb不用返回到正常的IP栈了
 rc = NF_STOLEN;
 goto out;
tx_error_icmp:
 dst_link_failure(skb);
  tx_error:
 dev_kfree_skb(skb);
 rc = NF_STOLEN;
  out:
 LeaveFunction(10);
 return rc;
  tx_error_put:
 ip_rt_put(rt);
 goto tx_error;
}

本文来自互联网用户投稿,该文观点仅代表作者本人,不代表本站立场。本站仅提供信息存储空间服务,不拥有所有权,不承担相关法律责任。如若转载,请注明出处:http://www.mzph.cn/news/295413.shtml

如若内容造成侵权/违法违规/事实不符,请联系多彩编程网进行投诉反馈email:809451989@qq.com,一经查实,立即删除!

相关文章

这些魔术用的是物理原理?有啥诀窍?

全世界只有3.14 % 的人关注了爆炸吧知识许多成功的魔术&#xff0c;都运用了物理知识。我们在观看魔术表演时&#xff0c;也可以学到相当多的知识&#xff0c;有时用一般的原理就可以表演一个十分精彩的魔术。所以我们希望揭开魔术的神秘面纱&#xff0c;探究其中的物理知识。一…

二分查找找下标或者值

public class Util { //求最大值public static int maxValue(int a,int b){int max=0;if(a>b){max=a;}else{max=b;}return max;}//求最小值public static int minValue(int a,int b){int min=0;if(a>b){min=b;}else{min=a;}return min;}//选择排序public static int[] se…

安装Wamp时出现无法启动此程序,因为计算机中丢失MSVCR110.dll的解决方法

可能有的朋友在运行某软件时&#xff0c;会出现了“无法启动此程序,因为计算机中丢失 MSVCR110.dll。尝试重新安装该程序以解决此问题。”的提示,遇到这样的情况该怎么办呢&#xff1f;不用着急&#xff0c;下面小编就为大家带来解决方法&#xff0c;遇到同样问题却不知道如何解…

java 线程 获取消息_获取java线程中信息

怎样获取java线程中信息&#xff1f;在进行多线程编程中&#xff0c;比较重要也是比较困难的一个操作就是如何获取线程中的信息。大多数人会采取比较常见的一种方法就是将线程中要返回的结果存储在一个字段中&#xff0c;然后再提供一个获取方法将这个字段的内容返回给该方法的…

OAuth 2.0 扩展协议之 PKCE

前言阅读本文前需要了解 OAuth 2.0 授权协议的相关内容&#xff0c; 可以参考我的上一篇文章 OAuth 2.0 的探险之旅[1]。PKCE 全称是 Proof Key for Code Exchange&#xff0c; 在2015年发布&#xff0c; 它是 OAuth 2.0 核心的一个扩展协议&#xff0c; 所以可以和现有的授权模…

欧洲杯直播助PPTV日均流量登顶视频行业首位

随着意大利溃败&#xff0c;西班牙最终捧杯&#xff0c;四年一度火爆的欧洲杯赛事也就此落下帷幕。令人欣喜的是&#xff0c;在本届欧洲杯比赛的直播过程中&#xff0c;由于比赛安排再深夜&#xff0c;互联网应用取代传统电视台成为人们观看赛事的主要渠道&#xff0c;各大视频…

深度优先算法

/*** @author Think* 给定整数a1,a2,a3,a4…,判断是否可以从中选出若干数,使他们的和恰好为K*/ public class 深度优先算法 {//n=4,a={1,2,4,7};k=13;public static int n=4;public static int [] a={1,2,4,7};public static int k=13;public static void main(String[] ar…

/etc/network/interfaces

man resolvconf man interfaceshttp://linux-net.osdl.org/index.php/Bridge示例:# This file describes the network interfaces available on your system# and how to activate them. For more information, see interfaces(5).# The loopback network interfaceauto lo ifa…

nashorn js 调用 java_从nashorn(JDK 8 JavaScript引擎)调用char []输入参数调用Java函数?...

我想从Oracle的nashorn JavaScript引擎中调用一个带有 char[] 输入参数的Java函数(非数组参数类型的函数对我来说没问题) .如果我用JavaScript字符串文字调用Java函数&#xff0c;nashorn balksjavax.script.ScriptException: TypeError: Can not invoke method[jdk.internal.d…

Netty之有效规避内存泄漏

有过痛苦的经历&#xff0c;特别能写出深刻的文章 —— 凯尔文. 肖 直接内存是IO框架的绝配&#xff0c;但直接内存的分配销毁不易&#xff0c;所以使用内存池能大幅提高性能&#xff0c;也告别了频繁的GC。但&#xff0c;要重新培养被Java的自动垃圾回收惯坏了的惰性。 Netty有…

.NET 6新特性试用 | record struct

前言在以前的文章中&#xff0c;我们介绍过record类型&#xff0c;它具有不变性(《为什么应该用record来定义DTO》)和值相等性(《为什么应该用record来定义DTO&#xff08;续&#xff09;》)。record是引用类型。而在.NET 6中&#xff0c;我们可以使用record struct定义值类型。…

原来我们看到的世界地图竟这样震撼!多年的地理白学了...

▲ 点击查看几乎每个家庭都会有两张地图&#xff1a;一张世界地图&#xff0c;一张中国地图。薄薄的两张纸&#xff0c;蕴藏着让每个人学会“看世界”的磅礴力量。哈佛上一任校长&#xff0c;也是300多年来唯一一位女校长德鲁吉尔平福斯特&#xff08;Drew Gilpin Faust&#x…

Exchange Powershell查看用户最后登陆邮箱时间

在Exchange日常管理中&#xff0c;我们可能经常会遇到这样的问题&#xff0c;就是怎么来知道一个用户最后的登录时间&#xff1f;这个问题在使用Exchange powershell就能很好的解决了。 用管理员身份运行Exchange management powershell 查看某一个邮箱数据库的统计信息&#x…

在n个火柴里面拿3根出来拼接成最大三角形的周长

求三角形max周长 public class 求三角形max周长 { public static void main(String[] args) {/*** 有n个棍子 每个棍子的长度是a[i]* 3<n<100;* 1<a[i]<100; */ System.out.println("请输入n根绳子"); Scanner input new Scanner(System.in); int ni…

mysql之mysqldump命令

导出要用到MySQL的mysqldump工具&#xff0c;基本用法是&#xff1a; shell> mysqldump [OPTIONS] database [tables] 如果你不给定任何表&#xff0c;整个数据库将被导出。 通过执行mysqldump --help&#xff0c;你能得到你mysqldump的版本支持的选项表。 注意&#xff0c;…

易企秀制作的步骤

2019独角兽企业重金招聘Python工程师标准>>> 1、选图很关键 &#xff08;图片干净 整洁&#xff0c;不同方位展示 &#xff0c;符合主题&#xff09;。 2、配上说明性文字 简明扼要 3、选择合适的模板和背景音乐。 4、及时沟通与调整。 转载于:https://my.oschina.n…

java instanceof运算符_Java instanceof 运算符的使用方法

用法&#xff1a;(类型变量 instanceof 类|接口)作用&#xff1a;instanceof 操作符用于判断前面的对象是否是后面的类&#xff0c;或者其子类、实现类的实例。如果是则返回true 否则就返回false。注意&#xff1a; instanceof前面的操作数的编译时类型要么与后面的类相同&…

C# WPF MVVM模式Prism框架下事件发布与订阅

01—前言处理同模块不同窗体之间的通信和不同模块之间不同窗体的通信&#xff0c;Prism提供了一种事件机制&#xff0c;可以在应用程序中低耦合的模块之间进行通信&#xff0c;该机制基于事件聚合器服务&#xff0c;允许发布者和订阅者之间通过事件进行通讯&#xff0c;且彼此之…

这几部高分学科纪录片,助力孩子涨姿势拓视野~

全世界只有3.14 % 的人关注了爆炸吧知识▌导读本文为同学们整理了几部高分经典学科纪录片&#xff0c;对应文学、数学、经济学、地理、化学。这不仅是课堂学习的补充与延伸&#xff0c;更是开拓视野、激发学习内驱力的绝佳利器。建议收藏&#xff01;&#xff08;关注视频号少年…

Linux 学习_在Linux下面安装tomcat

要在linux下面安装tomcat&#xff0c;首先我们需要做一些准备工作.... 下载tomcat&#xff1a; 下载地址&#xff1a;http://tomcat.apache.org/download-60.cgi 下载&#xff1a;tar.gz 如图&#xff1a; 说明&#xff1a; WinISO安装版&#xff1a;下载地址&#xff1a;http…