/* * Copyright (c) 2019 Cisco and/or its affiliates. * Licensed under the Apache License, Version 2.0 (the "License"); * you may not use this * You may obtain a copy of the License at: * * http://www.apache.org/licenses/LICENSE-2.0 * * Unless required by applicable law or agreed to in writing, software * distributed under the License is distributed on an "AS IS" BASIS, * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied. * See the License for the specific language governing permissions and * limitations under the License. */ #include #include typedef struct vls_shared_data_ { clib_spinlock_t lock; u32 owner_wrk_index; u32 *workers_subscribed; clib_bitmap_t *listeners; } vls_shared_data_t; typedef struct vcl_locked_session_ { clib_spinlock_t lock; u32 session_index; u32 worker_index; u32 vls_index; u32 shared_data_index; /** VCL session owned by different workers because of migration */ u32 owner_vcl_wrk_index; uword *vcl_wrk_index_to_session_index; } vcl_locked_session_t; typedef struct vls_worker_ { vcl_locked_session_t *vls_pool; uword *session_handle_to_vlsh_table; u32 wrk_index; } vls_worker_t; typedef struct vls_local_ { int vls_wrk_index; volatile int vls_mt_n_threads; pthread_mutex_t vls_mt_mq_mlock; pthread_mutex_t vls_mt_spool_mlock; volatile u8 select_mp_check; volatile u8 epoll_mp_check; } vls_process_local_t; static vls_process_local_t vls_local; static vls_process_local_t *vlsl = &vls_local; typedef struct vls_main_ { vls_worker_t *workers; clib_rwlock_t vls_table_lock; /** Pool of data shared by sessions owned by different workers */ vls_shared_data_t *shared_data_pool; clib_rwlock_t shared_data_lock; } vls_main_t; vls_main_t *vlsm; typedef enum vls_rpc_msg_type_ { VLS_RPC_CLONE_AND_SHARE, VLS_RPC_SESS_CLEANUP, } vls_rpc_msg_type_e; typedef struct vls_rpc_msg_ { u8 type; u8 data[0]; } vls_rpc_msg_t; typedef struct vls_clone_and_share_msg_ { u32 vls_index; /**< vls to be shared */ u32 session_index; /**< vcl session to be shared */ u32 origin_vls_wrk; /**< vls worker that initiated the rpc */ u32 origin_vls_index; /**< vls session of the originator */ u32 origin_vcl_wrk; /**< vcl worker that initiated the rpc */ u32 origin_session_index; /**< vcl session of the originator */ } vls_clone_and_share_msg_t; typedef struct vls_sess_cleanup_msg_ { u32 session_index; /**< vcl session to be cleaned */ u32 origin_vcl_wrk; /**< worker that initiated the rpc */ } vls_sess_cleanup_msg_t; void vls_send_session_cleanup_rpc (vcl_worker_t * wrk, u32 dst_wrk_index, u32 dst_session_index); void vls_send_clone_and_share_rpc (vcl_worker_t * wrk, vcl_locked_session_t * vls, u32 session_index, u32 vls_wrk_index, u32 dst_wrk_index, u32 dst_vls_index, u32 dst_session_index); static inline u32 vls_get_worker_index (void) { if (vls_mt_wrk_supported ()) return vlsl->vls_wrk_index; else return vcl_get_worker_index (); } static u32 vls_shared_data_alloc (void) { vls_shared_data_t *vls_shd; u32 shd_index; clib_rwlock_writer_lock (&vlsm->shared_data_lock); pool_get_zero (vlsm->shared_data_pool, vls_shd); clib_spinlock_init (&vls_shd->lock); shd_index = vls_shd - vlsm->shared_data_pool; clib_rwlock_writer_unlock (&vlsm->shared_data_lock); return shd_index; } static u32 vls_shared_data_index (vls_shared_data_t * vls_shd) { return vls_shd - vlsm->shared_data_pool; } vls_shared_data_t * vls_shared_data_get (u32 shd_index) { if (pool_is_free_index (vlsm->shared_data_pool, shd_index)) return 0; return pool_elt_at_index (vlsm->shared_data_pool, shd_index); } static void vls_shared_data_free (u32 shd_index) { vls_shared_data_t *vls_shd; clib_rwlock_writer_lock (&vlsm->shared_data_lock); vls_shd = vls_shared_data_get (shd_index); clib_spinlock_free (&vls_shd->lock); clib_bitmap_free (vls_shd->listeners); vec_free (vls_shd->workers_subscribed); pool_put (vlsm->shared_data_pool, vls_shd); clib_rwlock_writer_unlock (&vlsm->shared_data_lock); } static inline void vls_shared_data_pool_rlock (void) { clib_rwlock_reader_lock (&vlsm->shared_data_lock); } static inline void vls_shared_data_pool_runlock (void) { clib_rwlock_reader_unlock (&vlsm->shared_data_lock); } static inline void vls_mt_table_rlock (void) { if (vlsl->vls_mt_n_threads > 1) clib_rwlock_reader_lock (&vlsm->vls_table_lock); } static inline void vls_mt_table_runlock (void) { if (vlsl->vls_mt_n_threads > 1) clib_rwlock_reader_unlock (&vlsm->vls_table_lock); } static inline void vls_mt_table_wlock (void) { if (vlsl->vls_mt_n_threads > 1) clib_rwlock_writer_lock (&vlsm->vls_table_lock); } static inline void vls_mt_table_wunlock (void) { if (vlsl->vls_mt_n_threads > 1) clib_rwlock_writer_unlock (&vlsm->vls_table_lock); } typedef enum { VLS_MT_OP_READ, VLS_MT_OP_WRITE, VLS_MT_OP_SPOOL, VLS_MT_OP_XPOLL, } vls_mt_ops_t; typedef enum { VLS_MT_LOCK_MQ = 1 << 0, VLS_MT_LOCK_SPOOL = 1 << 1 } vls_mt_lock_type_t; static void vls_mt_add (void) { vlsl->vls_mt_n_threads += 1; /* If multi-thread workers are supported, for each new thread register a new * vcl worker with vpp. Otherwise, all threads use the same vcl worker, so * update the vcl worker's thread local worker index variable */ if (vls_mt_wrk_supported ()) { if (vppcom_worker_register () != VPPCOM_OK) VERR ("failed to register worker"); } else vcl_set_worker_index (vlsl->vls_wrk_index); } static inline void vls_mt_mq_lock (void) { pthread_mutex_lock (&vlsl->vls_mt_mq_mlock); } static inline void vls_mt_mq_unlock (void) { pthread_mutex_unlock (&vlsl->vls_mt_mq_mlock); } static inline void vls_mt_spool_lock (void) { pthread_mutex_lock (&vlsl->vls_mt_spool_mlock); } static inline void vls_mt_create_unlock (void) { pthread_mutex_unlock (&vlsl->vls_mt_spool_mlock); } static void vls_mt_locks_init (void) { pthread_mutex_init (&vlsl->vls_mt_mq_mlock, NULL); pthread_mutex_init (&vlsl->vls_mt_spool_mlock, NULL); } u8 vls_is_shared (vcl_locked_session_t * vls) { return (vls->shared_data_index != ~0); } static inline void vls_lock (vcl_locked_session_t * vls) { if ((vlsl->vls_mt_n_threads > 1) || vls_is_shared (vls)) clib_spinlock_lock (&vls->lock); } static inline void vls_unlock (vcl_locked_session_t * vls) { if ((vlsl->vls_mt_n_threads > 1) || vls_is_shared (vls)) clib_spinlock_unlock (&vls->lock); } static inline vcl_session_handle_t vls_to_sh (vcl_locked_session_t * vls) { return vcl_session_handle_from_index (vls->session_index); } static inline vcl_session_handle_t vls_to_sh_tu (vcl_locked_session_t * vls) { vcl_session_handle_t sh; sh = vls_to_sh (vls); vls_mt_table_runlock (); return sh; } static vls_worker_t * vls_worker_get_current (void) { return pool_elt_at_index (vlsm->workers, vls_get_worker_index ()); } static void vls_worker_alloc (void) { vls_worker_t *wrk; pool_get_zero (vlsm->workers, wrk); wrk->wrk_index = vcl_get_worker_index (); } static void vls_worker_free (vls_worker_t * wrk) { hash_free (wrk->session_handle_to_vlsh_table); pool_free (wrk->vls_pool); pool_put (vlsm->workers, wrk); } static vls_worker_t * vls_worker_get (u32 wrk_index) { if (pool_is_free_index (vlsm->workers, wrk_index)) return 0; return pool_elt_at_index (vlsm->workers, wrk_index); } static vls_handle_t vls_alloc (vcl_session_handle_t sh) { vls_worker_t *wrk = vls_worker_get_current (); vcl_locked_session_t *vls; vls_mt_table_wlock (); pool_get_zero (wrk->vls_pool, vls); vls->session_index = vppcom_session_index (sh); vls->worker_index = vppcom_session_worker (sh); vls->vls_index = vls - wrk->vls_pool; vls->shared_data_index = ~0; hash_set (wrk->session_handle_to_vlsh_table, sh, vls->vls_index); if (vls_mt_wrk_supported ()) { hash_set (vls->vcl_wrk_index_to_session_index, vls->worker_index, vls->session_index); vls->owner_vcl_wrk_index = vls->worker_index; } clib_spinlock_init (&vls->lock); vls_mt_table_wunlock (); return vls->vls_index; } static vcl_locked_session_t * vls_get (vls_handle_t vlsh) { vls_worker_t *wrk = vls_worker_get_current (); if (pool_is_free_index (wrk->vls_pool, vlsh)) return 0; return pool_elt_at_index (wrk->vls_pool, vlsh); } static void vls_free (vcl_locked_session_t * vls) { vls_worker_t *wrk = vls_worker_get_current (); ASSERT (vls != 0); hash_unset (wrk->session_handle_to_vlsh_table, vcl_session_handle_from_index (vls->session_index)); clib_spinlock_free (&vls->lock); pool_put (wrk->vls_pool, vls); } static vcl_locked_session_t * vls_get_and_lock (vls_handle_t vlsh) { vls_worker_t *wrk = vls_worker_get_current (); vcl_locked_session_t *vls; if (pool_is_free_index (wrk->vls_pool, vlsh)) return 0; vls = pool_elt_at_index (wrk->vls_pool, vlsh); vls_lock (vls); return vls; } static vcl_locked_session_t * vls_get_w_dlock (vls_handle_t vlsh) { vcl_locked_session_t *vls; vls_mt_table_rlock (); vls = vls_get_and_lock (vlsh); if (!vls) vls_mt_table_runlock (); return vls; } static inline void vls_get_and_unlock (vls_handle_t vlsh) { vcl_locked_session_t *vls; vls_mt_table_rlock (); vls = vls_get (vlsh); vls_unlock (vls); vls_mt_table_runlock (); } static inline void vls_dunlock (vcl_locked_session_t * vls) { vls_unlock (vls); vls_mt_table_runlock (); } static vcl_locked_session_t * vls_session_get (vls_worker_t * wrk, u32 vls_index) { if (pool_is_free_index (wrk->vls_pool, vls_index)) return 0; return pool_elt_at_index (wrk->vls_pool, vls_index); } vcl_session_handle_t vlsh_to_sh (vls_handle_t vlsh) { vcl_locked_session_t *vls; int rv; vls = vls_get_w_dlock (vlsh); if (!vls) return INVALID_SESSION_ID; rv = vls_to_sh (vls); vls_dunlock (vls); return rv; } vcl_session_handle_t vlsh_to_session_index (vls_handle_t vlsh) { vcl_session_handle_t sh; sh = vlsh_to_sh (vlsh); return vppcom_session_index (sh); } vls_handle_t vls_si_wi_to_vlsh (u32 session_index, u32 vcl_wrk_index) { vls_worker_t *wrk = vls_worker_get_current (); uword *vlshp; vlshp = hash_get (wrk->session_handle_to_vlsh_table, vcl_session_handle_from_wrk_session_index (session_index, vcl_wrk_index)); return vlshp ? *vlshp : VLS_INVALID_HANDLE; } vls_handle_t vls_session_index_to_vlsh (uint32_t session_index) { vls_handle_t vlsh; vls_mt_table_rlock (); vlsh = vls_si_wi_to_vlsh (session_index, vcl_get_worker_index ()); vls_mt_table_runlock (); return vlsh; } u8 vls_is_shared_by_wrk (vcl_locked_session_t * vls, u32 wrk_index) { vls_shared_data_t *vls_shd; int i; if (vls->shared_data_index == ~0) return 0; vls_shared_data_pool_rlock (); vls_shd = vls_shared_data_get (vls->shared_data_index); clib_spinlock_lock (&vls_shd->lock); for (i = 0; i < vec_len (vls_shd->workers_subscribed); i++) if (vls_shd->workers_subscribed[i] == wrk_index) { clib_spinlock_unlock (&vls_shd->lock); vls_shared_data_pool_runlock (); return 1; } clib_spinlock_unlock (&vls_shd->lock); vls_shared_data_pool_runlock (); return 0; } static void vls_listener_wrk_set (vcl_locked_session_t * vls, u32 wrk_index, u8 is_active) { vls_shared_data_t *vls_shd; if (vls->shared_data_index == ~0) { clib_warning ("not a shared session"); return; } vls_shared_data_pool_rlock (); vls_shd = vls_shared_data_get (vls->shared_data_index); clib_spinlock_lock (&vls_shd->lock); clib_bitmap_set (vls_shd->listeners, wrk_index, is_active); clib_spinlock_unlock (&vls_shd->lock); vls_shared_data_pool_runlock (); } static u32 vls_shared_get_owner (vcl_locked_session_t * vls) { vls_shared_data_t *vls_shd; u32 owner_wrk; vls_shared_data_pool_rlock (); vls_shd = vls_shared_data_get (vls->shared_data_index); owner_wrk = vls_shd->owner_wrk_index; vls_shared_data_pool_runlock (); return owner_wrk; } static u8 vls_listener_wrk_is_active (vcl_locked_session_t * vls, u32 wrk_index) { vls_shared_data_t *vls_shd; u8 is_set; if (vls->shared_data_index == ~0) { clib_warning ("not a shared session"); return 0; } vls_shared_data_pool_rlock (); vls_shd = vls_shared_data_get (vls->shared_data_index); clib_spinlock_lock (&vls_shd->lock); is_set = clib_bitmap_get (vls_shd->listeners, wrk_index); clib_spinlock_unlock (&vls_shd->lock); vls_shared_data_pool_runlock (); return (is_set == 1); } static void vls_listener_wrk_start_listen (vcl_locked_session_t * vls, u32 wrk_index) { vppcom_session_listen (vls_to_sh (vls), ~0); vls_listener_wrk_set (vls, wrk_index, 1 /* is_active */ ); } static void vls_listener_wrk_stop_listen (vcl_locked_session_t * vls, u32 wrk_index) { vcl_worker_t *wrk; vcl_session_t *s; wrk = vcl_worker_get (wrk_index); s = vcl_session_get (wrk, vls->session_index); if (s->session_state != VCL_STATE_LISTEN) return; vcl_send_session_unlisten (wrk, s); s->session_state = VCL_STATE_LISTEN_NO_MQ; vls_listener_wrk_set (vls, wrk_index, 0 /* is_active */ ); } static int vls_shared_data_subscriber_position (vls_shared_data_t * vls_shd, u32 wrk_index) { int i; for (i = 0; i < vec_len (vls_shd->workers_subscribed); i++) { if (vls_shd->workers_subscribed[i] == wrk_index) return i; } return -1; } int vls_unshare_session (vcl_locked_session_t * vls, vcl_worker_t * wrk) { vls_shared_data_t *vls_shd; int do_disconnect, pos; u32 n_subscribers; vcl_session_t *s; if (vls->shared_data_index == ~0) return 0; s = vcl_session_get (wrk, vls->session_index); if (s->session_state == VCL_STATE_LISTEN) vls_listener_wrk_set (vls, wrk->wrk_index, 0 /* is_active */ ); vls_shared_data_pool_rlock (); vls_shd = vls_shared_data_get (vls->shared_data_index); clib_spinlock_lock (&vls_shd->lock); pos = vls_shared_data_subscriber_position (vls_shd, wrk->wrk_index); if (pos < 0) { clib_warning ("worker %u not subscribed for vls %u", wrk->wrk_index, vls->worker_index); goto done; } /* * Unsubscribe from share data and fifos */ if (s->rx_fifo) { svm_fifo_del_subscriber (s->rx_fifo, wrk->vpp_wrk_index); svm_fifo_del_subscriber (s->tx_fifo, wrk->vpp_wrk_index); } vec_del1 (vls_shd->workers_subscribed, pos); /* * Cleanup vcl state */ n_subscribers = vec_len (vls_shd->workers_subscribed); do_disconnect = s->session_state == VCL_STATE_LISTEN || !n_subscribers; vcl_session_cleanup (wrk, s, vcl_session_handle (s), do_disconnect); /* * No subscriber left, cleanup shared data */ if (!n_subscribers) { u32 shd_index = vls_shared_data_index (vls_shd); clib_spinlock_unlock (&vls_shd->lock); vls_shared_data_pool_runlock (); vls_shared_data_free (shd_index); /* All locks have been dropped */ return 0; } /* Return, if this is not the owning worker */ if (vls_shd->owner_wrk_index != wrk->wrk_index) goto done; ASSERT (vec_len (vls_shd->workers_subscribed)); /* * Check if we can change owner or close */ vls_shd->owner_wrk_index = vls_shd->workers_subscribed[0]; vcl_send_session_worker_update (wrk, s, vls_shd->owner_wrk_index); /* XXX is this still needed? */ if (vec_len (vls_shd->workers_subscribed) > 1) clib_warning ("more workers need to be updated"); done: clib_spinlock_unlock (&vls_shd->lock); vls_shared_data_pool_runlock (); return 0; } void vls_init_share_session (vls_worker_t * vls_wrk, vcl_locked_session_t * vls) { vls_shared_data_t *vls_shd; u32 vls_shd_index = vls_shared_data_alloc (); vls_shared_data_pool_rlock (); vls_shd = vls_shared_data_get (vls_shd_index); vls_shd->owner_wrk_index = vls_wrk->wrk_index; vls->shared_data_index = vls_shd_index; vec_add1 (vls_shd->workers_subscribed, vls_wrk->wrk_index); vls_shared_data_pool_runlock (); } void vls_share_session (vls_worker_t * vls_wrk, vcl_locked_session_t * vls) { vcl_worker_t *vcl_wrk = vcl_worker_get (vls_wrk->wrk_index); vls_shared_data_t *vls_shd; vcl_session_t *s; s = vcl_session_get (vcl_wrk, vls->session_index); if (!s) { clib_warning ("wrk %u session %u vls %u NOT AVAILABLE", vcl_wrk->wrk_index, vls->session_index, vls->vls_index); return; } ASSERT (vls->shared_data_index != ~0); /* Reinit session lock */ clib_spinlock_init (&vls->lock); vls_shared_data_pool_rlock (); vls_shd = vls_shared_data_get (vls->shared_data_index); clib_spinlock_lock (&vls_shd->lock); vec_add1 (vls_shd->workers_subscribed, vls_wrk->wrk_index); clib_spinlock_unlock (&vls_shd->lock); vls_shared_data_pool_runlock (); if (s->rx_fifo) { svm_fifo_add_subscriber (s->rx_fifo, vcl_wrk->vpp_wrk_index); svm_fifo_add_subscriber (s->tx_fifo, vcl_wrk->vpp_wrk_index); } else if (s->session_state == VCL_STATE_LISTEN) { s->session_state = VCL_STATE_LISTEN_NO_MQ; } } static void vls_share_sessions (vls_worker_t * vls_parent_wrk, vls_worker_t * vls_wrk) { vcl_locked_session_t *vls, *parent_vls; /* *INDENT-OFF* */ pool_foreach (vls, vls_wrk->vls_pool) { /* Initialize sharing on parent session */ if (vls->shared_data_index == ~0) { parent_vls = vls_session_get (vls_parent_wrk, vls->vls_index); vls_init_share_session (vls_parent_wrk, parent_vls); vls->shared_data_index = parent_vls->shared_data_index; } vls_share_session (vls_wrk, vls); } /* *INDENT-ON* */ } void vls_worker_copy_on_fork (vcl_worker_t * parent_wrk) { vls_worker_t *vls_wrk = vls_worker_get_current (), *vls_parent_wrk; vcl_worker_t *wrk = vcl_worker_get_current (); u32 vls_index, session_index, wrk_index; vcl_session_handle_t sh; /* * init vcl worker */ wrk->sessions = pool_dup (parent_wrk->sessions); wrk->session_index_by_vpp_handles = hash_dup (parent_wrk->session_index_by_vpp_handles); /* * init vls worker */ vls_parent_wrk = vls_worker_get (parent_wrk->wrk_index); /* *INDENT-OFF* */ hash_foreach (sh, vls_index, vls_parent_wrk->session_handle_to_vlsh_table, ({ vcl_session_handle_parse (sh, &wrk_index, &session_index); hash_set (vls_wrk->session_handle_to_vlsh_table, vcl_session_handle_from_index (session_index), vls_index); })); /* *INDENT-ON* */ vls_wrk->vls_pool = pool_dup (vls_parent_wrk->vls_pool); vls_share_sessions (vls_parent_wrk, vls_wrk); } static void vls_mt_acq_locks (vcl_locked_session_t * vls, vls_mt_ops_t op, int *locks_acq) { vcl_worker_t *wrk = vcl_worker_get_current (); vcl_session_t *s = 0; int is_nonblk = 0; if (vls) { s = vcl_session_get (wrk, vls->session_index); if (PREDICT_FALSE (!s)) return; is_nonblk = vcl_session_has_attr (s, VCL_SESS_ATTR_NONBLOCK); } switch (op) { case VLS_MT_OP_READ: if (!is_nonblk) is_nonblk = vcl_session_read_ready (s) != 0; if (!is_nonblk) { vls_mt_mq_lock (); *locks_acq |= VLS_MT_LOCK_MQ; } break; case VLS_MT_OP_WRITE: ASSERT (s); if (!is_nonblk) is_nonblk = vcl_session_write_ready (s) != 0; if (!is_nonblk) { vls_mt_mq_lock (); *locks_acq |= VLS_MT_LOCK_MQ; } break; case VLS_MT_OP_XPOLL: vls_mt_mq_lock (); *locks_acq |= VLS_MT_LOCK_MQ; break; case VLS_MT_OP_SPOOL: vls_mt_spool_lock (); *locks_acq |= VLS_MT_LOCK_SPOOL; break; default: break; } } static void vls_mt_rel_locks (int locks_acq) { if (locks_acq & VLS_MT_LOCK_MQ) vls_mt_mq_unlock (); if (locks_acq & VLS_MT_LOCK_SPOOL) vls_mt_create_unlock (); } static inline u8 vls_mt_session_should_migrate (vcl_locked_session_t * vls) { return (vls_mt_wrk_supported () && vls->worker_index != vcl_get_worker_index ()); } static void vls_mt_session_migrate (vcl_locked_session_t * vls) { u32 wrk_index = vcl_get_worker_index (); vcl_worker_t *wrk; u32 src_sid, sid; vcl_session_t *session; uword *p; ASSERT (vls_mt_wrk_supported () && vls->worker_index != wrk_index); /* * VCL session on current vcl worker already allocated. Update current * owner worker and index and return */ if ((p = hash_get (vls->vcl_wrk_index_to_session_index, wrk_index))) { vls->worker_index = wrk_index; vls->session_index = (u32) p[0]; return; } /* * Ask vcl worker that owns the original vcl session to clone it into * current vcl worker session pool */ if (!(p = hash_get (vls->vcl_wrk_index_to_session_index, vls->owner_vcl_wrk_index))) { VERR ("session in owner worker(%u) is free", vls->owner_vcl_wrk_index); ASSERT (0); return; } src_sid = (u32) p[0]; wrk = vcl_worker_get_current (); sessi
/*
 * Copyright (c) 2018 Cisco and/or its affiliates.
 * Licensed under the Apache License, Version 2.0 (the "License");
 * you may not use this file except in compliance with the License.
 * You may obtain a copy of the License at:
 *
 *     http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */

