50c7f6ec2064dc956c8c84ffa82054b73399a751
[sliver-openvswitch.git] / datapath / datapath.c
1 /*
2  * Copyright (c) 2007, 2008, 2009, 2010 Nicira Networks.
3  * Distributed under the terms of the GNU GPL version 2.
4  *
5  * Significant portions of this file may be copied from parts of the Linux
6  * kernel, by Linus Torvalds and others.
7  */
8
9 /* Functions for managing the dp interface/device. */
10
11 #include <linux/init.h>
12 #include <linux/module.h>
13 #include <linux/fs.h>
14 #include <linux/if_arp.h>
15 #include <linux/if_vlan.h>
16 #include <linux/in.h>
17 #include <linux/ip.h>
18 #include <linux/delay.h>
19 #include <linux/time.h>
20 #include <linux/etherdevice.h>
21 #include <linux/kernel.h>
22 #include <linux/kthread.h>
23 #include <linux/mutex.h>
24 #include <linux/percpu.h>
25 #include <linux/rcupdate.h>
26 #include <linux/tcp.h>
27 #include <linux/udp.h>
28 #include <linux/version.h>
29 #include <linux/ethtool.h>
30 #include <linux/random.h>
31 #include <linux/wait.h>
32 #include <asm/system.h>
33 #include <asm/div64.h>
34 #include <asm/bug.h>
35 #include <linux/highmem.h>
36 #include <linux/netfilter_bridge.h>
37 #include <linux/netfilter_ipv4.h>
38 #include <linux/inetdevice.h>
39 #include <linux/list.h>
40 #include <linux/rculist.h>
41 #include <linux/workqueue.h>
42 #include <linux/dmi.h>
43 #include <net/inet_ecn.h>
44 #include <linux/compat.h>
45
46 #include "openvswitch/datapath-protocol.h"
47 #include "datapath.h"
48 #include "actions.h"
49 #include "flow.h"
50 #include "odp-compat.h"
51 #include "table.h"
52 #include "vport-internal_dev.h"
53
54 #include "compat.h"
55
56
57 int (*dp_ioctl_hook)(struct net_device *dev, struct ifreq *rq, int cmd);
58 EXPORT_SYMBOL(dp_ioctl_hook);
59
60 /* Datapaths.  Protected on the read side by rcu_read_lock, on the write side
61  * by dp_mutex.
62  *
63  * dp_mutex nests inside the RTNL lock: if you need both you must take the RTNL
64  * lock first.
65  *
66  * It is safe to access the datapath and dp_port structures with just
67  * dp_mutex.
68  */
69 static struct datapath *dps[ODP_MAX];
70 static DEFINE_MUTEX(dp_mutex);
71
72 /* Number of milliseconds between runs of the maintenance thread. */
73 #define MAINT_SLEEP_MSECS 1000
74
75 static int new_dp_port(struct datapath *, struct odp_port *, int port_no);
76
77 /* Must be called with rcu_read_lock or dp_mutex. */
78 struct datapath *get_dp(int dp_idx)
79 {
80         if (dp_idx < 0 || dp_idx >= ODP_MAX)
81                 return NULL;
82         return rcu_dereference(dps[dp_idx]);
83 }
84 EXPORT_SYMBOL_GPL(get_dp);
85
86 static struct datapath *get_dp_locked(int dp_idx)
87 {
88         struct datapath *dp;
89
90         mutex_lock(&dp_mutex);
91         dp = get_dp(dp_idx);
92         if (dp)
93                 mutex_lock(&dp->mutex);
94         mutex_unlock(&dp_mutex);
95         return dp;
96 }
97
98 /* Must be called with rcu_read_lock or RTNL lock. */
99 const char *dp_name(const struct datapath *dp)
100 {
101         return vport_get_name(dp->ports[ODPP_LOCAL]->vport);
102 }
103
104 static inline size_t br_nlmsg_size(void)
105 {
106         return NLMSG_ALIGN(sizeof(struct ifinfomsg))
107                + nla_total_size(IFNAMSIZ) /* IFLA_IFNAME */
108                + nla_total_size(MAX_ADDR_LEN) /* IFLA_ADDRESS */
109                + nla_total_size(4) /* IFLA_MASTER */
110                + nla_total_size(4) /* IFLA_MTU */
111                + nla_total_size(4) /* IFLA_LINK */
112                + nla_total_size(1); /* IFLA_OPERSTATE */
113 }
114
115 static int dp_fill_ifinfo(struct sk_buff *skb,
116                           const struct dp_port *port,
117                           int event, unsigned int flags)
118 {
119         const struct datapath *dp = port->dp;
120         int ifindex = vport_get_ifindex(port->vport);
121         int iflink = vport_get_iflink(port->vport);
122         struct ifinfomsg *hdr;
123         struct nlmsghdr *nlh;
124
125         if (ifindex < 0)
126                 return ifindex;
127
128         if (iflink < 0)
129                 return iflink;
130
131         nlh = nlmsg_put(skb, 0, 0, event, sizeof(*hdr), flags);
132         if (nlh == NULL)
133                 return -EMSGSIZE;
134
135         hdr = nlmsg_data(nlh);
136         hdr->ifi_family = AF_BRIDGE;
137         hdr->__ifi_pad = 0;
138         hdr->ifi_type = ARPHRD_ETHER;
139         hdr->ifi_index = ifindex;
140         hdr->ifi_flags = vport_get_flags(port->vport);
141         hdr->ifi_change = 0;
142
143         NLA_PUT_STRING(skb, IFLA_IFNAME, vport_get_name(port->vport));
144         NLA_PUT_U32(skb, IFLA_MASTER, vport_get_ifindex(dp->ports[ODPP_LOCAL]->vport));
145         NLA_PUT_U32(skb, IFLA_MTU, vport_get_mtu(port->vport));
146 #ifdef IFLA_OPERSTATE
147         NLA_PUT_U8(skb, IFLA_OPERSTATE,
148                    vport_is_running(port->vport)
149                         ? vport_get_operstate(port->vport)
150                         : IF_OPER_DOWN);
151 #endif
152
153         NLA_PUT(skb, IFLA_ADDRESS, ETH_ALEN,
154                                         vport_get_addr(port->vport));
155
156         if (ifindex != iflink)
157                 NLA_PUT_U32(skb, IFLA_LINK,iflink);
158
159         return nlmsg_end(skb, nlh);
160
161 nla_put_failure:
162         nlmsg_cancel(skb, nlh);
163         return -EMSGSIZE;
164 }
165
166 static void dp_ifinfo_notify(int event, struct dp_port *port)
167 {
168         struct sk_buff *skb;
169         int err = -ENOBUFS;
170
171         skb = nlmsg_new(br_nlmsg_size(), GFP_KERNEL);
172         if (skb == NULL)
173                 goto errout;
174
175         err = dp_fill_ifinfo(skb, port, event, 0);
176         if (err < 0) {
177                 /* -EMSGSIZE implies BUG in br_nlmsg_size() */
178                 WARN_ON(err == -EMSGSIZE);
179                 kfree_skb(skb);
180                 goto errout;
181         }
182         rtnl_notify(skb, &init_net, 0, RTNLGRP_LINK, NULL, GFP_KERNEL);
183         return;
184 errout:
185         if (err < 0)
186                 rtnl_set_sk_err(&init_net, RTNLGRP_LINK, err);
187 }
188
189 static void release_dp(struct kobject *kobj)
190 {
191         struct datapath *dp = container_of(kobj, struct datapath, ifobj);
192         kfree(dp);
193 }
194
195 static struct kobj_type dp_ktype = {
196         .release = release_dp
197 };
198
199 static int create_dp(int dp_idx, const char __user *devnamep)
200 {
201         struct odp_port internal_dev_port;
202         char devname[IFNAMSIZ];
203         struct datapath *dp;
204         int err;
205         int i;
206
207         if (devnamep) {
208                 int retval = strncpy_from_user(devname, devnamep, IFNAMSIZ);
209                 if (retval < 0) {
210                         err = -EFAULT;
211                         goto err;
212                 } else if (retval >= IFNAMSIZ) {
213                         err = -ENAMETOOLONG;
214                         goto err;
215                 }
216         } else {
217                 snprintf(devname, sizeof devname, "of%d", dp_idx);
218         }
219
220         rtnl_lock();
221         mutex_lock(&dp_mutex);
222         err = -ENODEV;
223         if (!try_module_get(THIS_MODULE))
224                 goto err_unlock;
225
226         /* Exit early if a datapath with that number already exists.
227          * (We don't use -EEXIST because that's ambiguous with 'devname'
228          * conflicting with an existing network device name.) */
229         err = -EBUSY;
230         if (get_dp(dp_idx))
231                 goto err_put_module;
232
233         err = -ENOMEM;
234         dp = kzalloc(sizeof *dp, GFP_KERNEL);
235         if (dp == NULL)
236                 goto err_put_module;
237         INIT_LIST_HEAD(&dp->port_list);
238         mutex_init(&dp->mutex);
239         dp->dp_idx = dp_idx;
240         for (i = 0; i < DP_N_QUEUES; i++)
241                 skb_queue_head_init(&dp->queues[i]);
242         init_waitqueue_head(&dp->waitqueue);
243
244         /* Initialize kobject for bridge.  This will be added as
245          * /sys/class/net/<devname>/brif later, if sysfs is enabled. */
246         dp->ifobj.kset = NULL;
247         kobject_init(&dp->ifobj, &dp_ktype);
248
249         /* Allocate table. */
250         err = -ENOMEM;
251         rcu_assign_pointer(dp->table, tbl_create(0));
252         if (!dp->table)
253                 goto err_free_dp;
254
255         /* Set up our datapath device. */
256         BUILD_BUG_ON(sizeof(internal_dev_port.devname) != sizeof(devname));
257         strcpy(internal_dev_port.devname, devname);
258         internal_dev_port.flags = ODP_PORT_INTERNAL;
259         err = new_dp_port(dp, &internal_dev_port, ODPP_LOCAL);
260         if (err) {
261                 if (err == -EBUSY)
262                         err = -EEXIST;
263
264                 goto err_destroy_table;
265         }
266
267         dp->drop_frags = 0;
268         dp->stats_percpu = alloc_percpu(struct dp_stats_percpu);
269         if (!dp->stats_percpu)
270                 goto err_destroy_local_port;
271
272         rcu_assign_pointer(dps[dp_idx], dp);
273         mutex_unlock(&dp_mutex);
274         rtnl_unlock();
275
276         dp_sysfs_add_dp(dp);
277
278         return 0;
279
280 err_destroy_local_port:
281         dp_detach_port(dp->ports[ODPP_LOCAL], 1);
282 err_destroy_table:
283         tbl_destroy(dp->table, NULL);
284 err_free_dp:
285         kfree(dp);
286 err_put_module:
287         module_put(THIS_MODULE);
288 err_unlock:
289         mutex_unlock(&dp_mutex);
290         rtnl_unlock();
291 err:
292         return err;
293 }
294
295 static void do_destroy_dp(struct datapath *dp)
296 {
297         struct dp_port *p, *n;
298         int i;
299
300         list_for_each_entry_safe (p, n, &dp->port_list, node)
301                 if (p->port_no != ODPP_LOCAL)
302                         dp_detach_port(p, 1);
303
304         dp_sysfs_del_dp(dp);
305
306         rcu_assign_pointer(dps[dp->dp_idx], NULL);
307
308         dp_detach_port(dp->ports[ODPP_LOCAL], 1);
309
310         tbl_destroy(dp->table, flow_free_tbl);
311
312         for (i = 0; i < DP_N_QUEUES; i++)
313                 skb_queue_purge(&dp->queues[i]);
314         for (i = 0; i < DP_MAX_GROUPS; i++)
315                 kfree(dp->groups[i]);
316         free_percpu(dp->stats_percpu);
317         kobject_put(&dp->ifobj);
318         module_put(THIS_MODULE);
319 }
320
321 static int destroy_dp(int dp_idx)
322 {
323         struct datapath *dp;
324         int err;
325
326         rtnl_lock();
327         mutex_lock(&dp_mutex);
328         dp = get_dp(dp_idx);
329         err = -ENODEV;
330         if (!dp)
331                 goto err_unlock;
332
333         do_destroy_dp(dp);
334         err = 0;
335
336 err_unlock:
337         mutex_unlock(&dp_mutex);
338         rtnl_unlock();
339         return err;
340 }
341
342 static void release_dp_port(struct kobject *kobj)
343 {
344         struct dp_port *p = container_of(kobj, struct dp_port, kobj);
345         kfree(p);
346 }
347
348 static struct kobj_type brport_ktype = {
349 #ifdef CONFIG_SYSFS
350         .sysfs_ops = &brport_sysfs_ops,
351 #endif
352         .release = release_dp_port
353 };
354
355 /* Called with RTNL lock and dp_mutex. */
356 static int new_dp_port(struct datapath *dp, struct odp_port *odp_port, int port_no)
357 {
358         struct vport *vport;
359         struct dp_port *p;
360         int err;
361
362         vport = vport_locate(odp_port->devname);
363         if (!vport) {
364                 vport_lock();
365
366                 if (odp_port->flags & ODP_PORT_INTERNAL)
367                         vport = vport_add(odp_port->devname, "internal", NULL);
368                 else
369                         vport = vport_add(odp_port->devname, "netdev", NULL);
370
371                 vport_unlock();
372
373                 if (IS_ERR(vport))
374                         return PTR_ERR(vport);
375         }
376
377         p = kzalloc(sizeof(*p), GFP_KERNEL);
378         if (!p)
379                 return -ENOMEM;
380
381         p->port_no = port_no;
382         p->dp = dp;
383         atomic_set(&p->sflow_pool, 0);
384
385         err = vport_attach(vport, p);
386         if (err) {
387                 kfree(p);
388                 return err;
389         }
390
391         rcu_assign_pointer(dp->ports[port_no], p);
392         list_add_rcu(&p->node, &dp->port_list);
393         dp->n_ports++;
394
395         /* Initialize kobject for bridge.  This will be added as
396          * /sys/class/net/<devname>/brport later, if sysfs is enabled. */
397         p->kobj.kset = NULL;
398         kobject_init(&p->kobj, &brport_ktype);
399
400         dp_ifinfo_notify(RTM_NEWLINK, p);
401
402         return 0;
403 }
404
405 static int attach_port(int dp_idx, struct odp_port __user *portp)
406 {
407         struct datapath *dp;
408         struct odp_port port;
409         int port_no;
410         int err;
411
412         err = -EFAULT;
413         if (copy_from_user(&port, portp, sizeof port))
414                 goto out;
415         port.devname[IFNAMSIZ - 1] = '\0';
416
417         rtnl_lock();
418         dp = get_dp_locked(dp_idx);
419         err = -ENODEV;
420         if (!dp)
421                 goto out_unlock_rtnl;
422
423         for (port_no = 1; port_no < DP_MAX_PORTS; port_no++)
424                 if (!dp->ports[port_no])
425                         goto got_port_no;
426         err = -EFBIG;
427         goto out_unlock_dp;
428
429 got_port_no:
430         err = new_dp_port(dp, &port, port_no);
431         if (err)
432                 goto out_unlock_dp;
433
434         set_internal_devs_mtu(dp);
435         dp_sysfs_add_if(dp->ports[port_no]);
436
437         err = put_user(port_no, &portp->port);
438
439 out_unlock_dp:
440         mutex_unlock(&dp->mutex);
441 out_unlock_rtnl:
442         rtnl_unlock();
443 out:
444         return err;
445 }
446
447 int dp_detach_port(struct dp_port *p, int may_delete)
448 {
449         struct vport *vport = p->vport;
450         int err;
451
452         ASSERT_RTNL();
453
454         if (p->port_no != ODPP_LOCAL)
455                 dp_sysfs_del_if(p);
456         dp_ifinfo_notify(RTM_DELLINK, p);
457
458         /* First drop references to device. */
459         p->dp->n_ports--;
460         list_del_rcu(&p->node);
461         rcu_assign_pointer(p->dp->ports[p->port_no], NULL);
462
463         err = vport_detach(vport);
464         if (err)
465                 return err;
466
467         /* Then wait until no one is still using it, and destroy it. */
468         synchronize_rcu();
469
470         if (may_delete) {
471                 const char *port_type = vport_get_type(vport);
472
473                 if (!strcmp(port_type, "netdev") || !strcmp(port_type, "internal")) {
474                         vport_lock();
475                         vport_del(vport);
476                         vport_unlock();
477                 }
478         }
479
480         kobject_put(&p->kobj);
481
482         return 0;
483 }
484
485 static int detach_port(int dp_idx, int port_no)
486 {
487         struct dp_port *p;
488         struct datapath *dp;
489         int err;
490
491         err = -EINVAL;
492         if (port_no < 0 || port_no >= DP_MAX_PORTS || port_no == ODPP_LOCAL)
493                 goto out;
494
495         rtnl_lock();
496         dp = get_dp_locked(dp_idx);
497         err = -ENODEV;
498         if (!dp)
499                 goto out_unlock_rtnl;
500
501         p = dp->ports[port_no];
502         err = -ENOENT;
503         if (!p)
504                 goto out_unlock_dp;
505
506         err = dp_detach_port(p, 1);
507
508 out_unlock_dp:
509         mutex_unlock(&dp->mutex);
510 out_unlock_rtnl:
511         rtnl_unlock();
512 out:
513         return err;
514 }
515
516 /* Must be called with rcu_read_lock. */
517 void dp_process_received_packet(struct dp_port *p, struct sk_buff *skb)
518 {
519         struct datapath *dp = p->dp;
520         struct dp_stats_percpu *stats;
521         int stats_counter_off;
522         struct odp_flow_key key;
523         struct tbl_node *flow_node;
524
525         OVS_CB(skb)->dp_port = p;
526
527         if (flow_extract(skb, p ? p->port_no : ODPP_NONE, &key)) {
528                 if (dp->drop_frags) {
529                         kfree_skb(skb);
530                         stats_counter_off = offsetof(struct dp_stats_percpu, n_frags);
531                         goto out;
532                 }
533         }
534
535         flow_node = tbl_lookup(rcu_dereference(dp->table), &key, flow_hash(&key), flow_cmp);
536         if (flow_node) {
537                 struct sw_flow *flow = flow_cast(flow_node);
538                 struct sw_flow_actions *acts = rcu_dereference(flow->sf_acts);
539                 flow_used(flow, skb);
540                 execute_actions(dp, skb, &key, acts->actions, acts->n_actions,
541                                 GFP_ATOMIC);
542                 stats_counter_off = offsetof(struct dp_stats_percpu, n_hit);
543         } else {
544                 stats_counter_off = offsetof(struct dp_stats_percpu, n_missed);
545                 dp_output_control(dp, skb, _ODPL_MISS_NR, OVS_CB(skb)->tun_id);
546         }
547
548 out:
549         local_bh_disable();
550         stats = per_cpu_ptr(dp->stats_percpu, smp_processor_id());
551         (*(u64 *)((u8 *)stats + stats_counter_off))++;
552         local_bh_enable();
553 }
554
555 #if defined(CONFIG_XEN) && defined(HAVE_PROTO_DATA_VALID)
556 /* This code is based on skb_checksum_setup() from Xen's net/dev/core.c.  We
557  * can't call this function directly because it isn't exported in all
558  * versions. */
559 int vswitch_skb_checksum_setup(struct sk_buff *skb)
560 {
561         struct iphdr *iph;
562         unsigned char *th;
563         int err = -EPROTO;
564         __u16 csum_start, csum_offset;
565
566         if (!skb->proto_csum_blank)
567                 return 0;
568
569         if (skb->protocol != htons(ETH_P_IP))
570                 goto out;
571
572         if (!pskb_may_pull(skb, skb_network_header(skb) + sizeof(struct iphdr) - skb->data))
573                 goto out;
574
575         iph = ip_hdr(skb);
576         th = skb_network_header(skb) + 4 * iph->ihl;
577
578         csum_start = th - skb->head;
579         switch (iph->protocol) {
580         case IPPROTO_TCP:
581                 csum_offset = offsetof(struct tcphdr, check);
582                 break;
583         case IPPROTO_UDP:
584                 csum_offset = offsetof(struct udphdr, check);
585                 break;
586         default:
587                 if (net_ratelimit())
588                         printk(KERN_ERR "Attempting to checksum a non-"
589                                "TCP/UDP packet, dropping a protocol"
590                                " %d packet", iph->protocol);
591                 goto out;
592         }
593
594         if (!pskb_may_pull(skb, th + csum_offset + 2 - skb->data))
595                 goto out;
596
597         skb->ip_summed = CHECKSUM_PARTIAL;
598         skb->proto_csum_blank = 0;
599
600 #if LINUX_VERSION_CODE >= KERNEL_VERSION(2,6,22)
601         skb->csum_start = csum_start;
602         skb->csum_offset = csum_offset;
603 #else
604         skb_set_transport_header(skb, csum_start - skb_headroom(skb));
605         skb->csum = csum_offset;
606 #endif
607
608         err = 0;
609
610 out:
611         return err;
612 }
613 #endif /* CONFIG_XEN && HAVE_PROTO_DATA_VALID */
614
615  /* Types of checksums that we can receive (these all refer to L4 checksums):
616  * 1. CHECKSUM_NONE: Device that did not compute checksum, contains full
617  *      (though not verified) checksum in packet but not in skb->csum.  Packets
618  *      from the bridge local port will also have this type.
619  * 2. CHECKSUM_COMPLETE (CHECKSUM_HW): Good device that computes checksums,
620  *      also the GRE module.  This is the same as CHECKSUM_NONE, except it has
621  *      a valid skb->csum.  Importantly, both contain a full checksum (not
622  *      verified) in the packet itself.  The only difference is that if the
623  *      packet gets to L4 processing on this machine (not in DomU) we won't
624  *      have to recompute the checksum to verify.  Most hardware devices do not
625  *      produce packets with this type, even if they support receive checksum
626  *      offloading (they produce type #5).
627  * 3. CHECKSUM_PARTIAL (CHECKSUM_HW): Packet without full checksum and needs to
628  *      be computed if it is sent off box.  Unfortunately on earlier kernels,
629  *      this case is impossible to distinguish from #2, despite having opposite
630  *      meanings.  Xen adds an extra field on earlier kernels (see #4) in order
631  *      to distinguish the different states.
632  * 4. CHECKSUM_UNNECESSARY (with proto_csum_blank true): This packet was
633  *      generated locally by a Xen DomU and has a partial checksum.  If it is
634  *      handled on this machine (Dom0 or DomU), then the checksum will not be
635  *      computed.  If it goes off box, the checksum in the packet needs to be
636  *      completed.  Calling skb_checksum_setup converts this to CHECKSUM_HW
637  *      (CHECKSUM_PARTIAL) so that the checksum can be completed.  In later
638  *      kernels, this combination is replaced with CHECKSUM_PARTIAL.
639  * 5. CHECKSUM_UNNECESSARY (with proto_csum_blank false): Packet with a correct
640  *      full checksum or using a protocol without a checksum.  skb->csum is
641  *      undefined.  This is common from devices with receive checksum
642  *      offloading.  This is somewhat similar to CHECKSUM_NONE, except that
643  *      nobody will try to verify the checksum with CHECKSUM_UNNECESSARY.
644  *
645  * Note that on earlier kernels, CHECKSUM_COMPLETE and CHECKSUM_PARTIAL are
646  * both defined as CHECKSUM_HW.  Normally the meaning of CHECKSUM_HW is clear
647  * based on whether it is on the transmit or receive path.  After the datapath
648  * it will be intepreted as CHECKSUM_PARTIAL.  If the packet already has a
649  * checksum, we will panic.  Since we can receive packets with checksums, we
650  * assume that all CHECKSUM_HW packets have checksums and map them to
651  * CHECKSUM_NONE, which has a similar meaning (the it is only different if the
652  * packet is processed by the local IP stack, in which case it will need to
653  * be reverified).  If we receive a packet with CHECKSUM_HW that really means
654  * CHECKSUM_PARTIAL, it will be sent with the wrong checksum.  However, there
655  * shouldn't be any devices that do this with bridging. */
656 void compute_ip_summed(struct sk_buff *skb, bool xmit)
657 {
658         /* For our convenience these defines change repeatedly between kernel
659          * versions, so we can't just copy them over... */
660         switch (skb->ip_summed) {
661         case CHECKSUM_NONE:
662                 OVS_CB(skb)->ip_summed = OVS_CSUM_NONE;
663                 break;
664         case CHECKSUM_UNNECESSARY:
665                 OVS_CB(skb)->ip_summed = OVS_CSUM_UNNECESSARY;
666                 break;
667 #ifdef CHECKSUM_HW
668         /* In theory this could be either CHECKSUM_PARTIAL or CHECKSUM_COMPLETE.
669          * However, on the receive side we should only get CHECKSUM_PARTIAL
670          * packets from Xen, which uses some special fields to represent this
671          * (see below).  Since we can only make one type work, pick the one
672          * that actually happens in practice.
673          *
674          * On the transmit side (basically after skb_checksum_setup()
675          * has been run or on internal dev transmit), packets with
676          * CHECKSUM_COMPLETE aren't generated, so assume CHECKSUM_PARTIAL. */
677         case CHECKSUM_HW:
678                 if (!xmit)
679                         OVS_CB(skb)->ip_summed = OVS_CSUM_COMPLETE;
680                 else
681                         OVS_CB(skb)->ip_summed = OVS_CSUM_PARTIAL;
682
683                 break;
684 #else
685         case CHECKSUM_COMPLETE:
686                 OVS_CB(skb)->ip_summed = OVS_CSUM_COMPLETE;
687                 break;
688         case CHECKSUM_PARTIAL:
689                 OVS_CB(skb)->ip_summed = OVS_CSUM_PARTIAL;
690                 break;
691 #endif
692         default:
693                 printk(KERN_ERR "openvswitch: unknown checksum type %d\n",
694                        skb->ip_summed);
695                 /* None seems the safest... */
696                 OVS_CB(skb)->ip_summed = OVS_CSUM_NONE;
697         }       
698
699 #if defined(CONFIG_XEN) && defined(HAVE_PROTO_DATA_VALID)
700         /* Xen has a special way of representing CHECKSUM_PARTIAL on older
701          * kernels. It should not be set on the transmit path though. */
702         if (skb->proto_csum_blank)
703                 OVS_CB(skb)->ip_summed = OVS_CSUM_PARTIAL;
704
705         WARN_ON_ONCE(skb->proto_csum_blank && xmit);
706 #endif
707 }
708
709 /* This function closely resembles skb_forward_csum() used by the bridge.  It
710  * is slightly different because we are only concerned with bridging and not
711  * other types of forwarding and can get away with slightly more optimal
712  * behavior.*/
713 void forward_ip_summed(struct sk_buff *skb)
714 {
715 #ifdef CHECKSUM_HW
716         if (OVS_CB(skb)->ip_summed == OVS_CSUM_COMPLETE)
717                 skb->ip_summed = CHECKSUM_NONE;
718 #endif
719 }
720
721 /* Append each packet in 'skb' list to 'queue'.  There will be only one packet
722  * unless we broke up a GSO packet. */
723 static int queue_control_packets(struct sk_buff *skb, struct sk_buff_head *queue,
724                                  int queue_no, u32 arg)
725 {
726         struct sk_buff *nskb;
727         int port_no;
728         int err;
729
730         if (OVS_CB(skb)->dp_port)
731                 port_no = OVS_CB(skb)->dp_port->port_no;
732         else
733                 port_no = ODPP_LOCAL;
734
735         do {
736                 struct odp_msg *header;
737
738                 nskb = skb->next;
739                 skb->next = NULL;
740
741                 err = skb_cow(skb, sizeof *header);
742                 if (err)
743                         goto err_kfree_skbs;
744
745                 header = (struct odp_msg*)__skb_push(skb, sizeof *header);
746                 header->type = queue_no;
747                 header->length = skb->len;
748                 header->port = port_no;
749                 header->reserved = 0;
750                 header->arg = arg;
751                 skb_queue_tail(queue, skb);
752
753                 skb = nskb;
754         } while (skb);
755         return 0;
756
757 err_kfree_skbs:
758         kfree_skb(skb);
759         while ((skb = nskb) != NULL) {
760                 nskb = skb->next;
761                 kfree_skb(skb);
762         }
763         return err;
764 }
765
766 int dp_output_control(struct datapath *dp, struct sk_buff *skb, int queue_no,
767                       u32 arg)
768 {
769         struct dp_stats_percpu *stats;
770         struct sk_buff_head *queue;
771         int err;
772
773         WARN_ON_ONCE(skb_shared(skb));
774         BUG_ON(queue_no != _ODPL_MISS_NR && queue_no != _ODPL_ACTION_NR && queue_no != _ODPL_SFLOW_NR);
775         queue = &dp->queues[queue_no];
776         err = -ENOBUFS;
777         if (skb_queue_len(queue) >= DP_MAX_QUEUE_LEN)
778                 goto err_kfree_skb;
779
780         forward_ip_summed(skb);
781
782         err = vswitch_skb_checksum_setup(skb);
783         if (err)
784                 goto err_kfree_skb;
785
786         /* Break apart GSO packets into their component pieces.  Otherwise
787          * userspace may try to stuff a 64kB packet into a 1500-byte MTU. */
788         if (skb_is_gso(skb)) {
789                 struct sk_buff *nskb = skb_gso_segment(skb, NETIF_F_SG | NETIF_F_HW_CSUM);
790                 if (nskb) {
791                         kfree_skb(skb);
792                         skb = nskb;
793                         if (unlikely(IS_ERR(skb))) {
794                                 err = PTR_ERR(skb);
795                                 goto err;
796                         }
797                 } else {
798                         /* XXX This case might not be possible.  It's hard to
799                          * tell from the skb_gso_segment() code and comment. */
800                 }
801         }
802
803         err = queue_control_packets(skb, queue, queue_no, arg);
804         wake_up_interruptible(&dp->waitqueue);
805         return err;
806
807 err_kfree_skb:
808         kfree_skb(skb);
809 err:
810         local_bh_disable();
811         stats = per_cpu_ptr(dp->stats_percpu, smp_processor_id());
812         stats->n_lost++;
813         local_bh_enable();
814
815         return err;
816 }
817
818 static int flush_flows(struct datapath *dp)
819 {
820         struct tbl *old_table = rcu_dereference(dp->table);
821         struct tbl *new_table;
822
823         new_table = tbl_create(0);
824         if (!new_table)
825                 return -ENOMEM;
826
827         rcu_assign_pointer(dp->table, new_table);
828
829         tbl_deferred_destroy(old_table, flow_free_tbl);
830
831         return 0;
832 }
833
834 static int validate_actions(const struct sw_flow_actions *actions)
835 {
836         unsigned int i;
837
838         for (i = 0; i < actions->n_actions; i++) {
839                 const union odp_action *a = &actions->actions[i];
840                 switch (a->type) {
841                 case ODPAT_OUTPUT:
842                         if (a->output.port >= DP_MAX_PORTS)
843                                 return -EINVAL;
844                         break;
845
846                 case ODPAT_OUTPUT_GROUP:
847                         if (a->output_group.group >= DP_MAX_GROUPS)
848                                 return -EINVAL;
849                         break;
850
851                 case ODPAT_SET_VLAN_VID:
852                         if (a->vlan_vid.vlan_vid & htons(~VLAN_VID_MASK))
853                                 return -EINVAL;
854                         break;
855
856                 case ODPAT_SET_VLAN_PCP:
857                         if (a->vlan_pcp.vlan_pcp
858                             & ~(VLAN_PCP_MASK >> VLAN_PCP_SHIFT))
859                                 return -EINVAL;
860                         break;
861
862                 case ODPAT_SET_NW_TOS:
863                         if (a->nw_tos.nw_tos & INET_ECN_MASK)
864                                 return -EINVAL;
865                         break;
866
867                 default:
868                         if (a->type >= ODPAT_N_ACTIONS)
869                                 return -EOPNOTSUPP;
870                         break;
871                 }
872         }
873
874         return 0;
875 }
876
877 static struct sw_flow_actions *get_actions(const struct odp_flow *flow)
878 {
879         struct sw_flow_actions *actions;
880         int error;
881
882         actions = flow_actions_alloc(flow->n_actions);
883         error = PTR_ERR(actions);
884         if (IS_ERR(actions))
885                 goto error;
886
887         error = -EFAULT;
888         if (copy_from_user(actions->actions, flow->actions,
889                            flow->n_actions * sizeof(union odp_action)))
890                 goto error_free_actions;
891         error = validate_actions(actions);
892         if (error)
893                 goto error_free_actions;
894
895         return actions;
896
897 error_free_actions:
898         kfree(actions);
899 error:
900         return ERR_PTR(error);
901 }
902
903 static struct timespec get_time_offset(void)
904 {
905         struct timespec now_mono, now_jiffies;
906
907         ktime_get_ts(&now_mono);
908         jiffies_to_timespec(jiffies, &now_jiffies);
909         return timespec_sub(now_mono, now_jiffies);
910 }
911
912 static void get_stats(struct sw_flow *flow, struct odp_flow_stats *stats,
913                       struct timespec time_offset)
914 {
915         if (flow->used) {
916                 struct timespec flow_ts, used;
917
918                 jiffies_to_timespec(flow->used, &flow_ts);
919                 set_normalized_timespec(&used, flow_ts.tv_sec + time_offset.tv_sec,
920                                         flow_ts.tv_nsec + time_offset.tv_nsec);
921
922                 stats->used_sec = used.tv_sec;
923                 stats->used_nsec = used.tv_nsec;
924         } else {
925                 stats->used_sec = 0;
926                 stats->used_nsec = 0;
927         }
928
929         stats->n_packets = flow->packet_count;
930         stats->n_bytes = flow->byte_count;
931         stats->ip_tos = flow->ip_tos;
932         stats->tcp_flags = flow->tcp_flags;
933         stats->error = 0;
934 }
935
936 static void clear_stats(struct sw_flow *flow)
937 {
938         flow->used = 0;
939         flow->tcp_flags = 0;
940         flow->ip_tos = 0;
941         flow->packet_count = 0;
942         flow->byte_count = 0;
943 }
944
945 static int expand_table(struct datapath *dp)
946 {
947         struct tbl *old_table = rcu_dereference(dp->table);
948         struct tbl *new_table;
949
950         new_table = tbl_expand(old_table);
951         if (IS_ERR(new_table))
952                 return PTR_ERR(new_table);
953
954         rcu_assign_pointer(dp->table, new_table);
955         tbl_deferred_destroy(old_table, NULL);
956
957         return 0;
958 }
959
960 static int do_put_flow(struct datapath *dp, struct odp_flow_put *uf,
961                        struct odp_flow_stats *stats)
962 {
963         struct tbl_node *flow_node;
964         struct sw_flow *flow;
965         struct tbl *table;
966         int error;
967
968         memset(uf->flow.key.reserved, 0, sizeof uf->flow.key.reserved);
969
970         table = rcu_dereference(dp->table);
971         flow_node = tbl_lookup(table, &uf->flow.key, flow_hash(&uf->flow.key), flow_cmp);
972         if (!flow_node) {
973                 /* No such flow. */
974                 struct sw_flow_actions *acts;
975
976                 error = -ENOENT;
977                 if (!(uf->flags & ODPPF_CREATE))
978                         goto error;
979
980                 /* Expand table, if necessary, to make room. */
981                 if (tbl_count(table) >= tbl_n_buckets(table)) {
982                         error = expand_table(dp);
983                         if (error)
984                                 goto error;
985                         table = rcu_dereference(dp->table);
986                 }
987
988                 /* Allocate flow. */
989                 error = -ENOMEM;
990                 flow = kmem_cache_alloc(flow_cache, GFP_KERNEL);
991                 if (flow == NULL)
992                         goto error;
993                 flow->key = uf->flow.key;
994                 spin_lock_init(&flow->lock);
995                 clear_stats(flow);
996
997                 /* Obtain actions. */
998                 acts = get_actions(&uf->flow);
999                 error = PTR_ERR(acts);
1000                 if (IS_ERR(acts))
1001                         goto error_free_flow;
1002                 rcu_assign_pointer(flow->sf_acts, acts);
1003
1004                 /* Put flow in bucket. */
1005                 error = tbl_insert(table, &flow->tbl_node, flow_hash(&flow->key));
1006                 if (error)
1007                         goto error_free_flow_acts;
1008
1009                 memset(stats, 0, sizeof(struct odp_flow_stats));
1010         } else {
1011                 /* We found a matching flow. */
1012                 struct sw_flow_actions *old_acts, *new_acts;
1013
1014                 flow = flow_cast(flow_node);
1015
1016                 /* Bail out if we're not allowed to modify an existing flow. */
1017                 error = -EEXIST;
1018                 if (!(uf->flags & ODPPF_MODIFY))
1019                         goto error;
1020
1021                 /* Swap actions. */
1022                 new_acts = get_actions(&uf->flow);
1023                 error = PTR_ERR(new_acts);
1024                 if (IS_ERR(new_acts))
1025                         goto error;
1026                 old_acts = rcu_dereference(flow->sf_acts);
1027                 if (old_acts->n_actions != new_acts->n_actions ||
1028                     memcmp(old_acts->actions, new_acts->actions,
1029                            sizeof(union odp_action) * old_acts->n_actions)) {
1030                         rcu_assign_pointer(flow->sf_acts, new_acts);
1031                         flow_deferred_free_acts(old_acts);
1032                 } else {
1033                         kfree(new_acts);
1034                 }
1035
1036                 /* Fetch stats, then clear them if necessary. */
1037                 spin_lock_bh(&flow->lock);
1038                 get_stats(flow, stats, get_time_offset());
1039                 if (uf->flags & ODPPF_ZERO_STATS)
1040                         clear_stats(flow);
1041                 spin_unlock_bh(&flow->lock);
1042         }
1043
1044         return 0;
1045
1046 error_free_flow_acts:
1047         kfree(flow->sf_acts);
1048 error_free_flow:
1049         kmem_cache_free(flow_cache, flow);
1050 error:
1051         return error;
1052 }
1053
1054 static int put_flow(struct datapath *dp, struct odp_flow_put __user *ufp)
1055 {
1056         struct odp_flow_stats stats;
1057         struct odp_flow_put uf;
1058         int error;
1059
1060         if (copy_from_user(&uf, ufp, sizeof(struct odp_flow_put)))
1061                 return -EFAULT;
1062
1063         error = do_put_flow(dp, &uf, &stats);
1064         if (error)
1065                 return error;
1066
1067         if (copy_to_user(&ufp->flow.stats, &stats,
1068                          sizeof(struct odp_flow_stats)))
1069                 return -EFAULT;
1070
1071         return 0;
1072 }
1073
1074 static int do_answer_query(struct sw_flow *flow, u32 query_flags,
1075                            struct timespec time_offset,
1076                            struct odp_flow_stats __user *ustats,
1077                            union odp_action __user *actions,
1078                            u32 __user *n_actionsp)
1079 {
1080         struct sw_flow_actions *sf_acts;
1081         struct odp_flow_stats stats;
1082         u32 n_actions;
1083
1084         spin_lock_bh(&flow->lock);
1085         get_stats(flow, &stats, time_offset);
1086         if (query_flags & ODPFF_ZERO_TCP_FLAGS)
1087                 flow->tcp_flags = 0;
1088
1089         spin_unlock_bh(&flow->lock);
1090
1091         if (copy_to_user(ustats, &stats, sizeof(struct odp_flow_stats)) ||
1092             get_user(n_actions, n_actionsp))
1093                 return -EFAULT;
1094
1095         if (!n_actions)
1096                 return 0;
1097
1098         sf_acts = rcu_dereference(flow->sf_acts);
1099         if (put_user(sf_acts->n_actions, n_actionsp) ||
1100             (actions && copy_to_user(actions, sf_acts->actions,
1101                                      sizeof(union odp_action) *
1102                                      min(sf_acts->n_actions, n_actions))))
1103                 return -EFAULT;
1104
1105         return 0;
1106 }
1107
1108 static int answer_query(struct sw_flow *flow, u32 query_flags,
1109                         struct timespec time_offset,
1110                         struct odp_flow __user *ufp)
1111 {
1112         union odp_action *actions;
1113
1114         if (get_user(actions, &ufp->actions))
1115                 return -EFAULT;
1116
1117         return do_answer_query(flow, query_flags, time_offset,
1118                                &ufp->stats, actions, &ufp->n_actions);
1119 }
1120
1121 static struct sw_flow *do_del_flow(struct datapath *dp, struct odp_flow_key *key)
1122 {
1123         struct tbl *table = rcu_dereference(dp->table);
1124         struct tbl_node *flow_node;
1125         int error;
1126
1127         memset(key->reserved, 0, sizeof key->reserved);
1128         flow_node = tbl_lookup(table, key, flow_hash(key), flow_cmp);
1129         if (!flow_node)
1130                 return ERR_PTR(-ENOENT);
1131
1132         error = tbl_remove(table, flow_node);
1133         if (error)
1134                 return ERR_PTR(error);
1135
1136         /* XXX Returned flow_node's statistics might lose a few packets, since
1137          * other CPUs can be using this flow.  We used to synchronize_rcu() to
1138          * make sure that we get completely accurate stats, but that blows our
1139          * performance, badly. */
1140         return flow_cast(flow_node);
1141 }
1142
1143 static int del_flow(struct datapath *dp, struct odp_flow __user *ufp)
1144 {
1145         struct sw_flow *flow;
1146         struct odp_flow uf;
1147         int error;
1148
1149         if (copy_from_user(&uf, ufp, sizeof uf))
1150                 return -EFAULT;
1151
1152         flow = do_del_flow(dp, &uf.key);
1153         if (IS_ERR(flow))
1154                 return PTR_ERR(flow);
1155
1156         error = answer_query(flow, 0, get_time_offset(), ufp);
1157         flow_deferred_free(flow);
1158         return error;
1159 }
1160
1161 static int do_query_flows(struct datapath *dp, const struct odp_flowvec *flowvec)
1162 {
1163         struct tbl *table = rcu_dereference(dp->table);
1164         struct timespec time_offset;
1165         u32 i;
1166
1167         time_offset = get_time_offset();
1168
1169         for (i = 0; i < flowvec->n_flows; i++) {
1170                 struct odp_flow __user *ufp = &flowvec->flows[i];
1171                 struct odp_flow uf;
1172                 struct tbl_node *flow_node;
1173                 int error;
1174
1175                 if (copy_from_user(&uf, ufp, sizeof uf))
1176                         return -EFAULT;
1177                 memset(uf.key.reserved, 0, sizeof uf.key.reserved);
1178
1179                 flow_node = tbl_lookup(table, &uf.key, flow_hash(&uf.key), flow_cmp);
1180                 if (!flow_node)
1181                         error = put_user(ENOENT, &ufp->stats.error);
1182                 else
1183                         error = answer_query(flow_cast(flow_node), uf.flags, time_offset, ufp);
1184                 if (error)
1185                         return -EFAULT;
1186         }
1187         return flowvec->n_flows;
1188 }
1189
1190 struct list_flows_cbdata {
1191         struct odp_flow __user *uflows;
1192         u32 n_flows;
1193         u32 listed_flows;
1194         struct timespec time_offset;
1195 };
1196
1197 static int list_flow(struct tbl_node *node, void *cbdata_)
1198 {
1199         struct sw_flow *flow = flow_cast(node);
1200         struct list_flows_cbdata *cbdata = cbdata_;
1201         struct odp_flow __user *ufp = &cbdata->uflows[cbdata->listed_flows++];
1202         int error;
1203
1204         if (copy_to_user(&ufp->key, &flow->key, sizeof flow->key))
1205                 return -EFAULT;
1206         error = answer_query(flow, 0, cbdata->time_offset, ufp);
1207         if (error)
1208                 return error;
1209
1210         if (cbdata->listed_flows >= cbdata->n_flows)
1211                 return cbdata->listed_flows;
1212         return 0;
1213 }
1214
1215 static int do_list_flows(struct datapath *dp, const struct odp_flowvec *flowvec)
1216 {
1217         struct list_flows_cbdata cbdata;
1218         int error;
1219
1220         if (!flowvec->n_flows)
1221                 return 0;
1222
1223         cbdata.uflows = flowvec->flows;
1224         cbdata.n_flows = flowvec->n_flows;
1225         cbdata.listed_flows = 0;
1226         cbdata.time_offset = get_time_offset();
1227
1228         error = tbl_foreach(rcu_dereference(dp->table), list_flow, &cbdata);
1229         return error ? error : cbdata.listed_flows;
1230 }
1231
1232 static int do_flowvec_ioctl(struct datapath *dp, unsigned long argp,
1233                             int (*function)(struct datapath *,
1234                                             const struct odp_flowvec *))
1235 {
1236         struct odp_flowvec __user *uflowvec;
1237         struct odp_flowvec flowvec;
1238         int retval;
1239
1240         uflowvec = (struct odp_flowvec __user *)argp;
1241         if (copy_from_user(&flowvec, uflowvec, sizeof flowvec))
1242                 return -EFAULT;
1243
1244         if (flowvec.n_flows > INT_MAX / sizeof(struct odp_flow))
1245                 return -EINVAL;
1246
1247         retval = function(dp, &flowvec);
1248         return (retval < 0 ? retval
1249                 : retval == flowvec.n_flows ? 0
1250                 : put_user(retval, &uflowvec->n_flows));
1251 }
1252
1253 static int do_execute(struct datapath *dp, const struct odp_execute *execute)
1254 {
1255         struct odp_flow_key key;
1256         struct sk_buff *skb;
1257         struct sw_flow_actions *actions;
1258         struct ethhdr *eth;
1259         int err;
1260
1261         err = -EINVAL;
1262         if (execute->length < ETH_HLEN || execute->length > 65535)
1263                 goto error;
1264
1265         err = -ENOMEM;
1266         actions = flow_actions_alloc(execute->n_actions);
1267         if (!actions)
1268                 goto error;
1269
1270         err = -EFAULT;
1271         if (copy_from_user(actions->actions, execute->actions,
1272                            execute->n_actions * sizeof *execute->actions))
1273                 goto error_free_actions;
1274
1275         err = validate_actions(actions);
1276         if (err)
1277                 goto error_free_actions;
1278
1279         err = -ENOMEM;
1280         skb = alloc_skb(execute->length, GFP_KERNEL);
1281         if (!skb)
1282                 goto error_free_actions;
1283
1284         if (execute->in_port < DP_MAX_PORTS)
1285                 OVS_CB(skb)->dp_port = dp->ports[execute->in_port];
1286         else
1287                 OVS_CB(skb)->dp_port = NULL;
1288
1289         err = -EFAULT;
1290         if (copy_from_user(skb_put(skb, execute->length), execute->data,
1291                            execute->length))
1292                 goto error_free_skb;
1293
1294         skb_reset_mac_header(skb);
1295         eth = eth_hdr(skb);
1296
1297         /* Normally, setting the skb 'protocol' field would be handled by a
1298          * call to eth_type_trans(), but it assumes there's a sending
1299          * device, which we may not have. */
1300         if (ntohs(eth->h_proto) >= 1536)
1301                 skb->protocol = eth->h_proto;
1302         else
1303                 skb->protocol = htons(ETH_P_802_2);
1304
1305         flow_extract(skb, execute->in_port, &key);
1306
1307         rcu_read_lock();
1308         err = execute_actions(dp, skb, &key, actions->actions,
1309                               actions->n_actions, GFP_KERNEL);
1310         rcu_read_unlock();
1311
1312         kfree(actions);
1313         return err;
1314
1315 error_free_skb:
1316         kfree_skb(skb);
1317 error_free_actions:
1318         kfree(actions);
1319 error:
1320         return err;
1321 }
1322
1323 static int execute_packet(struct datapath *dp, const struct odp_execute __user *executep)
1324 {
1325         struct odp_execute execute;
1326
1327         if (copy_from_user(&execute, executep, sizeof execute))
1328                 return -EFAULT;
1329
1330         return do_execute(dp, &execute);
1331 }
1332
1333 static int get_dp_stats(struct datapath *dp, struct odp_stats __user *statsp)
1334 {
1335         struct tbl *table = rcu_dereference(dp->table);
1336         struct odp_stats stats;
1337         int i;
1338
1339         stats.n_flows = tbl_count(table);
1340         stats.cur_capacity = tbl_n_buckets(table);
1341         stats.max_capacity = TBL_MAX_BUCKETS;
1342         stats.n_ports = dp->n_ports;
1343         stats.max_ports = DP_MAX_PORTS;
1344         stats.max_groups = DP_MAX_GROUPS;
1345         stats.n_frags = stats.n_hit = stats.n_missed = stats.n_lost = 0;
1346         for_each_possible_cpu(i) {
1347                 const struct dp_stats_percpu *s;
1348                 s = per_cpu_ptr(dp->stats_percpu, i);
1349                 stats.n_frags += s->n_frags;
1350                 stats.n_hit += s->n_hit;
1351                 stats.n_missed += s->n_missed;
1352                 stats.n_lost += s->n_lost;
1353         }
1354         stats.max_miss_queue = DP_MAX_QUEUE_LEN;
1355         stats.max_action_queue = DP_MAX_QUEUE_LEN;
1356         return copy_to_user(statsp, &stats, sizeof stats) ? -EFAULT : 0;
1357 }
1358
1359 /* MTU of the dp pseudo-device: ETH_DATA_LEN or the minimum of the ports */
1360 int dp_min_mtu(const struct datapath *dp)
1361 {
1362         struct dp_port *p;
1363         int mtu = 0;
1364
1365         ASSERT_RTNL();
1366
1367         list_for_each_entry_rcu (p, &dp->port_list, node) {
1368                 int dev_mtu;
1369
1370                 /* Skip any internal ports, since that's what we're trying to
1371                  * set. */
1372                 if (is_internal_vport(p->vport))
1373                         continue;
1374
1375                 dev_mtu = vport_get_mtu(p->vport);
1376                 if (!mtu || dev_mtu < mtu)
1377                         mtu = dev_mtu;
1378         }
1379
1380         return mtu ? mtu : ETH_DATA_LEN;
1381 }
1382
1383 /* Sets the MTU of all datapath devices to the minimum of the ports.  Must
1384  * be called with RTNL lock. */
1385 void set_internal_devs_mtu(const struct datapath *dp)
1386 {
1387         struct dp_port *p;
1388         int mtu;
1389
1390         ASSERT_RTNL();
1391
1392         mtu = dp_min_mtu(dp);
1393
1394         list_for_each_entry_rcu (p, &dp->port_list, node) {
1395                 if (is_internal_vport(p->vport))
1396                         vport_set_mtu(p->vport, mtu);
1397         }
1398 }
1399
1400 static int put_port(const struct dp_port *p, struct odp_port __user *uop)
1401 {
1402         struct odp_port op;
1403
1404         memset(&op, 0, sizeof op);
1405
1406         rcu_read_lock();
1407         strncpy(op.devname, vport_get_name(p->vport), sizeof op.devname);
1408         rcu_read_unlock();
1409
1410         op.port = p->port_no;
1411         op.flags = is_internal_vport(p->vport) ? ODP_PORT_INTERNAL : 0;
1412
1413         return copy_to_user(uop, &op, sizeof op) ? -EFAULT : 0;
1414 }
1415
1416 static int query_port(struct datapath *dp, struct odp_port __user *uport)
1417 {
1418         struct odp_port port;
1419
1420         if (copy_from_user(&port, uport, sizeof port))
1421                 return -EFAULT;
1422
1423         if (port.devname[0]) {
1424                 struct vport *vport;
1425                 struct dp_port *dp_port;
1426                 int err = 0;
1427
1428                 port.devname[IFNAMSIZ - 1] = '\0';
1429
1430                 vport_lock();
1431                 rcu_read_lock();
1432
1433                 vport = vport_locate(port.devname);
1434                 if (!vport) {
1435                         err = -ENODEV;
1436                         goto error_unlock;
1437                 }
1438
1439                 dp_port = vport_get_dp_port(vport);
1440                 if (!dp_port || dp_port->dp != dp) {
1441                         err = -ENOENT;
1442                         goto error_unlock;
1443                 }
1444
1445                 port.port = dp_port->port_no;
1446
1447 error_unlock:
1448                 rcu_read_unlock();
1449                 vport_unlock();
1450
1451                 if (err)
1452                         return err;
1453         } else {
1454                 if (port.port >= DP_MAX_PORTS)
1455                         return -EINVAL;
1456                 if (!dp->ports[port.port])
1457                         return -ENOENT;
1458         }
1459
1460         return put_port(dp->ports[port.port], uport);
1461 }
1462
1463 static int do_list_ports(struct datapath *dp, struct odp_port __user *uports,
1464                          int n_ports)
1465 {
1466         int idx = 0;
1467         if (n_ports) {
1468                 struct dp_port *p;
1469
1470                 list_for_each_entry_rcu (p, &dp->port_list, node) {
1471                         if (put_port(p, &uports[idx]))
1472                                 return -EFAULT;
1473                         if (idx++ >= n_ports)
1474                                 break;
1475                 }
1476         }
1477         return idx;
1478 }
1479
1480 static int list_ports(struct datapath *dp, struct odp_portvec __user *upv)
1481 {
1482         struct odp_portvec pv;
1483         int retval;
1484
1485         if (copy_from_user(&pv, upv, sizeof pv))
1486                 return -EFAULT;
1487
1488         retval = do_list_ports(dp, pv.ports, pv.n_ports);
1489         if (retval < 0)
1490                 return retval;
1491
1492         return put_user(retval, &upv->n_ports);
1493 }
1494
1495 /* RCU callback for freeing a dp_port_group */
1496 static void free_port_group(struct rcu_head *rcu)
1497 {
1498         struct dp_port_group *g = container_of(rcu, struct dp_port_group, rcu);
1499         kfree(g);
1500 }
1501
1502 static int do_set_port_group(struct datapath *dp, u16 __user *ports,
1503                              int n_ports, int group)
1504 {
1505         struct dp_port_group *new_group, *old_group;
1506         int error;
1507
1508         error = -EINVAL;
1509         if (n_ports > DP_MAX_PORTS || group >= DP_MAX_GROUPS)
1510                 goto error;
1511
1512         error = -ENOMEM;
1513         new_group = kmalloc(sizeof *new_group + sizeof(u16) * n_ports, GFP_KERNEL);
1514         if (!new_group)
1515                 goto error;
1516
1517         new_group->n_ports = n_ports;
1518         error = -EFAULT;
1519         if (copy_from_user(new_group->ports, ports, sizeof(u16) * n_ports))
1520                 goto error_free;
1521
1522         old_group = rcu_dereference(dp->groups[group]);
1523         rcu_assign_pointer(dp->groups[group], new_group);
1524         if (old_group)
1525                 call_rcu(&old_group->rcu, free_port_group);
1526         return 0;
1527
1528 error_free:
1529         kfree(new_group);
1530 error:
1531         return error;
1532 }
1533
1534 static int set_port_group(struct datapath *dp,
1535                           const struct odp_port_group __user *upg)
1536 {
1537         struct odp_port_group pg;
1538
1539         if (copy_from_user(&pg, upg, sizeof pg))
1540                 return -EFAULT;
1541
1542         return do_set_port_group(dp, pg.ports, pg.n_ports, pg.group);
1543 }
1544
1545 static int do_get_port_group(struct datapath *dp,
1546                              u16 __user *ports, int n_ports, int group,
1547                              u16 __user *n_portsp)
1548 {
1549         struct dp_port_group *g;
1550         u16 n_copy;
1551
1552         if (group >= DP_MAX_GROUPS)
1553                 return -EINVAL;
1554
1555         g = dp->groups[group];
1556         n_copy = g ? min_t(int, g->n_ports, n_ports) : 0;
1557         if (n_copy && copy_to_user(ports, g->ports, n_copy * sizeof(u16)))
1558                 return -EFAULT;
1559
1560         if (put_user(g ? g->n_ports : 0, n_portsp))
1561                 return -EFAULT;
1562
1563         return 0;
1564 }
1565
1566 static int get_port_group(struct datapath *dp, struct odp_port_group __user *upg)
1567 {
1568         struct odp_port_group pg;
1569
1570         if (copy_from_user(&pg, upg, sizeof pg))
1571                 return -EFAULT;
1572
1573         return do_get_port_group(dp, pg.ports, pg.n_ports, pg.group, &upg->n_ports);
1574 }
1575
1576 static int get_listen_mask(const struct file *f)
1577 {
1578         return (long)f->private_data;
1579 }
1580
1581 static void set_listen_mask(struct file *f, int listen_mask)
1582 {
1583         f->private_data = (void*)(long)listen_mask;
1584 }
1585
1586 static long openvswitch_ioctl(struct file *f, unsigned int cmd,
1587                            unsigned long argp)
1588 {
1589         int dp_idx = iminor(f->f_dentry->d_inode);
1590         struct datapath *dp;
1591         int drop_frags, listeners, port_no;
1592         unsigned int sflow_probability;
1593         int err;
1594
1595         /* Handle commands with special locking requirements up front. */
1596         switch (cmd) {
1597         case ODP_DP_CREATE:
1598                 err = create_dp(dp_idx, (char __user *)argp);
1599                 goto exit;
1600
1601         case ODP_DP_DESTROY:
1602                 err = destroy_dp(dp_idx);
1603                 goto exit;
1604
1605         case ODP_PORT_ATTACH:
1606                 err = attach_port(dp_idx, (struct odp_port __user *)argp);
1607                 goto exit;
1608
1609         case ODP_PORT_DETACH:
1610                 err = get_user(port_no, (int __user *)argp);
1611                 if (!err)
1612                         err = detach_port(dp_idx, port_no);
1613                 goto exit;
1614
1615         case ODP_VPORT_ADD:
1616                 err = vport_user_add((struct odp_vport_add __user *)argp);
1617                 goto exit;
1618
1619         case ODP_VPORT_MOD:
1620                 err = vport_user_mod((struct odp_vport_mod __user *)argp);
1621                 goto exit;
1622
1623         case ODP_VPORT_DEL:
1624                 err = vport_user_del((char __user *)argp);
1625                 goto exit;
1626
1627         case ODP_VPORT_STATS_GET:
1628                 err = vport_user_stats_get((struct odp_vport_stats_req __user *)argp);
1629                 goto exit;
1630
1631         case ODP_VPORT_STATS_SET:
1632                 err = vport_user_stats_set((struct odp_vport_stats_req __user *)argp);
1633                 goto exit;
1634
1635         case ODP_VPORT_ETHER_GET:
1636                 err = vport_user_ether_get((struct odp_vport_ether __user *)argp);
1637                 goto exit;
1638
1639         case ODP_VPORT_ETHER_SET:
1640                 err = vport_user_ether_set((struct odp_vport_ether __user *)argp);
1641                 goto exit;
1642
1643         case ODP_VPORT_MTU_GET:
1644                 err = vport_user_mtu_get((struct odp_vport_mtu __user *)argp);
1645                 goto exit;
1646
1647         case ODP_VPORT_MTU_SET:
1648                 err = vport_user_mtu_set((struct odp_vport_mtu __user *)argp);
1649                 goto exit;
1650         }
1651
1652         dp = get_dp_locked(dp_idx);
1653         err = -ENODEV;
1654         if (!dp)
1655                 goto exit;
1656
1657         switch (cmd) {
1658         case ODP_DP_STATS:
1659                 err = get_dp_stats(dp, (struct odp_stats __user *)argp);
1660                 break;
1661
1662         case ODP_GET_DROP_FRAGS:
1663                 err = put_user(dp->drop_frags, (int __user *)argp);
1664                 break;
1665
1666         case ODP_SET_DROP_FRAGS:
1667                 err = get_user(drop_frags, (int __user *)argp);
1668                 if (err)
1669                         break;
1670                 err = -EINVAL;
1671                 if (drop_frags != 0 && drop_frags != 1)
1672                         break;
1673                 dp->drop_frags = drop_frags;
1674                 err = 0;
1675                 break;
1676
1677         case ODP_GET_LISTEN_MASK:
1678                 err = put_user(get_listen_mask(f), (int __user *)argp);
1679                 break;
1680
1681         case ODP_SET_LISTEN_MASK:
1682                 err = get_user(listeners, (int __user *)argp);
1683                 if (err)
1684                         break;
1685                 err = -EINVAL;
1686                 if (listeners & ~ODPL_ALL)
1687                         break;
1688                 err = 0;
1689                 set_listen_mask(f, listeners);
1690                 break;
1691
1692         case ODP_GET_SFLOW_PROBABILITY:
1693                 err = put_user(dp->sflow_probability, (unsigned int __user *)argp);
1694                 break;
1695
1696         case ODP_SET_SFLOW_PROBABILITY:
1697                 err = get_user(sflow_probability, (unsigned int __user *)argp);
1698                 if (!err)
1699                         dp->sflow_probability = sflow_probability;
1700                 break;
1701
1702         case ODP_PORT_QUERY:
1703                 err = query_port(dp, (struct odp_port __user *)argp);
1704                 break;
1705
1706         case ODP_PORT_LIST:
1707                 err = list_ports(dp, (struct odp_portvec __user *)argp);
1708                 break;
1709
1710         case ODP_PORT_GROUP_SET:
1711                 err = set_port_group(dp, (struct odp_port_group __user *)argp);
1712                 break;
1713
1714         case ODP_PORT_GROUP_GET:
1715                 err = get_port_group(dp, (struct odp_port_group __user *)argp);
1716                 break;
1717
1718         case ODP_FLOW_FLUSH:
1719                 err = flush_flows(dp);
1720                 break;
1721
1722         case ODP_FLOW_PUT:
1723                 err = put_flow(dp, (struct odp_flow_put __user *)argp);
1724                 break;
1725
1726         case ODP_FLOW_DEL:
1727                 err = del_flow(dp, (struct odp_flow __user *)argp);
1728                 break;
1729
1730         case ODP_FLOW_GET:
1731                 err = do_flowvec_ioctl(dp, argp, do_query_flows);
1732                 break;
1733
1734         case ODP_FLOW_LIST:
1735                 err = do_flowvec_ioctl(dp, argp, do_list_flows);
1736                 break;
1737
1738         case ODP_EXECUTE:
1739                 err = execute_packet(dp, (struct odp_execute __user *)argp);
1740                 break;
1741
1742         default:
1743                 err = -ENOIOCTLCMD;
1744                 break;
1745         }
1746         mutex_unlock(&dp->mutex);
1747 exit:
1748         return err;
1749 }
1750
1751 static int dp_has_packet_of_interest(struct datapath *dp, int listeners)
1752 {
1753         int i;
1754         for (i = 0; i < DP_N_QUEUES; i++) {
1755                 if (listeners & (1 << i) && !skb_queue_empty(&dp->queues[i]))
1756                         return 1;
1757         }
1758         return 0;
1759 }
1760
1761 #ifdef CONFIG_COMPAT
1762 static int compat_list_ports(struct datapath *dp, struct compat_odp_portvec __user *upv)
1763 {
1764         struct compat_odp_portvec pv;
1765         int retval;
1766
1767         if (copy_from_user(&pv, upv, sizeof pv))
1768                 return -EFAULT;
1769
1770         retval = do_list_ports(dp, compat_ptr(pv.ports), pv.n_ports);
1771         if (retval < 0)
1772                 return retval;
1773
1774         return put_user(retval, &upv->n_ports);
1775 }
1776
1777 static int compat_set_port_group(struct datapath *dp, const struct compat_odp_port_group __user *upg)
1778 {
1779         struct compat_odp_port_group pg;
1780
1781         if (copy_from_user(&pg, upg, sizeof pg))
1782                 return -EFAULT;
1783
1784         return do_set_port_group(dp, compat_ptr(pg.ports), pg.n_ports, pg.group);
1785 }
1786
1787 static int compat_get_port_group(struct datapath *dp, struct compat_odp_port_group __user *upg)
1788 {
1789         struct compat_odp_port_group pg;
1790
1791         if (copy_from_user(&pg, upg, sizeof pg))
1792                 return -EFAULT;
1793
1794         return do_get_port_group(dp, compat_ptr(pg.ports), pg.n_ports,
1795                                  pg.group, &upg->n_ports);
1796 }
1797
1798 static int compat_get_flow(struct odp_flow *flow, const struct compat_odp_flow __user *compat)
1799 {
1800         compat_uptr_t actions;
1801
1802         if (!access_ok(VERIFY_READ, compat, sizeof(struct compat_odp_flow)) ||
1803             __copy_from_user(&flow->stats, &compat->stats, sizeof(struct odp_flow_stats)) ||
1804             __copy_from_user(&flow->key, &compat->key, sizeof(struct odp_flow_key)) ||
1805             __get_user(actions, &compat->actions) ||
1806             __get_user(flow->n_actions, &compat->n_actions) ||
1807             __get_user(flow->flags, &compat->flags))
1808                 return -EFAULT;
1809
1810         flow->actions = compat_ptr(actions);
1811         return 0;
1812 }
1813
1814 static int compat_put_flow(struct datapath *dp, struct compat_odp_flow_put __user *ufp)
1815 {
1816         struct odp_flow_stats stats;
1817         struct odp_flow_put fp;
1818         int error;
1819
1820         if (compat_get_flow(&fp.flow, &ufp->flow) ||
1821             get_user(fp.flags, &ufp->flags))
1822                 return -EFAULT;
1823
1824         error = do_put_flow(dp, &fp, &stats);
1825         if (error)
1826                 return error;
1827
1828         if (copy_to_user(&ufp->flow.stats, &stats,
1829                          sizeof(struct odp_flow_stats)))
1830                 return -EFAULT;
1831
1832         return 0;
1833 }
1834
1835 static int compat_answer_query(struct sw_flow *flow, u32 query_flags,
1836                                struct timespec time_offset,
1837                                struct compat_odp_flow __user *ufp)
1838 {
1839         compat_uptr_t actions;
1840
1841         if (get_user(actions, &ufp->actions))
1842                 return -EFAULT;
1843
1844         return do_answer_query(flow, query_flags, time_offset, &ufp->stats,
1845                                compat_ptr(actions), &ufp->n_actions);
1846 }
1847
1848 static int compat_del_flow(struct datapath *dp, struct compat_odp_flow __user *ufp)
1849 {
1850         struct sw_flow *flow;
1851         struct odp_flow uf;
1852         int error;
1853
1854         if (compat_get_flow(&uf, ufp))
1855                 return -EFAULT;
1856
1857         flow = do_del_flow(dp, &uf.key);
1858         if (IS_ERR(flow))
1859                 return PTR_ERR(flow);
1860
1861         error = compat_answer_query(flow, 0, get_time_offset(), ufp);
1862         flow_deferred_free(flow);
1863         return error;
1864 }
1865
1866 static int compat_query_flows(struct datapath *dp, struct compat_odp_flow *flows, u32 n_flows)
1867 {
1868         struct tbl *table = rcu_dereference(dp->table);
1869         struct timespec time_offset;
1870         u32 i;
1871
1872         time_offset = get_time_offset();
1873
1874         for (i = 0; i < n_flows; i++) {
1875                 struct compat_odp_flow __user *ufp = &flows[i];
1876                 struct odp_flow uf;
1877                 struct tbl_node *flow_node;
1878                 int error;
1879
1880                 if (compat_get_flow(&uf, ufp))
1881                         return -EFAULT;
1882                 memset(uf.key.reserved, 0, sizeof uf.key.reserved);
1883
1884                 flow_node = tbl_lookup(table, &uf.key, flow_hash(&uf.key), flow_cmp);
1885                 if (!flow_node)
1886                         error = put_user(ENOENT, &ufp->stats.error);
1887                 else
1888                         error = compat_answer_query(flow_cast(flow_node), uf.flags, time_offset, ufp);
1889                 if (error)
1890                         return -EFAULT;
1891         }
1892         return n_flows;
1893 }
1894
1895 struct compat_list_flows_cbdata {
1896         struct compat_odp_flow __user *uflows;
1897         u32 n_flows;
1898         u32 listed_flows;
1899         struct timespec time_offset;
1900 };
1901
1902 static int compat_list_flow(struct tbl_node *node, void *cbdata_)
1903 {
1904         struct sw_flow *flow = flow_cast(node);
1905         struct compat_list_flows_cbdata *cbdata = cbdata_;
1906         struct compat_odp_flow __user *ufp = &cbdata->uflows[cbdata->listed_flows++];
1907         int error;
1908
1909         if (copy_to_user(&ufp->key, &flow->key, sizeof flow->key))
1910                 return -EFAULT;
1911         error = compat_answer_query(flow, 0, cbdata->time_offset, ufp);
1912         if (error)
1913                 return error;
1914
1915         if (cbdata->listed_flows >= cbdata->n_flows)
1916                 return cbdata->listed_flows;
1917         return 0;
1918 }
1919
1920 static int compat_list_flows(struct datapath *dp, struct compat_odp_flow *flows, u32 n_flows)
1921 {
1922         struct compat_list_flows_cbdata cbdata;
1923         int error;
1924
1925         if (!n_flows)
1926                 return 0;
1927
1928         cbdata.uflows = flows;
1929         cbdata.n_flows = n_flows;
1930         cbdata.listed_flows = 0;
1931         cbdata.time_offset = get_time_offset();
1932
1933         error = tbl_foreach(rcu_dereference(dp->table), compat_list_flow, &cbdata);
1934         return error ? error : cbdata.listed_flows;
1935 }
1936
1937 static int compat_flowvec_ioctl(struct datapath *dp, unsigned long argp,
1938                                 int (*function)(struct datapath *,
1939                                                 struct compat_odp_flow *,
1940                                                 u32 n_flows))
1941 {
1942         struct compat_odp_flowvec __user *uflowvec;
1943         struct compat_odp_flow __user *flows;
1944         struct compat_odp_flowvec flowvec;
1945         int retval;
1946
1947         uflowvec = compat_ptr(argp);
1948         if (!access_ok(VERIFY_WRITE, uflowvec, sizeof *uflowvec) ||
1949             copy_from_user(&flowvec, uflowvec, sizeof flowvec))
1950                 return -EFAULT;
1951
1952         if (flowvec.n_flows > INT_MAX / sizeof(struct compat_odp_flow))
1953                 return -EINVAL;
1954
1955         flows = compat_ptr(flowvec.flows);
1956         if (!access_ok(VERIFY_WRITE, flows,
1957                        flowvec.n_flows * sizeof(struct compat_odp_flow)))
1958                 return -EFAULT;
1959
1960         retval = function(dp, flows, flowvec.n_flows);
1961         return (retval < 0 ? retval
1962                 : retval == flowvec.n_flows ? 0
1963                 : put_user(retval, &uflowvec->n_flows));
1964 }
1965
1966 static int compat_execute(struct datapath *dp, const struct compat_odp_execute __user *uexecute)
1967 {
1968         struct odp_execute execute;
1969         compat_uptr_t actions;
1970         compat_uptr_t data;
1971
1972         if (!access_ok(VERIFY_READ, uexecute, sizeof(struct compat_odp_execute)) ||
1973             __get_user(execute.in_port, &uexecute->in_port) ||
1974             __get_user(actions, &uexecute->actions) ||
1975             __get_user(execute.n_actions, &uexecute->n_actions) ||
1976             __get_user(data, &uexecute->data) ||
1977             __get_user(execute.length, &uexecute->length))
1978                 return -EFAULT;
1979
1980         execute.actions = compat_ptr(actions);
1981         execute.data = compat_ptr(data);
1982
1983         return do_execute(dp, &execute);
1984 }
1985
1986 static long openvswitch_compat_ioctl(struct file *f, unsigned int cmd, unsigned long argp)
1987 {
1988         int dp_idx = iminor(f->f_dentry->d_inode);
1989         struct datapath *dp;
1990         int err;
1991
1992         switch (cmd) {
1993         case ODP_DP_DESTROY:
1994         case ODP_FLOW_FLUSH:
1995                 /* Ioctls that don't need any translation at all. */
1996                 return openvswitch_ioctl(f, cmd, argp);
1997
1998         case ODP_DP_CREATE:
1999         case ODP_PORT_ATTACH:
2000         case ODP_PORT_DETACH:
2001         case ODP_VPORT_DEL:
2002         case ODP_VPORT_MTU_SET:
2003         case ODP_VPORT_MTU_GET:
2004         case ODP_VPORT_ETHER_SET:
2005         case ODP_VPORT_ETHER_GET:
2006         case ODP_VPORT_STATS_SET:
2007         case ODP_VPORT_STATS_GET:
2008         case ODP_DP_STATS:
2009         case ODP_GET_DROP_FRAGS:
2010         case ODP_SET_DROP_FRAGS:
2011         case ODP_SET_LISTEN_MASK:
2012         case ODP_GET_LISTEN_MASK:
2013         case ODP_SET_SFLOW_PROBABILITY:
2014         case ODP_GET_SFLOW_PROBABILITY:
2015         case ODP_PORT_QUERY:
2016                 /* Ioctls that just need their pointer argument extended. */
2017                 return openvswitch_ioctl(f, cmd, (unsigned long)compat_ptr(argp));
2018
2019         case ODP_VPORT_ADD32:
2020                 return compat_vport_user_add(compat_ptr(argp));
2021
2022         case ODP_VPORT_MOD32:
2023                 return compat_vport_user_mod(compat_ptr(argp));
2024         }
2025
2026         dp = get_dp_locked(dp_idx);
2027         err = -ENODEV;
2028         if (!dp)
2029                 goto exit;
2030
2031         switch (cmd) {
2032         case ODP_PORT_LIST32:
2033                 err = compat_list_ports(dp, compat_ptr(argp));
2034                 break;
2035
2036         case ODP_PORT_GROUP_SET32:
2037                 err = compat_set_port_group(dp, compat_ptr(argp));
2038                 break;
2039
2040         case ODP_PORT_GROUP_GET32:
2041                 err = compat_get_port_group(dp, compat_ptr(argp));
2042                 break;
2043
2044         case ODP_FLOW_PUT32:
2045                 err = compat_put_flow(dp, compat_ptr(argp));
2046                 break;
2047
2048         case ODP_FLOW_DEL32:
2049                 err = compat_del_flow(dp, compat_ptr(argp));
2050                 break;
2051
2052         case ODP_FLOW_GET32:
2053                 err = compat_flowvec_ioctl(dp, argp, compat_query_flows);
2054                 break;
2055
2056         case ODP_FLOW_LIST32:
2057                 err = compat_flowvec_ioctl(dp, argp, compat_list_flows);
2058                 break;
2059
2060         case ODP_EXECUTE32:
2061                 err = compat_execute(dp, compat_ptr(argp));
2062                 break;
2063
2064         default:
2065                 err = -ENOIOCTLCMD;
2066                 break;
2067         }
2068         mutex_unlock(&dp->mutex);
2069 exit:
2070         return err;
2071 }
2072 #endif
2073
2074 /* Unfortunately this function is not exported so this is a verbatim copy
2075  * from net/core/datagram.c in 2.6.30. */
2076 static int skb_copy_and_csum_datagram(const struct sk_buff *skb, int offset,
2077                                       u8 __user *to, int len,
2078                                       __wsum *csump)
2079 {
2080         int start = skb_headlen(skb);
2081         int pos = 0;
2082         int i, copy = start - offset;
2083
2084         /* Copy header. */
2085         if (copy > 0) {
2086                 int err = 0;
2087                 if (copy > len)
2088                         copy = len;
2089                 *csump = csum_and_copy_to_user(skb->data + offset, to, copy,
2090                                                *csump, &err);
2091                 if (err)
2092                         goto fault;
2093                 if ((len -= copy) == 0)
2094                         return 0;
2095                 offset += copy;
2096                 to += copy;
2097                 pos = copy;
2098         }
2099
2100         for (i = 0; i < skb_shinfo(skb)->nr_frags; i++) {
2101                 int end;
2102
2103                 WARN_ON(start > offset + len);
2104
2105                 end = start + skb_shinfo(skb)->frags[i].size;
2106                 if ((copy = end - offset) > 0) {
2107                         __wsum csum2;
2108                         int err = 0;
2109                         u8  *vaddr;
2110                         skb_frag_t *frag = &skb_shinfo(skb)->frags[i];
2111                         struct page *page = frag->page;
2112
2113                         if (copy > len)
2114                                 copy = len;
2115                         vaddr = kmap(page);
2116                         csum2 = csum_and_copy_to_user(vaddr +
2117                                                         frag->page_offset +
2118                                                         offset - start,
2119                                                       to, copy, 0, &err);
2120                         kunmap(page);
2121                         if (err)
2122                                 goto fault;
2123                         *csump = csum_block_add(*csump, csum2, pos);
2124                         if (!(len -= copy))
2125                                 return 0;
2126                         offset += copy;
2127                         to += copy;
2128                         pos += copy;
2129                 }
2130                 start = end;
2131         }
2132
2133         if (skb_shinfo(skb)->frag_list) {
2134                 struct sk_buff *list = skb_shinfo(skb)->frag_list;
2135
2136                 for (; list; list=list->next) {
2137                         int end;
2138
2139                         WARN_ON(start > offset + len);
2140
2141                         end = start + list->len;
2142                         if ((copy = end - offset) > 0) {
2143                                 __wsum csum2 = 0;
2144                                 if (copy > len)
2145                                         copy = len;
2146                                 if (skb_copy_and_csum_datagram(list,
2147                                                                offset - start,
2148                                                                to, copy,
2149                                                                &csum2))
2150                                         goto fault;
2151                                 *csump = csum_block_add(*csump, csum2, pos);
2152                                 if ((len -= copy) == 0)
2153                                         return 0;
2154                                 offset += copy;
2155                                 to += copy;
2156                                 pos += copy;
2157                         }
2158                         start = end;
2159                 }
2160         }
2161         if (!len)
2162                 return 0;
2163
2164 fault:
2165         return -EFAULT;
2166 }
2167
2168 ssize_t openvswitch_read(struct file *f, char __user *buf, size_t nbytes,
2169                       loff_t *ppos)
2170 {
2171         /* XXX is there sufficient synchronization here? */
2172         int listeners = get_listen_mask(f);
2173         int dp_idx = iminor(f->f_dentry->d_inode);
2174         struct datapath *dp = get_dp(dp_idx);
2175         struct sk_buff *skb;
2176         size_t copy_bytes, tot_copy_bytes;
2177         int retval;
2178
2179         if (!dp)
2180                 return -ENODEV;
2181
2182         if (nbytes == 0 || !listeners)
2183                 return 0;
2184
2185         for (;;) {
2186                 int i;
2187
2188                 for (i = 0; i < DP_N_QUEUES; i++) {
2189                         if (listeners & (1 << i)) {
2190                                 skb = skb_dequeue(&dp->queues[i]);
2191                                 if (skb)
2192                                         goto success;
2193                         }
2194                 }
2195
2196                 if (f->f_flags & O_NONBLOCK) {
2197                         retval = -EAGAIN;
2198                         goto error;
2199                 }
2200
2201                 wait_event_interruptible(dp->waitqueue,
2202                                          dp_has_packet_of_interest(dp,
2203                                                                    listeners));
2204
2205                 if (signal_pending(current)) {
2206                         retval = -ERESTARTSYS;
2207                         goto error;
2208                 }
2209         }
2210 success:
2211         copy_bytes = tot_copy_bytes = min_t(size_t, skb->len, nbytes);
2212         
2213         retval = 0;
2214         if (skb->ip_summed == CHECKSUM_PARTIAL) {
2215                 if (copy_bytes == skb->len) {
2216                         __wsum csum = 0;
2217                         unsigned int csum_start, csum_offset;
2218
2219 #if LINUX_VERSION_CODE >= KERNEL_VERSION(2,6,22)
2220                         csum_start = skb->csum_start - skb_headroom(skb);
2221                         csum_offset = skb->csum_offset;
2222 #else
2223                         csum_start = skb_transport_header(skb) - skb->data;
2224                         csum_offset = skb->csum;
2225 #endif
2226                         BUG_ON(csum_start >= skb_headlen(skb));
2227                         retval = skb_copy_and_csum_datagram(skb, csum_start, buf + csum_start,
2228                                                             copy_bytes - csum_start, &csum);
2229                         if (!retval) {
2230                                 __sum16 __user *csump;
2231
2232                                 copy_bytes = csum_start;
2233                                 csump = (__sum16 __user *)(buf + csum_start + csum_offset);
2234
2235                                 BUG_ON((char *)csump + sizeof(__sum16) > buf + nbytes);
2236                                 put_user(csum_fold(csum), csump);
2237                         }
2238                 } else
2239                         retval = skb_checksum_help(skb);
2240         }
2241
2242         if (!retval) {
2243                 struct iovec __user iov;
2244
2245                 iov.iov_base = buf;
2246                 iov.iov_len = copy_bytes;
2247                 retval = skb_copy_datagram_iovec(skb, 0, &iov, iov.iov_len);
2248         }
2249
2250         if (!retval)
2251                 retval = tot_copy_bytes;
2252
2253         kfree_skb(skb);
2254
2255 error:
2256         return retval;
2257 }
2258
2259 static unsigned int openvswitch_poll(struct file *file, poll_table *wait)
2260 {
2261         /* XXX is there sufficient synchronization here? */
2262         int dp_idx = iminor(file->f_dentry->d_inode);
2263         struct datapath *dp = get_dp(dp_idx);
2264         unsigned int mask;
2265
2266         if (dp) {
2267                 mask = 0;
2268                 poll_wait(file, &dp->waitqueue, wait);
2269                 if (dp_has_packet_of_interest(dp, get_listen_mask(file)))
2270                         mask |= POLLIN | POLLRDNORM;
2271         } else {
2272                 mask = POLLIN | POLLRDNORM | POLLHUP;
2273         }
2274         return mask;
2275 }
2276
2277 struct file_operations openvswitch_fops = {
2278         /* XXX .aio_read = openvswitch_aio_read, */
2279         .read  = openvswitch_read,
2280         .poll  = openvswitch_poll,
2281         .unlocked_ioctl = openvswitch_ioctl,
2282 #ifdef CONFIG_COMPAT
2283         .compat_ioctl = openvswitch_compat_ioctl,
2284 #endif
2285         /* XXX .fasync = openvswitch_fasync, */
2286 };
2287
2288 static int major;
2289
2290 static int __init dp_init(void)
2291 {
2292         struct sk_buff *dummy_skb;
2293         int err;
2294
2295         BUILD_BUG_ON(sizeof(struct ovs_skb_cb) > sizeof(dummy_skb->cb));
2296
2297         printk("Open vSwitch %s, built "__DATE__" "__TIME__"\n", VERSION BUILDNR);
2298
2299         err = flow_init();
2300         if (err)
2301                 goto error;
2302
2303         err = vport_init();
2304         if (err)
2305                 goto error_flow_exit;
2306
2307         err = register_netdevice_notifier(&dp_device_notifier);
2308         if (err)
2309                 goto error_vport_exit;
2310
2311         major = register_chrdev(0, "openvswitch", &openvswitch_fops);
2312         if (err < 0)
2313                 goto error_unreg_notifier;
2314
2315         return 0;
2316
2317 error_unreg_notifier:
2318         unregister_netdevice_notifier(&dp_device_notifier);
2319 error_vport_exit:
2320         vport_exit();
2321 error_flow_exit:
2322         flow_exit();
2323 error:
2324         return err;
2325 }
2326
2327 static void dp_cleanup(void)
2328 {
2329         rcu_barrier();
2330         unregister_chrdev(major, "openvswitch");
2331         unregister_netdevice_notifier(&dp_device_notifier);
2332         vport_exit();
2333         flow_exit();
2334 }
2335
2336 module_init(dp_init);
2337 module_exit(dp_cleanup);
2338
2339 MODULE_DESCRIPTION("Open vSwitch switching datapath");
2340 MODULE_LICENSE("GPL");