#include "ipip.h"
#include <vppinfra/error.h>
#include <vnet/vnet.h>
#include <vnet/fib/fib_table.h>

static clib_error_t *
create_ipip_tunnel_command_fn (vlib_main_t * vm,
			       unformat_input_t * input,
			       vlib_cli_command_t * cmd)
{
  unformat_input_t _line_input, *line_input = &_line_input;
  ip46_address_t src = ip46_address_initializer, dst =
    ip46_address_initializer;
  u32 instance = ~0;
  u32 fib_index = 0;
  u32 table_id = 0;
  int rv;
  u32 num_m_args = 0;
  u32 sw_if_index;
  clib_error_t *error = NULL;
  bool ip4_set = false, ip6_set = false;
  tunnel_mode_t mode = TUNNEL_MODE_P2P;
  tunnel_encap_decap_flags_t flags = TUNNEL_ENCAP_DECAP_FLAG_NONE;

  /* Get a line of input. */
  if (!unformat_user (input, unformat_line_input, line_input))
    return 0;

  while (unformat_check_input (line_input) != UNFORMAT_END_OF_INPUT)
    {
      if (unformat (line_input, "instance %d", &instance))
	;
      else
	if (unformat (line_input, "src %U", unformat_ip4_address, &src.ip4))
	{
	  num_m_args++;
	  ip4_set = true;
	}
      else
	if (unformat (line_input, "dst %U", unformat_ip4_address, &dst.ip4))
	{
	  num_m_args++;
	  ip4_set = true;
	}
      else
	if (unformat (line_input, "src %U", unformat_ip6_address, &src.ip6))
	{
	  num_m_args++;
	  ip6_set = true;
	}
      else
	if (unformat (line_input, "dst %U", unformat_ip6_address, &dst.ip6))
	{
	  num_m_args++;
	  ip6_set = true;
	}
      else if (unformat (line_input, "%U", unformat_tunnel_mode, &mode))
	{
	  num_m_args++;
	}
      else if (unformat (line_input, "outer-table-id %d", &table_id))
	;
      else
	if (unformat
	    (line_input, "flags %U", unformat_tunnel_encap_decap_flags,
	     &flags))
	;
      else
	{
	  error =
	    clib_error_return (0, "unknown input `%U'", format_unformat_error,
			       line_input);
	  goto done;
	}
    }

  if (num_m_args < 2)
    {
      error = clib_error_return (0, "mandatory argument(s) missing");
      goto done;
    }
  if (ip4_set && ip6_set)
    {
      error =
	clib_error_return (0,
			   "source and destination must be of same address family");
      goto done;
    }

  fib_index = fib