OpenSDN source code
All Classes Namespaces Files Functions Variables Typedefs Enumerations Enumerator Friends Macros Pages
routing_instance.cc
Go to the documentation of this file.
1 /*
2  * Copyright (c) 2013 Juniper Networks, Inc. All rights reserved.
3  */
4 
6 
7 #include <boost/foreach.hpp>
8 #include <boost/assign/list_of.hpp>
9 #include <boost/functional/hash.hpp>
10 
11 #include <algorithm>
12 
13 #include "base/set_util.h"
14 #include "base/task_annotations.h"
15 #include "base/task_trigger.h"
16 #include "bgp/bgp_config.h"
17 #include "bgp/bgp_factory.h"
18 #include "bgp/bgp_log.h"
19 #include "bgp/bgp_mvpn.h"
20 #include "bgp/bgp_server.h"
21 #include "bgp/mvpn/mvpn_table.h"
27 #include "bgp/routing-instance/routing_table_types.h"
31 
32 using boost::assign::list_of;
33 using boost::system::error_code;
34 using boost::tie;
35 using std::make_pair;
36 using std::ostringstream;
37 using std::set;
38 using std::string;
39 using std::vector;
40 
43 
45 public:
46  explicit DeleteActor(RoutingInstanceMgr *manager)
47  : LifetimeActor(manager->server_->lifetime_manager()),
48  manager_(manager) {
49  }
50  virtual bool MayDelete() const {
51  return manager_->MayDelete();
52  }
53  virtual void Shutdown() {
54  manager_->Shutdown();
55  }
56  virtual void Destroy() {
58  }
59 
60 private:
62 };
63 
65  server_(server),
66  instance_config_lists_(
67  TaskScheduler::GetInstance()->HardwareThreadCount()),
68  default_rtinstance_(NULL),
69  deleted_count_(0),
70  asn_listener_id_(server->RegisterASNUpdateCallback(
71  boost::bind(&RoutingInstanceMgr::ASNUpdateCallback, this, _1, _2))),
72  identifier_listener_id_(server->RegisterIdentifierUpdateCallback(
73  boost::bind(&RoutingInstanceMgr::IdentifierUpdateCallback,
74  this, _1))),
75  dormant_trace_buf_size_(
76  GetEnvRoutingInstanceDormantTraceBufferCapacity()),
77  trace_buf_threshold_(
78  GetEnvRoutingInstanceDormantTraceBufferThreshold()),
79  deleter_(new DeleteActor(this)),
80  server_delete_ref_(this, server->deleter()) {
81  int task_id = TaskScheduler::GetInstance()->GetTaskId("bgp::ConfigHelper");
82  int hw_thread_count = TaskScheduler::GetInstance()->HardwareThreadCount();
83  for (int idx = 0; idx < hw_thread_count; ++idx) {
84  instance_config_triggers_.push_back(new TaskTrigger(boost::bind(
86  task_id, idx));
87  }
90  TaskScheduler::GetInstance()->GetTaskId("bgp::Config"), 0));
91 }
92 
94  assert(mvpn_project_managers_.empty());
95  assert(virtual_networks_.empty());
96  assert(deleted_count_ == 0);
100 }
101 
103  const string &network) const {
104  tbb::mutex::scoped_lock lock(mutex_);
105 
106  MvpnProjectManagerNetworks::const_iterator iter =
107  mvpn_project_managers_.find(network);
108  if (iter == mvpn_project_managers_.end())
109  return 0;
110  return iter->second.size();
111 }
112 
114  deleter_->Delete();
115 }
116 
118  for (RoutingInstanceIterator it = begin(); it != end(); ++it) {
119  InstanceTargetRemove(it->second);
120  InstanceVnIndexRemove(it->second);
121  }
122 }
123 
125  if (!neighbor_config_list_.empty())
126  return false;
127  for (size_t idx = 0; idx < instance_config_lists_.size(); ++idx) {
128  if (!instance_config_lists_[idx].empty())
129  return false;
130  }
131  return true;
132 }
133 
135  return deleter_.get();
136 }
137 
139  return deleter()->IsDeleted();
140 }
141 
142 //
143 // Go through all export targets for the RoutingInstance and add an entry for
144 // each one to the InstanceTargetMap.
145 //
146 // Ignore export targets that are not in the import list. This is done since
147 // export only targets are managed by user and the same export only target can
148 // be configured on multiple virtual networks.
149 //
151  tbb::mutex::scoped_lock lock(mutex_);
152  for (RoutingInstance::RouteTargetList::const_iterator it =
153  rti->GetExportList().begin(); it != rti->GetExportList().end(); ++it) {
154  if (rti->GetImportList().find(*it) == rti->GetImportList().end())
155  continue;
156  target_map_.insert(make_pair(*it, rti));
157  }
158 }
159 
160 //
161 // Go through all export targets for the RoutingInstance and remove the entry
162 // for each one from the InstanceTargetMap. Note that there may be multiple
163 // entries in the InstanceTargetMap for a given export target. Hence we need
164 // to make sure that we only remove the entry that matches the RoutingInstance.
165 //
166 // Ignore export targets that are not in the import list. They shouldn't be in
167 // in the map because of the same check in InstanceTargetAdd.
168 //
170  tbb::mutex::scoped_lock lock(mutex_);
171  for (RoutingInstance::RouteTargetList::const_iterator it =
172  rti->GetExportList().begin(); it != rti->GetExportList().end(); ++it) {
173  if (rti->GetImportList().find(*it) == rti->GetImportList().end())
174  continue;
175  for (InstanceTargetMap::iterator loc = target_map_.find(*it);
176  loc != target_map_.end() && loc->first == *it; ++loc) {
177  if (loc->second == rti) {
178  target_map_.erase(loc);
179  break;
180  }
181  }
182  }
183 }
184 
185 //
186 // Lookup the RoutingInstance for the given RouteTarget.
187 //
189  const RouteTarget &rtarget) const {
190  InstanceTargetMap::const_iterator loc = target_map_.find(rtarget);
191  if (loc == target_map_.end()) {
192  return NULL;
193  }
194  return loc->second;
195 }
196 
197 //
198 // Add an entry for the vn index to the VnIndexMap.
199 //
201  tbb::mutex::scoped_lock lock(mutex_);
202  if (rti->virtual_network_index())
203  vn_index_map_.insert(make_pair(rti->virtual_network_index(), rti));
204 }
205 
206 //
207 // Remove the entry for the vn index from the VnIndexMap. Note that there may
208 // be multiple entries in the VnIndexMap for a given vn index target. Hence we
209 // need to make sure that we remove the entry that matches the RoutingInstance.
210 //
212  tbb::mutex::scoped_lock lock(mutex_);
213  if (!rti->virtual_network_index())
214  return;
215 
216  int vn_index = rti->virtual_network_index();
217  for (VnIndexMap::iterator loc = vn_index_map_.find(vn_index);
218  loc != vn_index_map_.end() && loc->first == vn_index; ++loc) {
219  if (loc->second == rti) {
220  vn_index_map_.erase(loc);
221  break;
222  }
223  }
224 }
225 
226 //
227 // Lookup the RoutingInstance for the given vn index.
228 //
230  int vn_index) const {
231  VnIndexMap::const_iterator loc = vn_index_map_.find(vn_index);
232  if (loc == vn_index_map_.end())
233  return NULL;
234  return loc->second;
235 }
236 
237 //
238 // Lookup the VN name for the given vn index.
239 //
241  int vn_index) const {
242  const RoutingInstance *rti = GetInstanceByVnIndex(vn_index);
243  return rti ? rti->GetVirtualNetworkName() : "unresolved";
244 }
245 
246 //
247 // Lookup the vn index for the given RouteTarget.
248 //
249 // Return 0 if the RouteTarget does not map to a RoutingInstance.
250 // Return -1 if the RouteTarget maps to multiple RoutingInstances
251 // that belong to different VNs.
252 //
254  const RouteTarget &rtarget) const {
255  int vn_index = 0;
256  for (InstanceTargetMap::const_iterator loc = target_map_.find(rtarget);
257  loc != target_map_.end() && loc->first == rtarget; ++loc) {
258  int ri_vn_index = loc->second->virtual_network_index();
259  if (vn_index && ri_vn_index && ri_vn_index != vn_index)
260  return -1;
261  vn_index = ri_vn_index;
262  }
263 
264  return vn_index;
265 }
266 
267 //
268 // Derive the vn index from the route targets in the ExtCommunity.
269 //
270 // If the result is ambiguous i.e. we have a RouteTarget that maps
271 // to multiple vn indexes or we have multiple RouteTargets that map
272 // to different vn indexes, return 0.
273 //
275  const ExtCommunity *ext_community) const {
276  int vn_index = 0;
277  BOOST_FOREACH(const ExtCommunity::ExtCommunityValue &comm,
278  ext_community->communities()) {
280  continue;
281 
282  RouteTarget rtarget(comm);
283  int rtgt_vn_index = GetVnIndexByRouteTarget(rtarget);
284  if (rtgt_vn_index < 0 ||
285  (vn_index && rtgt_vn_index && rtgt_vn_index != vn_index)) {
286  vn_index = 0;
287  break;
288  } else if (rtgt_vn_index) {
289  vn_index = rtgt_vn_index;
290  }
291  }
292 
293  return vn_index;
294 }
295 
296 int
298  tbb::mutex::scoped_lock lock(mutex_);
299  size_t i = bmap_.find_first();
300  if (i == bmap_.npos) {
301  i = callbacks_.size();
302  callbacks_.push_back(callback);
303  } else {
304  bmap_.reset(i);
305  if (bmap_.none()) {
306  bmap_.clear();
307  }
308  callbacks_[i] = callback;
309  }
310  return i;
311 }
312 
314  tbb::mutex::scoped_lock lock(mutex_);
315  callbacks_[listener] = NULL;
316  if ((size_t) listener == callbacks_.size() - 1) {
317  while (!callbacks_.empty() && callbacks_.back() == NULL) {
318  callbacks_.pop_back();
319  }
320  if (bmap_.size() > callbacks_.size()) {
321  bmap_.resize(callbacks_.size());
322  }
323  } else {
324  if ((size_t) listener >= bmap_.size()) {
325  bmap_.resize(listener + 1);
326  }
327  bmap_.set(listener);
328  }
329 }
330 
332  tbb::mutex::scoped_lock lock(mutex_);
333  for (InstanceOpListenersList::iterator iter = callbacks_.begin();
334  iter != callbacks_.end(); ++iter) {
335  if (*iter != NULL) {
336  RoutingInstanceCb cb = *iter;
337  (cb)(name, op);
338  }
339  }
340 }
341 
343  if (deleted()) {
344  deleter()->RetryDelete();
345  } else {
346  BOOST_FOREACH(const string &name, instance_config_lists_[idx]) {
347  const BgpInstanceConfig *config =
348  server()->config_manager()->FindInstance(name);
349  if (!config)
350  continue;
351  LocateRoutingInstance(config);
352  }
353  }
354 
355  instance_config_lists_[idx].clear();
356  return true;
357 }
358 
360  return default_rtinstance_;
361 }
362 
364  return default_rtinstance_;
365 }
366 
368  RoutingInstanceList::iterator iter = instances_.find(name);
369  if (iter != instances_.end())
370  return iter->second;
371  return NULL;
372 }
373 
375  const string &name) const {
376  RoutingInstanceList::const_iterator iter = instances_.find(name);
377  if (iter != instances_.end())
378  return iter->second;
379  return NULL;
380 }
381 
383  const string &name) {
384  tbb::mutex::scoped_lock lock(mutex_);
385  RoutingInstanceList::iterator iter = instances_.find(name);
386  if (iter != instances_.end())
387  return iter->second;
388  return NULL;
389 }
390 
392  tbb::mutex::scoped_lock lock(mutex_);
393  instances_.insert(make_pair(rtinstance->config()->name(),
394  rtinstance));
395 }
396 
398  const BgpInstanceConfig *config) {
399  RoutingInstance *rtinstance = GetRoutingInstanceLocked(config->name());
400  if (rtinstance) {
401  if (rtinstance->deleted()) {
404  config->name(),
405  "Instance recreated before pending deletion is complete");
406  } else {
407  UpdateRoutingInstance(rtinstance, config);
408  }
409  } else {
410  rtinstance = CreateRoutingInstance(config);
411  }
412 }
413 
414 void RoutingInstanceMgr::LocateRoutingInstance(const string &name) {
415  static boost::hash<string> string_hash;
416 
417  if (name == BgpConfigManager::kMasterInstance) {
418  const BgpInstanceConfig *config =
419  server()->config_manager()->FindInstance(name);
420  assert(config);
421  LocateRoutingInstance(config);
422  } else {
423  size_t idx = string_hash(name) % instance_config_lists_.size();
424  instance_config_lists_[idx].insert(name);
425  instance_config_triggers_[idx]->Set();
426  }
427 }
428 
429 // Update VirtualNetwork to RoutingInstance name mapping.
431  const string &virtual_network, const string &instance_name) {
432  tbb::mutex::scoped_lock lock(mutex_);
433 
434  VirtualNetworksMap::iterator iter;
435  bool inserted;
436  tie(iter, inserted) = virtual_networks_.insert(make_pair(virtual_network,
437  set<string>()));
438  assert(iter->second.insert(instance_name).second);
439  return true;
440 }
441 
443  const string &virtual_network, const string &instance_name) {
444  tbb::mutex::scoped_lock lock(mutex_);
445 
446  VirtualNetworksMap::iterator iter = virtual_networks_.find(virtual_network);
447  assert(iter != virtual_networks_.end());
448 
449  // Delete this instance from the set of virtual-network to instances map.
450  assert(iter->second.erase(instance_name) == 1);
451 
452  RoutingInstanceStatsData instance_info;
453  bool mapping_deleted = iter->second.empty();
454 
455  // Delete the mapping if the member set is empty.
456  if (mapping_deleted) {
457  virtual_networks_.erase(iter);
458 
459  // Delete the virtual-network specific UVE.
460  instance_info.set_deleted(true);
461  } else {
462 
463  // Delete this instance's uve, by deleting all table stats.
464  map<string, RoutingTableStats> stats_map;
465  stats_map.insert(make_pair(instance_name, RoutingTableStats()));
466  stats_map[instance_name].set_deleted(true);
467 
468  // Delete all uve stats across all address families.
470  i = static_cast<Address::Family>(i + 1)) {
471  SetTableStatsUve(i, stats_map, &instance_info);
472  }
473  }
474 
475  // Send delete uve.
476  instance_info.set_name(virtual_network);
477  assert(!instance_info.get_name().empty());
478  BGP_UVE_SEND(RoutingInstanceStats, instance_info);
479 
480  return mapping_deleted;
481 }
482 
484  const map<string, RoutingTableStats> &stats_map,
485  RoutingInstanceStatsData *instance_info) const {
486  // By switching over all families, we get compiler to tell us in future,
487  // when ever familiy enum list gets modified.
488  switch (family) {
489  case Address::UNSPEC:
490  break;
491  case Address::INET:
492  case Address::INETMPLS:
493  instance_info->set_raw_ipv4_stats(stats_map);
494  break;
495  case Address::INET6:
496  instance_info->set_raw_ipv6_stats(stats_map);
497  break;
498  case Address::INETVPN:
499  instance_info->set_raw_inetvpn_stats(stats_map);
500  break;
501  case Address::INET6VPN:
502  instance_info->set_raw_inet6vpn_stats(stats_map);
503  break;
504  case Address::RTARGET:
505  instance_info->set_raw_rtarget_stats(stats_map);
506  break;
507  case Address::EVPN:
508  instance_info->set_raw_evpn_stats(stats_map);
509  break;
510  case Address::ERMVPN:
511  instance_info->set_raw_ermvpn_stats(stats_map);
512  break;
513  case Address::MVPN:
514  instance_info->set_raw_mvpn_stats(stats_map);
515  break;
517  break;
518  }
519 }
520 
522  uint32_t out_q_depth = 0;
523 
524  for (RoutingInstanceIterator rit = begin(); rit != end(); ++rit) {
525  RoutingInstanceStatsData instance_info;
526  map<string, RoutingTableStats> stats_map;
527 
528  stats_map.insert(make_pair(rit->second->name(), RoutingTableStats()));
529  RoutingInstance::RouteTableList const rt_list =
530  rit->second->GetTables();
531 
532  // Prepare and send Statistics UVE for each routing-instance.
533  for (RoutingInstance::RouteTableList::const_iterator it =
534  rt_list.begin(); it != rt_list.end(); ++it) {
535  BgpTable *table = it->second;
536 
537  size_t markers;
538  out_q_depth += table->GetPendingRiboutsCount(&markers);
539 
540  stats_map[rit->second->name()].set_prefixes(table->Size());
541  stats_map[rit->second->name()].set_primary_paths(
542  table->GetPrimaryPathCount());
543  stats_map[rit->second->name()].set_secondary_paths(
544  table->GetSecondaryPathCount());
545  stats_map[rit->second->name()].set_infeasible_paths(
546  table->GetInfeasiblePathCount());
547 
548  uint64_t total_paths = table->GetPrimaryPathCount() +
549  table->GetSecondaryPathCount() +
550  table->GetInfeasiblePathCount();
551  stats_map[rit->second->name()].set_total_paths(total_paths);
552  SetTableStatsUve(table->family(), stats_map, &instance_info);
553  }
554 
555  // Set the primary key and trigger uve send.
556  instance_info.set_name(rit->second->GetVirtualNetworkName());
557  assert(!instance_info.get_name().empty());
558  BGP_UVE_SEND(RoutingInstanceStats, instance_info);
559  }
560 
561  return out_q_depth;
562 }
563 
565  const BgpInstanceConfig *config) {
566  RoutingInstance *rtinstance = BgpStaticObjectFactory::Create<RoutingInstance>(
567  config->name(), server_, this, config);
568  uint32_t ri_index = config->index();
569  if (config->name() == BgpConfigManager::kMasterInstance) {
570  default_rtinstance_ = rtinstance;
571  ri_index = 0;
572  }
573 
574  rtinstance->ProcessConfig();
575  InsertRoutingInstance(rtinstance);
576  rtinstance->set_index(ri_index);
577 
578  InstanceTargetAdd(rtinstance);
579  InstanceVnIndexAdd(rtinstance);
581 
582  // Notify clients about routing instance create
583  NotifyInstanceOp(config->name(), INSTANCE_ADD);
584 
585  vector<string> import_rt(config->import_list().begin(),
586  config->import_list().end());
587  vector<string> export_rt(config->export_list().begin(),
588  config->export_list().end());
589  RTINSTANCE_LOG(Create, rtinstance,
590  SandeshLevel::SYS_DEBUG, RTINSTANCE_LOG_FLAG_ALL,
591  import_rt, export_rt, rtinstance->virtual_network_index());
592 
593  // Schedule creation of neighbors for this instance.
595 
596  // Update instance to virtual-network mapping structures.
598  rtinstance->name());
599 
600  // Create MvpnManager for all children mvpn networks.
601  MvpnTable *mvpn_table =
602  dynamic_cast<MvpnTable *>(rtinstance->GetTable(Address::MVPN));
603  mvpn_table->CreateMvpnManagers();
604  return rtinstance;
605 }
606 
608  const BgpInstanceConfig *config) {
609  bool old_always_subscribe = rtinstance->always_subscribe();
610 
611  // Note that InstanceTarget[Remove|Add] depend on the RouteTargetList in
612  // the RoutingInstance.
613  InstanceTargetRemove(rtinstance);
614  InstanceVnIndexRemove(rtinstance);
615  rtinstance->UpdateConfig(config);
616  InstanceTargetAdd(rtinstance);
617  InstanceVnIndexAdd(rtinstance);
618 
619  if (old_always_subscribe != rtinstance->always_subscribe()) {
622  }
623 
624  // Notify clients about routing instance create
626 
627  vector<string> import_rt(config->import_list().begin(),
628  config->import_list().end());
629  vector<string> export_rt(config->export_list().begin(),
630  config->export_list().end());
631  RTINSTANCE_LOG(Update, rtinstance,
632  SandeshLevel::SYS_DEBUG, RTINSTANCE_LOG_FLAG_ALL, import_rt, export_rt,
633  rtinstance->virtual_network_index());
634 }
635 
636 //
637 // Concurrency: BGP Config task
638 //
639 // Trigger deletion of a particular routing-instance
640 //
641 // This involves several asynchronous steps such as deleting all tables in
642 // routing-instance (flush all notifications, registrations and user data).
643 //
645  CHECK_CONCURRENCY("bgp::Config");
646 
647  RoutingInstance *rtinstance = GetRoutingInstance(name);
648 
649  // Ignore if instance is not found as it might already have been deleted.
650  if (rtinstance && rtinstance->deleted()) {
652  rtinstance->GetVirtualNetworkName(), name,
653  "Duplicate instance delete while pending deletion");
654  return;
655  } else if (!rtinstance) {
657  name, name, "Instance not found during delete");
658  return;
659  }
660 
661  InstanceVnIndexRemove(rtinstance);
662  InstanceTargetRemove(rtinstance);
663  rtinstance->ClearConfig();
664 
665  RTINSTANCE_LOG(Delete, rtinstance,
666  SandeshLevel::SYS_DEBUG, RTINSTANCE_LOG_FLAG_ALL);
667 
668  rtinstance->ProcessServiceChainConfig();
669  rtinstance->FlushStaticRouteConfig();
670  rtinstance->FlushRouteAggregationConfig();
671 
673  rtinstance->ManagedDelete();
674 }
675 
676 //
677 // Concurrency: Called from BGP config task manager
678 //
679 // Destroy a routing instance from the data structures
680 //
682  CHECK_CONCURRENCY("bgp::Config");
683 
684  RTINSTANCE_LOG(Destroy, rtinstance,
685  SandeshLevel::SYS_DEBUG, RTINSTANCE_LOG_FLAG_ALL);
686 
688  rtinstance->name());
689 
690  // instance should also be deleted here
691  const string name = rtinstance->name();
692  RoutingInstanceList::iterator loc = instances_.find(rtinstance->name());
693  assert(loc != instances_.end());
694  instances_.erase(loc);
695  int index = rtinstance->index();
696  delete rtinstance;
697  // disable the TraceBuf for the deleted RoutingInstance
698  DisableTraceBuffer(name);
699  // index was allocated in Config Manager so needs to be freed
700  if (index >= 0)
702 
703  if (deleted())
704  return;
705 
706  if (rtinstance == default_rtinstance_) {
707  default_rtinstance_ = NULL;
708  return;
709  }
710 
711  const BgpInstanceConfig *config
712  = server()->config_manager()->FindInstance(name);
713  if (config) {
714  CreateRoutingInstance(config);
715  return;
716  }
717 }
718 
720  const std::string &name) {
721  SandeshTraceBufferPtr trace_buf;
722 
723  trace_buf = GetActiveTraceBuffer(name);
724  if (trace_buf == NULL) {
725  trace_buf = GetTraceBuffer(name);
726  }
727 
728  return trace_buf;
729 }
730 
732  const std::string &name) {
733  tbb::spin_rw_mutex::scoped_lock write_lock(rw_mutex_, true);
734  SandeshTraceBufferPtr trace_buf;
735  RoutingInstanceTraceBufferMap::iterator iter;
736 
737  iter = trace_buffer_active_.find(name);
738  if (iter != trace_buffer_active_.end()) {
739  return iter->second;
740  }
741 
742  iter = trace_buffer_dormant_.find(name);
743  if (iter != trace_buffer_dormant_.end()) {
744  // tracebuf was created for this RoutingInstance in its prior
745  // incarnation
746  trace_buf = iter->second;
747  trace_buffer_dormant_.erase(iter);
748  trace_buffer_dormant_list_.remove(name);
749  trace_buffer_active_.insert(make_pair(name, trace_buf));
750  return trace_buf;
751  }
752 
753  // create new sandesh Buffer
754  trace_buf = SandeshTraceBufferCreate(
755  name + RTINSTANCE_TRACE_BUF, 1000);
756  trace_buffer_active_.insert(make_pair(name, trace_buf));
757 
758  return trace_buf;
759 }
760 
761 void RoutingInstanceMgr::DisableTraceBuffer(const std::string &name) {
762  tbb::spin_rw_mutex::scoped_lock write_lock(rw_mutex_, true);
763  SandeshTraceBufferPtr trace_buf;
764  SandeshTraceBufferPtr trace_buf_delete;
765  RoutingInstanceTraceBufferMap::iterator iter;
766  std::pair<RoutingInstanceTraceBufferMap::iterator, bool> ret;
767  std::string ri_name;
768 
769  // Moving the trace buff from Active map to Dormant map
770  iter = trace_buffer_active_.find(name);
771  if (iter != trace_buffer_active_.end()) {
772  trace_buf = iter->second;
773  trace_buffer_active_.erase(iter);
775  // Move to Dormant map.
777  // Make room in the Dormant map, so creating by:
778  // 1. Delete oldest entries in dormant map
779  // 2. Insert the new entry.
780  size_t del_count = std::min(trace_buffer_dormant_list_.size(),
782  if (!del_count) {
783  // retain the latest deleted RI's TraceBuf
784  del_count = 1;
785  }
786  for (size_t i = 0; i < del_count; i++) {
787  iter = trace_buffer_dormant_.find(
789  assert(iter != trace_buffer_dormant_.end());
790  trace_buf_delete = iter->second;
791  trace_buffer_dormant_.erase(iter);
792  trace_buffer_dormant_list_.pop_front();
793  trace_buf_delete.reset();
794  }
795  }
796  ret = trace_buffer_dormant_.insert(make_pair(name, trace_buf));
797  assert(ret.second == true);
798  trace_buffer_dormant_list_.push_back(name);
799  }
800  }
801 
802  return;
803 }
804 
806 RoutingInstanceMgr::GetActiveTraceBuffer(const std::string &name) const {
807  tbb::spin_rw_mutex::scoped_lock read_lock(rw_mutex_, false);
808  RoutingInstanceTraceBufferMap::const_iterator iter =
809  trace_buffer_active_.find(name);
810 
811  if (iter != trace_buffer_active_.end()) {
812  return iter->second;
813  } else {
814  return SandeshTraceBufferPtr();
815  }
816 }
817 
819 RoutingInstanceMgr::GetDormantTraceBuffer(const std::string &name) const {
820  tbb::spin_rw_mutex::scoped_lock read_lock(rw_mutex_, false);
821  RoutingInstanceTraceBufferMap::const_iterator iter =
822  trace_buffer_dormant_.find(name);
823 
824  if (iter != trace_buffer_dormant_.end()) {
825  return iter->second;
826  } else {
827  return SandeshTraceBufferPtr();
828  }
829 }
830 
832  &name) const {
833  tbb::spin_rw_mutex::scoped_lock read_lock(rw_mutex_, false);
834  RoutingInstanceTraceBufferMap::const_iterator iter =
835  trace_buffer_active_.find(name);
836 
837  return (iter != trace_buffer_active_.end());
838 }
839 
841  &name) const {
842  tbb::spin_rw_mutex::scoped_lock read_lock(rw_mutex_, false);
843  RoutingInstanceTraceBufferMap::const_iterator iter =
844  trace_buffer_dormant_.find(name);
845  return (iter != trace_buffer_dormant_.end());
846 }
847 
848 size_t
850  char *buffer_capacity_str = getenv(
851  "CONTRAIL_ROUTING_INSTANCE_DORMANT_TRACE_BUFFER_SIZE");
852  // return Trace buf capacity 0, if not set in env variable.
853  if (buffer_capacity_str) {
854  size_t env_buffer_capacity = strtoul(buffer_capacity_str, NULL, 0);
855  return env_buffer_capacity;
856  }
857  return 0;
858 }
859 
860 size_t
862  char *buffer_threshold_str = getenv(
863  "CONTRAIL_ROUTING_INSTANCE_DORMANT_TRACE_BUFFER_THRESHOLD");
864  if (buffer_threshold_str) {
865  size_t env_buffer_threshold = strtoul(buffer_threshold_str, NULL, 0);
866  return env_buffer_threshold;
867  }
869 }
870 
872  tbb::spin_rw_mutex::scoped_lock read_lock(rw_mutex_, false);
873  return trace_buffer_active_.size();
874 }
875 
877  tbb::spin_rw_mutex::scoped_lock read_lock(rw_mutex_, false);
878  return trace_buffer_dormant_.size();
879 }
880 
882  const BgpInstanceConfig *config) {
883  if (config->neighbor_list().empty())
884  return;
885  tbb::mutex::scoped_lock lock(mutex_);
886  neighbor_config_list_.insert(config->name());
888 }
889 
891  if (deleted()) {
892  deleter()->RetryDelete();
893  } else {
894  BOOST_FOREACH(const string &name, neighbor_config_list_) {
895  RoutingInstance *rtinstance = GetRoutingInstance(name);
896  if (!rtinstance || rtinstance->deleted())
897  continue;
898  rtinstance->CreateNeighbors();
899  }
900  }
901 
902  neighbor_config_list_.clear();
903  return true;
904 }
905 
906 void RoutingInstanceMgr::ASNUpdateCallback(as_t old_asn, as_t old_local_asn) {
907  if (server_->local_autonomous_system() == old_local_asn)
908  return;
909  for (RoutingInstanceIterator it = begin(); it != end(); ++it) {
910  it->second->FlushAllRTargetRoutes(old_local_asn);
911  it->second->InitAllRTargetRoutes(server_->local_autonomous_system());
912  }
914  const Ip4Address old_identifier(server()->bgp_identifier());
915  master->DeleteMvpnRTargetRoute(old_local_asn, old_identifier);
917 }
918 
920  for (RoutingInstanceIterator it = begin(); it != end(); ++it) {
921  it->second->ProcessIdentifierUpdate(server_->local_autonomous_system());
922  }
925  old_identifier);
927 }
928 
929 //
930 // Disable processing of all instance config lists.
931 // For testing only.
932 //
934  for (size_t idx = 0; idx < instance_config_triggers_.size(); ++idx) {
935  instance_config_triggers_[idx]->set_disable();
936  }
937 }
938 
939 //
940 // Enable processing of all instance config lists.
941 // For testing only.
942 //
944  for (size_t idx = 0; idx < instance_config_triggers_.size(); ++idx) {
945  instance_config_triggers_[idx]->set_enable();
946  }
947 }
948 
949 //
950 // Disable processing of neighbor config list.
951 // For testing only.
952 //
954  neighbor_config_trigger_->set_disable();
955 }
956 
957 //
958 // Enable processing of neighbor config list.
959 // For testing only.
960 //
962  neighbor_config_trigger_->set_enable();
963 }
964 
966 public:
968  : LifetimeActor(server ? server->lifetime_manager() : NULL),
969  parent_(parent) {
970  }
971  virtual bool MayDelete() const {
972  return parent_->MayDelete();
973  }
974  virtual void Shutdown() {
978  parent_->Shutdown();
979  }
980  virtual void Destroy() {
983  }
984 
985 private:
987 };
988 
990  RoutingInstanceMgr *mgr,
991  const BgpInstanceConfig *config)
992  : name_(name), index_(-1), server_(server), mgr_(mgr), config_(config),
993  is_master_(false), always_subscribe_(false), virtual_network_index_(0),
994  virtual_network_allow_transit_(false),
995  virtual_network_pbb_evpn_enable_(false),
996  vxlan_id_(0),
997  deleter_(new DeleteActor(server, this)),
998  manager_delete_ref_(this, NULL),
999  mvpn_project_manager_network_(BgpConfigManager::kFabricInstance) {
1000  if (mgr) {
1001  tbb::mutex::scoped_lock lock(mgr->mutex());
1003  }
1004 }
1005 
1007 }
1008 
1010  CHECK_CONCURRENCY("bgp::Config");
1011 
1012  if (config_->neighbor_list().empty())
1013  return;
1015  BOOST_FOREACH(const string &name, config_->neighbor_list()) {
1016  if (peer_manager->PeerLookup(name))
1017  continue;
1018  peer_manager->PeerResurrect(name);
1019  }
1020 }
1021 
1023  RoutingPolicyMgr *policy_mgr = server()->routing_policy_mgr();
1024  BOOST_FOREACH(RoutingPolicyAttachInfo info,
1026  RoutingPolicy *policy =
1027  policy_mgr->GetRoutingPolicy(info.routing_policy_);
1028  if (policy) {
1029  routing_policies_.push_back(make_pair(policy,
1030  policy->generation()));
1031  }
1032  }
1033 }
1034 
1036  return mgr_->LocateTraceBuffer(name_);
1037 }
1038 
1039 //
1040 // Update the routing policy on the instance
1041 // 1. New policy is added
1042 // 2. Policy order changed
1043 // 3. Policy is removed
1044 // 4. Existing policy gets updated(terms in the policy got modified)
1045 // In any of the above cases, we call routing policy manager to re-evaluate the
1046 // routes in the BgpTables of this routing instance with new set of policies
1047 //
1049  CHECK_CONCURRENCY("bgp::Config", "bgp::ConfigHelper");
1050  RoutingPolicyMgr *policy_mgr = server()->routing_policy_mgr();
1052  routing_policies())) {
1053  // Let RoutingPolicyMgr handle update of routing policy on the instance
1054  policy_mgr->ApplyRoutingPolicy(this);
1055  }
1056 }
1057 
1059  if (is_master_)
1060  return;
1061 
1073  vector<SCAddress::Family> families = list_of
1076 
1077  BOOST_FOREACH(SCAddress::Family family, families) {
1078  const ServiceChainConfig *sc_config =
1079  config_ ? config_->service_chain_info(family) : NULL;
1081  if (sc_config && !sc_config->routing_instance.empty()) {
1082  manager->LocateServiceChain(this, *sc_config);
1083  } else {
1084  manager->StopServiceChain(this);
1085  }
1086  }
1087 }
1088 
1090  if (is_master_)
1091  return;
1092 
1093  vector<Address::Family> families = list_of(Address::INET)(Address::INET6);
1094  BOOST_FOREACH(Address::Family family, families) {
1096  if (!manager && !config_->static_routes(family).empty())
1097  manager = LocateStaticRouteMgr(family);
1098  if (manager)
1099  manager->ProcessStaticRouteConfig();
1100  }
1101 }
1102 
1104  if (is_master_)
1105  return;
1106 
1107  vector<Address::Family> families = list_of(Address::INET)(Address::INET6);
1108  BOOST_FOREACH(Address::Family family, families) {
1110  if (!manager && !config_->static_routes(family).empty())
1111  manager = LocateStaticRouteMgr(family);
1112  if (manager)
1113  manager->UpdateStaticRouteConfig();
1114  }
1115 }
1116 
1118  if (is_master_)
1119  return;
1120 
1121  vector<Address::Family> families = list_of(Address::INET)(Address::INET6);
1122  BOOST_FOREACH(Address::Family family, families) {
1124  if (manager)
1125  manager->FlushStaticRouteConfig();
1126  }
1127 }
1128 
1130  if (is_master_)
1131  return;
1132 
1133  vector<Address::Family> families = list_of(Address::INET)(Address::INET6);
1134  BOOST_FOREACH(Address::Family family, families) {
1136  if (manager)
1137  manager->UpdateAllRoutes();
1138  }
1139 }
1140 
1142  if (is_master_)
1143  return;
1144 
1145  vector<Address::Family> families = list_of(Address::INET)(Address::INET6);
1146  BOOST_FOREACH(Address::Family family, families) {
1147  IRouteAggregator *aggregator = route_aggregator(family);
1148  if (!aggregator && !config_->aggregate_routes(family).empty())
1149  aggregator = LocateRouteAggregator(family);
1150  if (aggregator)
1151  aggregator->ProcessAggregateRouteConfig();
1152  }
1153 }
1154 
1156  if (is_master_)
1157  return;
1158 
1159  vector<Address::Family> families = list_of(Address::INET)(Address::INET6);
1160  BOOST_FOREACH(Address::Family family, families) {
1161  IRouteAggregator *aggregator = route_aggregator(family);
1162  if (!aggregator && !config_->aggregate_routes(family).empty())
1163  aggregator = LocateRouteAggregator(family);
1164  if (aggregator)
1165  aggregator->UpdateAggregateRouteConfig();
1166  }
1167 }
1168 
1170  if (is_master_)
1171  return;
1172 
1173  vector<Address::Family> families = list_of(Address::INET)(Address::INET6);
1174  BOOST_FOREACH(Address::Family family, families) {
1175  IRouteAggregator *aggregator = route_aggregator(family);
1176  if (aggregator)
1177  aggregator->FlushAggregateRouteConfig();
1178  }
1179 }
1180 
1182  if (asn == 0)
1183  return;
1184  string id_str = "target:" + old_ip.to_string() + ":0";
1185  RouteTarget rtarget = RouteTarget::FromString(id_str);
1186  DeleteRTargetRoute(asn, rtarget);
1187 }
1188 
1190  if (asn == 0)
1191  return;
1192  const Ip4Address server_ip(server()->bgp_identifier());
1193  string id_str = "target:" + server_ip.to_string() + ":0";
1194  RouteTarget rtarget = RouteTarget::FromString(id_str);
1195  AddRTargetRoute(asn, rtarget);
1196 }
1197 
1199  RoutingInstanceInfo info = GetDataCollection("");
1200 
1201  // Initialize virtual network info.
1207  vxlan_id_ = config_->vxlan_id();
1208 
1209  // Always subscribe (using RTF) for RTs of PNF service chain instances.
1211 
1212  vector<string> import_rt, export_rt;
1213  BOOST_FOREACH(string irt, config_->import_list()) {
1214  error_code error;
1215  RouteTarget rt = RouteTarget::FromString(irt, &error);
1216  if (!error) {
1217  import_.insert(rt);
1218  import_rt.push_back(irt);
1219  }
1220  }
1221  BOOST_FOREACH(string ert, config_->export_list()) {
1222  error_code error;
1223  RouteTarget rt = RouteTarget::FromString(ert, &error);
1224  if (!error) {
1225  export_.insert(rt);
1226  export_rt.push_back(ert);
1227  }
1228  }
1229  RTINSTANCE_LOG(Update, this,
1230  SandeshLevel::SYS_DEBUG, RTINSTANCE_LOG_FLAG_ALL,
1231  import_rt, export_rt, this->virtual_network_index());
1232 
1233  if (import_rt.size())
1234  info.set_add_import_rt(import_rt);
1235  if (export_rt.size())
1236  info.set_add_export_rt(export_rt);
1237  if (import_rt.size() || export_rt.size())
1239 
1240  // Create BGP Table
1242  assert(mgr_->count() == 0);
1243  is_master_ = true;
1244 
1252 
1253  BgpTable *table_inet = static_cast<BgpTable *>(
1254  server_->database()->CreateTable("inet.0"));
1255  assert(table_inet);
1256  AddTable(table_inet);
1257 
1258  BgpTable *table_inetmpls = static_cast<BgpTable *>(
1259  server_->database()->CreateTable("inet.3"));
1260  assert(table_inetmpls);
1261  AddTable(table_inetmpls);
1262 
1263  BgpTable *table_inet6 = static_cast<BgpTable *>(
1264  server_->database()->CreateTable("inet6.0"));
1265  assert(table_inet6);
1266  AddTable(table_inet6);
1267  } else {
1268  // Create foo.family.0.
1269  // Create path-resolver in INET, INET6 and EVPN VRF tables to enable
1270  // nh_reachability check for fast convergence.
1272  inet_table->LocatePathResolver();
1273 
1274  BgpTable *inet6_table =
1276  inet6_table->LocatePathResolver();
1277 
1279 
1281  evpn_table->LocatePathResolver();
1282 
1284 
1285  // Create path-resolver in mvpn table.
1286  table->LocatePathResolver();
1287  }
1288 
1293 }
1294 
1296  CHECK_CONCURRENCY("bgp::Config", "bgp::ConfigHelper");
1297 
1298  // This is a noop in production code. However unit tests may pass a
1299  // new object.
1300  config_ = cfg;
1301 
1302  // Always subscribe (using RTF) for RTs of PNF service chain instances.
1304 
1305  // Figure out if there's a significant configuration change that requires
1306  // notifying routes to all listeners.
1307  bool notify_routes = false;
1309  notify_routes = true;
1312  notify_routes = true;
1313  if (virtual_network_ != cfg->virtual_network())
1314  notify_routes = true;
1316  notify_routes = true;
1317 
1318  // Trigger notification of all routes in each table.
1319  if (notify_routes) {
1320  BOOST_FOREACH(RouteTableList::value_type &entry, vrf_tables_by_name_) {
1321  BgpTable *table = entry.second;
1322  table->NotifyAllEntries();
1323  }
1324  }
1325 
1326  // Update all static routes so that they reflect the new OriginVn.
1329 
1330  string prev_vn_name = GetVirtualNetworkName();
1331 
1332  // Update virtual network info.
1334 
1335  // Recreate instance stats' UVE, if its key: virtual_network is modified.
1336  if (prev_vn_name != GetVirtualNetworkName()) {
1337  mgr_->DeleteVirtualNetworkMapping(prev_vn_name, name_);
1339  }
1340 
1344  vxlan_id_ = cfg->vxlan_id();
1345 
1346  // Master routing instance doesn't have import & export list
1347  // Master instance imports and exports all RT
1349  return;
1350 
1351  RouteTargetList future_import;
1352  vector<string> add_import_rt, remove_import_rt;
1353  BOOST_FOREACH(const string &rtarget_str, cfg->import_list()) {
1354  error_code error;
1355  RouteTarget rt = RouteTarget::FromString(rtarget_str, &error);
1356  if (!error)
1357  future_import.insert(rt);
1358  }
1359  set_synchronize(&import_, &future_import,
1360  boost::bind(&RoutingInstance::AddRouteTarget, this, true,
1361  &add_import_rt, _1),
1362  boost::bind(&RoutingInstance::DeleteRouteTarget, this, true,
1363  &remove_import_rt, _1));
1364 
1365  RouteTargetList future_export;
1366  vector<string> add_export_rt, remove_export_rt;
1367  BOOST_FOREACH(const string &rtarget_str, cfg->export_list()) {
1368  error_code error;
1369  RouteTarget rt = RouteTarget::FromString(rtarget_str, &error);
1370  if (!error)
1371  future_export.insert(rt);
1372  }
1373  set_synchronize(&export_, &future_export,
1374  boost::bind(&RoutingInstance::AddRouteTarget, this, false,
1375  &add_export_rt, _1),
1376  boost::bind(&RoutingInstance::DeleteRouteTarget, this, false,
1377  &remove_export_rt, _1));
1378 
1379  RoutingInstanceInfo info = GetDataCollection("");
1380  if (add_import_rt.size())
1381  info.set_add_import_rt(add_import_rt);
1382  if (remove_import_rt.size())
1383  info.set_remove_import_rt(remove_import_rt);
1384  if (add_export_rt.size())
1385  info.set_add_export_rt(add_export_rt);
1386  if (remove_export_rt.size())
1387  info.set_remove_export_rt(remove_export_rt);
1388  if (add_import_rt.size() || remove_import_rt.size() ||
1389  add_export_rt.size() || remove_export_rt.size())
1391 
1396 }
1397 
1399  CHECK_CONCURRENCY("bgp::Config");
1400  config_ = NULL;
1401 }
1402 
1404  // RoutingInstanceMgr logs the delete for non-master instances.
1405  if (IsMasterRoutingInstance()) {
1406  RTINSTANCE_LOG(Delete, this,
1407  SandeshLevel::SYS_DEBUG, RTINSTANCE_LOG_FLAG_ALL);
1408  }
1409  deleter_->Delete();
1410 }
1411 
1413  CHECK_CONCURRENCY("bgp::Config");
1414 
1415  RTINSTANCE_LOG(Shutdown, this,
1416  SandeshLevel::SYS_DEBUG, RTINSTANCE_LOG_FLAG_ALL);
1417 
1418  ClearConfig();
1420  if (is_master_) {
1421  const Ip4Address old_identifier(server()->bgp_identifier());
1423  old_identifier);
1424  }
1425  ClearRouteTarget();
1426 
1430 }
1431 
1433  return true;
1434 }
1435 
1437  return deleter_.get();
1438 }
1439 
1441  return deleter_.get();
1442 }
1443 
1445  return deleter()->IsDeleted();
1446 }
1447 
1449  if (!virtual_network_.empty())
1450  return virtual_network_;
1451  size_t pos = name_.rfind(':');
1452  if (pos == string::npos) {
1453  return name_;
1454  } else {
1455  return name_.substr(0, pos);
1456  }
1457 }
1458 
1460  return virtual_network_index_;
1461 }
1462 
1465 }
1466 
1469 }
1470 
1472  return vxlan_id_;
1473 }
1474 
1476  Address::Family vpn_family) {
1477  BgpTable *table = GetTable(vrf_family);
1478  if (table) {
1479  RoutePathReplicator *replicator = server_->replicator(vpn_family);
1480  BOOST_FOREACH(RouteTarget rt, import_) {
1481  replicator->Leave(table, rt, true);
1482  }
1483  BOOST_FOREACH(RouteTarget rt, export_) {
1484  replicator->Leave(table, rt, false);
1485  }
1486  }
1487 }
1488 
1490  const RouteTarget &rtarget) {
1491  CHECK_CONCURRENCY("bgp::Config", "bgp::ConfigHelper");
1492 
1493  RTargetPrefix prefix(asn, rtarget);
1494  RTargetRoute rt_key(prefix);
1495 
1497  BgpTable *table = master->GetTable(Address::RTARGET);
1498  DBTablePartition *tbl_partition =
1499  static_cast<DBTablePartition *>(table->GetTablePartition(0));
1500 
1501  tbb::mutex::scoped_lock lock(mgr_->mutex());
1502  RTargetRoute *route =
1503  static_cast<RTargetRoute *>(tbl_partition->Find(&rt_key));
1504  if (!route) {
1505  route = new RTargetRoute(prefix);
1506  tbl_partition->Add(route);
1507  } else {
1508  route->ClearDelete();
1509  }
1510 
1511  if (route->FindPath(BgpPath::Local, index_))
1512  return;
1513 
1514  BgpAttrSpec attr_spec;
1516  attr_spec.push_back(&nexthop);
1518  attr_spec.push_back(&origin);
1519  BgpAttrPtr attr = server_->attr_db()->Locate(attr_spec);
1520 
1521  BgpPath *path = new BgpPath(index_, BgpPath::Local, attr);
1522  route->InsertPath(path);
1523  tbl_partition->Notify(route);
1524  BGP_LOG_ROUTE(table, static_cast<IPeer *>(NULL),
1525  route, "Insert Local path with path id " << index_);
1526 }
1527 
1529  const RouteTarget &rtarget) {
1530  CHECK_CONCURRENCY("bgp::Config", "bgp::ConfigHelper");
1531 
1532  if (asn == 0)
1533  return;
1534 
1535  RTargetPrefix prefix(asn, rtarget);
1536  RTargetRoute rt_key(prefix);
1537 
1539  BgpTable *table = master->GetTable(Address::RTARGET);
1540  DBTablePartition *tbl_partition =
1541  static_cast<DBTablePartition *>(table->GetTablePartition(0));
1542 
1543  tbb::mutex::scoped_lock lock(mgr_->mutex());
1544  RTargetRoute *route =
1545  static_cast<RTargetRoute *>(tbl_partition->Find(&rt_key));
1546  if (!route || !route->RemovePath(BgpPath::Local, index_))
1547  return;
1548 
1549  BGP_LOG_ROUTE(table, static_cast<IPeer *>(NULL),
1550  route, "Delete Local path with path id " << index_);
1551  if (!route->HasPaths()) {
1552  tbl_partition->Delete(route);
1553  } else {
1554  tbl_partition->Notify(route);
1555  }
1556 }
1557 
1559  if (is_master_)
1560  return;
1561 
1562  CHECK_CONCURRENCY("bgp::Config", "bgp::ConfigHelper");
1563  BOOST_FOREACH(RouteTarget rtarget, import_) {
1564  if (asn != 0 && always_subscribe_)
1565  AddRTargetRoute(asn, rtarget);
1566  }
1567 }
1568 
1570  if (is_master_)
1571  return;
1572 
1573  CHECK_CONCURRENCY("bgp::Config", "bgp::ConfigHelper");
1574  BOOST_FOREACH(RouteTarget rtarget, import_) {
1575  DeleteRTargetRoute(asn, rtarget);
1576  }
1577 }
1578 
1580  FlushAllRTargetRoutes(asn);
1581  InitAllRTargetRoutes(asn);
1583 }
1584 
1586  vector<string> *change_list, RouteTargetList::const_iterator it) {
1587  BgpTable *ermvpn_table = GetTable(Address::ERMVPN);
1588  RoutePathReplicator *ermvpn_replicator =
1590  BgpTable *mvpn_table = GetTable(Address::MVPN);
1591  RoutePathReplicator *mvpn_replicator =
1593  BgpTable *evpn_table = GetTable(Address::EVPN);
1594  RoutePathReplicator *evpn_replicator =
1596  BgpTable *inet_table = GetTable(Address::INET);
1597  RoutePathReplicator *inetvpn_replicator =
1599  BgpTable *inet6_table = GetTable(Address::INET6);
1600  RoutePathReplicator *inet6vpn_replicator =
1602 
1603  change_list->push_back(it->ToString());
1604  if (import) {
1605  import_.insert(*it);
1608  } else {
1609  export_.insert(*it);
1610  }
1611 
1612  ermvpn_replicator->Join(ermvpn_table, *it, import);
1613  mvpn_replicator->Join(mvpn_table, *it, import);
1614  evpn_replicator->Join(evpn_table, *it, import);
1615  inetvpn_replicator->Join(inet_table, *it, import);
1616  inet6vpn_replicator->Join(inet6_table, *it, import);
1617 }
1618 
1620  vector<string> *change_list, RouteTargetList::iterator it) {
1621  BgpTable *ermvpn_table = GetTable(Address::ERMVPN);
1622  RoutePathReplicator *ermvpn_replicator =
1624  BgpTable *mvpn_table = GetTable(Address::MVPN);
1625  RoutePathReplicator *mvpn_replicator =
1627  BgpTable *evpn_table = GetTable(Address::EVPN);
1628  RoutePathReplicator *evpn_replicator =
1630  BgpTable *inet_table = GetTable(Address::INET);
1631  RoutePathReplicator *inetvpn_replicator =
1633  BgpTable *inet6_table = GetTable(Address::INET6);
1634  RoutePathReplicator *inet6vpn_replicator =
1636 
1637  ermvpn_replicator->Leave(ermvpn_table, *it, import);
1638  mvpn_replicator->Leave(mvpn_table, *it, import);
1639  evpn_replicator->Leave(evpn_table, *it, import);
1640  inetvpn_replicator->Leave(inet_table, *it, import);
1641  inet6vpn_replicator->Leave(inet6_table, *it, import);
1642 
1643  change_list->push_back(it->ToString());
1644  if (import) {
1646  import_.erase(it);
1647  } else {
1648  export_.erase(it);
1649  }
1650 }
1651 
1653  CHECK_CONCURRENCY("bgp::Config");
1654  if (IsMasterRoutingInstance()) {
1655  return;
1656  }
1657 
1663 
1664  import_.clear();
1665  export_.clear();
1666 }
1667 
1669  BgpTable *rtargettbl = static_cast<BgpTable *>(
1670  server_->database()->CreateTable("bgp.rtarget.0"));
1671  RTINSTANCE_LOG_TABLE(Create, this, rtargettbl, SandeshLevel::SYS_DEBUG,
1673  AddTable(rtargettbl);
1674  return rtargettbl;
1675 }
1676 
1678  string table_name = GetTableName(name(), vpn_family);
1679  BgpTable *table = static_cast<BgpTable *>(
1680  server_->database()->CreateTable(table_name));
1681  assert(table);
1682 
1683  AddTable(table);
1684  RTINSTANCE_LOG_TABLE(Create, this, table, SandeshLevel::SYS_DEBUG,
1686  assert(server_->rtarget_group_mgr()->empty());
1687  RoutePathReplicator *replicator = server_->replicator(vpn_family);
1688  replicator->Initialize();
1689  return table;
1690 }
1691 
1693  Address::Family vpn_family) {
1694  string table_name = GetTableName(name(), vrf_family);
1695  BgpTable *table = static_cast<BgpTable *>(
1696  server_->database()->CreateTable(table_name));
1697  assert(table);
1698 
1699  AddTable(table);
1700  RTINSTANCE_LOG_TABLE(Create, this, table, SandeshLevel::SYS_DEBUG,
1702  RoutePathReplicator *replicator = server_->replicator(vpn_family);
1703  BOOST_FOREACH(RouteTarget rt, import_) {
1704  replicator->Join(table, rt, true);
1705  }
1706  BOOST_FOREACH(RouteTarget rt, export_) {
1707  replicator->Join(table, rt, false);
1708  }
1709  return table;
1710 }
1711 
1713  vrf_tables_by_name_.insert(make_pair(tbl->name(), tbl));
1714  vrf_tables_by_family_.insert(make_pair(tbl->family(), tbl));
1715  tbl->set_routing_instance(this);
1716  RoutingInstanceInfo info = GetDataCollection("Add");
1717  info.set_family(Address::FamilyToString(tbl->family()));
1719 }
1720 
1722  RoutingInstanceInfo info = GetDataCollection("Remove");
1723  info.set_family(Address::FamilyToString(tbl->family()));
1724  vrf_tables_by_name_.erase(tbl->name());
1725  vrf_tables_by_family_.erase(tbl->family());
1727 }
1728 
1729 //
1730 // Concurrency: BGP Config task
1731 //
1732 // Remove the table from the map and delete the table data structure
1733 //
1735  CHECK_CONCURRENCY("bgp::Config");
1736 
1737  BgpTable *table = static_cast<BgpTable *>(dbtable);
1738 
1739  RTINSTANCE_LOG_TABLE(Destroy, this, table,
1740  SandeshLevel::SYS_DEBUG, RTINSTANCE_LOG_FLAG_ALL);
1741 
1742  // Remove this table from various data structures
1743  server_->database()->RemoveTable(table);
1744  RemoveTable(table);
1745 
1746  // Make sure that there are no routes left in this table
1747  assert(table->Size() == 0);
1748 
1749  delete table;
1750 }
1751 
1752 string RoutingInstance::GetTableName(string instance_name,
1753  Address::Family fmly) {
1754  string table_name;
1755  if (instance_name == BgpConfigManager::kMasterInstance) {
1756  if ((fmly == Address::INET) || (fmly == Address::INET6)) {
1757  table_name = Address::FamilyToTableString(fmly) + ".0";
1758  } else if (fmly == Address::INETMPLS) {
1759  table_name = Address::FamilyToTableString(fmly) + ".3";
1760  } else {
1761  table_name = "bgp." + Address::FamilyToTableString(fmly) + ".0";
1762  }
1763  } else {
1764  table_name =
1765  instance_name + "." + Address::FamilyToTableString(fmly) + ".0";
1766  }
1767  return table_name;
1768 }
1769 
1771  RouteTableFamilyList::const_iterator loc = vrf_tables_by_family_.find(fmly);
1772  return (loc != vrf_tables_by_family_.end() ? loc->second : NULL);
1773 }
1774 
1776  RouteTableFamilyList::const_iterator loc = vrf_tables_by_family_.find(fmly);
1777  return (loc != vrf_tables_by_family_.end() ? loc->second : NULL);
1778 }
1779 
1780 string RoutingInstance::GetVrfFromTableName(const string table) {
1781  static set<string> master_tables = list_of("inet.0")("inet.3")("inet6.0");
1782  static set<string> vpn_tables =
1783  list_of("bgp.l3vpn.0")("bgp.ermvpn.0")("bgp.evpn.0")("bgp.rtarget.0")
1784  ("bgp.l3vpn-inet6.0")("bgp.mvpn.0");
1785 
1786  if (master_tables.find(table) != master_tables.end())
1788  if (vpn_tables.find(table) != vpn_tables.end())
1790 
1791  size_t pos1 = table.rfind('.');
1792  if (pos1 == string::npos)
1793  return "__unknown__";
1794  size_t pos2 = table.rfind('.', pos1 - 1);
1795  if (pos2 == string::npos)
1796  return "__unknown__";
1797 
1798  return table.substr(0, pos2);
1799 }
1800 
1802  index_ = index;
1803  if (is_master_)
1804  return;
1805 
1807 }
1808 
1809 RoutingInstanceInfo RoutingInstance::GetDataCollection(const char *operation) {
1810  RoutingInstanceInfo info;
1811  info.set_name(GetVirtualNetworkName());
1812  info.set_instance_name(name_);
1813  info.set_hostname(server_->localname());
1814  if (rd_.get()) info.set_route_distinguisher(rd_->ToString());
1815  if (operation) info.set_operation(operation);
1816  return info;
1817 }
1818 
1819 //
1820 // Return true if one of the route targets in the ExtCommunity is in the
1821 // set of export RouteTargets for this RoutingInstance.
1822 //
1824  if (!extcomm)
1825  return false;
1826 
1827  BOOST_FOREACH(const ExtCommunity::ExtCommunityValue &value,
1828  extcomm->communities()) {
1829  if (!ExtCommunity::is_route_target(value))
1830  continue;
1831  RouteTarget rtarget(value);
1832  if (export_.find(rtarget) != export_.end())
1833  return true;
1834  }
1835 
1836  return false;
1837 }
1838 
1839 // Return true if the route is a service-chain route
1841  const BgpTable *table = route->table();
1842  if (!table) {
1843  return false;
1844  }
1845  const BgpInstanceConfig *rt_config = this->config();
1846  if (!rt_config) {
1847  return false;
1848  }
1849  SCAddress::Family sc_family =
1851  const ServiceChainConfig *sc_config =
1852  rt_config->service_chain_info(sc_family);
1853  if (!sc_config) {
1854  return false;
1855  }
1856  return true;
1857 }
1858 
1859 //
1860 // On given route/path apply the routing policy
1861 // Called from
1862 // * InsertPath [While adding the path for the first time]
1863 // * While walking the routing table to apply updating routing policy
1864 //
1865 
1867  BgpPath *path) const {
1868  ExtCommunityPtr ext_community = path->GetOriginalAttr()->ext_community();
1869  if (path->IsReplicated() &&
1870  ext_community && ext_community->GetSubClusterId()) {
1871  // If self sub-cluster id macthes with what is associated with the route
1872  // then no need to apply policy.
1873  if (route->SubClusterId() == ext_community->GetSubClusterId()) {
1874  BGP_LOG_ROUTE(route->table(), static_cast<IPeer *>(path->GetPeer()),
1875  route, "Not applying policy since sub-cluster associated "
1876  "with path is same as that with route");
1877  return true;
1878  }
1879  }
1880  // Don't apply routing policy on secondary path for service chain route
1881  if (path->IsReplicated() && IsServiceChainRoute(route)) {
1882  BGP_LOG_ROUTE(route->table(), static_cast<IPeer *>(path->GetPeer()),
1883  route, "Not applying policy for service-chain secondary "
1884  "routes");
1885  return true;
1886  }
1887  const RoutingPolicyMgr *policy_mgr = server()->routing_policy_mgr();
1888  // Take snapshot of original attribute
1889  BgpAttr *out_attr = new BgpAttr(*(path->GetOriginalAttr()));
1890  BOOST_FOREACH(RoutingPolicyInfo info, routing_policies()) {
1891  RoutingPolicyPtr policy = info.first;
1892  // Process the routing policy on original attribute and prefix
1893  // Update of the attribute based on routing policy action is done
1894  // on the snapshot of original attribute passed to this function
1896  policy_mgr->ExecuteRoutingPolicy(policy.get(), route,
1897  path, out_attr);
1898  if (result.first) {
1899  // Hit a terminal policy
1900  if (!result.second) {
1901  // Result of the policy is reject
1902  path->SetPolicyReject();
1903  } else if (path->IsPolicyReject()) {
1904  // Result of the policy is Accept
1905  // Clear the reject flag is marked before
1906  path->ResetPolicyReject();
1907  }
1908  IPeer *peer = path->GetPeer();
1909  // Process default tunnel encapsulation that may be configured per
1910  // address family on the peer. 'peer' is not expected to be NULL
1911  // except in unit tests.
1912  if (peer) {
1913  peer->ProcessPathTunnelEncapsulation(path, out_attr,
1914  server_->extcomm_db(), route->table());
1915  }
1916  BgpAttrPtr modified_attr = server_->attr_db()->Locate(out_attr);
1917  // Update the path with new set of attributes
1918  path->SetAttr(modified_attr, path->GetOriginalAttr());
1919  return result.second;
1920  }
1921  }
1922  // After processing all the routing policy,,
1923  // We are here means, all the routing policies have accepted the route
1924  IPeer *peer = path->GetPeer();
1925  if (peer) {
1926  peer->ProcessPathTunnelEncapsulation(path, out_attr,
1927  server_->extcomm_db(), route->table());
1928  }
1929  BgpAttrPtr modified_attr = server_->attr_db()->Locate(out_attr);
1930  path->SetAttr(modified_attr, path->GetOriginalAttr());
1931  // Clear the reject if marked so in past
1932  if (path->IsPolicyReject()) path->ResetPolicyReject();
1933  return true;
1934 }
1935 
1937  Address::Family family) {
1939  if (manager)
1940  return manager;
1941  if (family == Address::INET) {
1942  inet_static_route_mgr_.reset(
1943  BgpStaticObjectFactory::Create<IStaticRouteMgr, Address::INET>(this));
1944  return inet_static_route_mgr_.get();
1945  } else if (family == Address::INET6) {
1947  BgpStaticObjectFactory::Create<IStaticRouteMgr, Address::INET6>(this));
1948  return inet6_static_route_mgr_.get();
1949  }
1950  return NULL;
1951 }
1952 
1954  Address::Family family) {
1955  IRouteAggregator *aggregator = route_aggregator(family);
1956  if (aggregator)
1957  return aggregator;
1958  if (family == Address::INET) {
1959  GetTable(family)->LocatePathResolver();
1960  inet_route_aggregator_.reset(
1961  BgpStaticObjectFactory::Create<IRouteAggregator, Address::INET>(this));
1962  inet_route_aggregator_->Initialize();
1963  return inet_route_aggregator_.get();
1964  } else if (family == Address::INET6) {
1965  GetTable(family)->LocatePathResolver();
1967  BgpStaticObjectFactory::Create<IRouteAggregator, Address::INET6>(this));
1968  inet6_route_aggregator_->Initialize();
1969  return inet6_route_aggregator_.get();
1970  }
1971  return NULL;
1972 }
1973 
1975  if (family == Address::INET) {
1976  inet_route_aggregator_.reset();
1977  } else if (family == Address::INET6) {
1978  inet6_route_aggregator_.reset();
1979  }
1980 }
1981 
1982 // Check whether the route is aggregating route
1984  const BgpRoute *route) const {
1985  if (!route_aggregator(table->family())) return false;
1986  return route_aggregator(table->family())->IsAggregateRoute(route);
1987 }
1988 
1989 // Check whether the route is contributing route to aggregate route
1991  const BgpRoute *route) const {
1992  if (!route_aggregator(table->family())) return false;
1993  return route_aggregator(table->family())->IsContributingRoute(route);
1994 }
1995 
1997  SCAddress sc_addr;
1998  SCAddress::Family sc_family =
1999  sc_addr.AddressFamilyToSCFamily(fmly);
2000  const ServiceChainConfig *sc_config =
2001  config_ ? config_->service_chain_info(sc_family) : NULL;
2002  if (sc_config && !sc_config->routing_instance.empty()) {
2003  RoutingInstance *dest =
2005  if (dest) return dest->virtual_network_index();
2006  }
2007  return virtual_network_index_;
2008 }
2009 
2011  return (peer_manager_ ? peer_manager_->size() : 0);
2012 }
2013 
2015  if (!peer_manager_)
2016  peer_manager_.reset(BgpStaticObjectFactory::Create<PeerManager>(this));
2017  return peer_manager_.get();
2018 }
2019 
2020 // Get primary routing instance name from service RI names which works for both
2021 // in-network and transparent service chains. Use name based lookup to identify
2022 // the primary RI of service instance.
2023 // Service RI Name Format: <domain>:<project>:<VN>:<ServiceRI>
2024 // Primaru RI Name Format: <domain>:<project>:<VN>:<VN>
2026  string n = name;
2027  vector<string> tokens;
2028  boost::split(tokens, n, boost::is_any_of(":"));
2029  if (tokens.size() < 3)
2030  return "";
2031  ostringstream os;
2032  os << tokens[0] << ":" << tokens[1] << ":" << tokens[2] << ":" << tokens[2];
2033  return os.str();
2034 }
void DisableInstanceConfigListProcessing()
BgpTable * VrfTableCreate(Address::Family vrf_family, Address::Family vpn_family)
const RoutingInstance * GetInstanceByTarget(const RouteTarget &target) const
void ResetPolicyReject()
Definition: bgp_path.h:116
InstanceTargetMap target_map_
void AddTable(BgpTable *tbl)
virtual void StopServiceChain(RoutingInstance *rtinstance)=0
#define RTINSTANCE_LOG_TABLE(type, rtinstance, table, level, flags,...)
const std::string & virtual_network() const
Definition: bgp_config.h:454
bool MayDelete() const
RoutingInstance(std::string name, BgpServer *server, RoutingInstanceMgr *mgr, const BgpInstanceConfig *config)
const BgpInstanceConfig * config_
virtual void ResetRoutingInstanceIndexBit(int index)=0
MvpnProjectManagerNetworks mvpn_project_managers_
size_t GetRoutingInstanceActiveTraceBufSize() const
const RouteTargetList & import_list() const
Definition: bgp_config.h:442
size_t GetRoutingInstanceDormantTraceBufSize() const
RoutingInstanceTraceBufferMap trace_buffer_dormant_
const RouteTargetList & GetImportList() const
RoutingInstance * default_rtinstance_
boost::array< uint8_t, 8 > ExtCommunityValue
Definition: community.h:152
virtual ~RoutingInstance()
void STLDeleteValues(Container *container)
Definition: util.h:101
BgpTable * GetTable(Address::Family fmly)
virtual BgpPeer * PeerLookup(std::string name) const
int RegisterInstanceOpCallback(RoutingInstanceCb cb)
The TaskScheduler keeps track of what tasks are currently schedulable. When a task is enqueued it is ...
Definition: task.h:178
static std::string GetTableName(std::string instance_name, Address::Family fmly)
TypePtr Locate(Type *attr)
const RouteTargetList & GetExportList() const
PeerManager * peer_manager()
void DisableTraceBuffer(const std::string &name)
void FlushRouteAggregationConfig()
RoutingInstance * GetRoutingInstance(const std::string &name)
size_t count() const
boost::scoped_ptr< TaskTrigger > neighbor_config_trigger_
void DeleteRTargetRoute(as_t asn, const RouteTarget &rtarget)
void UpdateConfig(const BgpInstanceConfig *config)
int virtual_network_index() const
bool set_synchronize(const SetType *set1, const SetType *set2, AddFunctor add_fn, DelFunctor del_fn)
Definition: set_util.h:21
void EnableNeighborConfigListProcessing()
BgpServer * server()
void UnregisterASNUpdateCallback(int listener)
Definition: bgp_server.cc:873
DBEntry * Find(const DBEntry *entry)
virtual void UpdateAggregateRouteConfig()=0
RoutingPolicy * GetRoutingPolicy(const std::string &name)
DBTableBase * CreateTable(const std::string &name)
Definition: db.cc:99
DB * database()
Definition: bgp_server.h:200
bool UpdateRoutingPolicyList(const RoutingPolicyConfigList &cfg_list, RoutingPolicyAttachList *oper_list)
SandeshTraceBufferPtr GetDormantTraceBuffer(const std::string &name) const
RoutingInstanceList instances_
Family
Definition: address.h:24
static const char * kMasterInstance
Definition: bgp_config.h:764
IRouteAggregator * LocateRouteAggregator(Address::Family family)
boost::scoped_ptr< IRouteAggregator > inet6_route_aggregator_
LifetimeActor * deleter()
void DestroyRouteAggregator(Address::Family family)
boost::scoped_ptr< IRouteAggregator > inet_route_aggregator_
BgpTable * RTargetTableCreate()
virtual void DeleteRoutingInstance(const std::string &name)
void InstanceVnIndexRemove(const RoutingInstance *rti)
void IdentifierUpdateCallback(Ip4Address old_identifier)
DeleteActor(BgpServer *server, RoutingInstance *parent)
void ProcessRoutingPolicyConfig()
void InitAllRTargetRoutes(as_t asn)
static std::string GetPrimaryRoutingInstanceName(const string &name_in)
#define BGP_LOG_ROUTE(table, peer, route, arg)
Definition: bgp_log.h:247
RoutingInstanceIterator end()
#define BGP_UVE_SEND(type, object)
Definition: bgp_log.h:46
std::string virtual_network_
void NotifyInstanceOp(std::string name, Operation deleted)
std::vector< BgpAttribute * > BgpAttrSpec
Definition: bgp_attr.h:822
const std::string & name() const
void LocatePathResolver()
Definition: bgp_table.cc:1074
void UpdateRouteAggregationConfig()
const RouteTargetList & export_list() const
Definition: bgp_config.h:446
int vxlan_id() const
int GetVnIndexByExtCommunity(const ExtCommunity *community) const
RoutingInstance * GetDefaultRoutingInstance()
boost::scoped_ptr< IStaticRouteMgr > inet_static_route_mgr_
RoutePathReplicator * replicator(Address::Family family)
Definition: bgp_server.h:146
static Family AddressFamilyToSCFamily(Address::Family family)
void AddRouteTarget(bool import, std::vector< std::string > *change_list, RouteTargetList::const_iterator it)
LifetimeRef< RoutingInstanceMgr > server_delete_ref_
void NotifyAllEntries()
Definition: db_table.cc:596
RoutingPolicyAttachList * routing_policies()
RoutingInstanceInfo GetDataCollection(const char *operation)
boost::scoped_ptr< PeerManager > peer_manager_
static std::string FamilyToTableString(Family family)
Definition: address.cc:67
bool virtual_network_pbb_evpn_enable() const
Definition: bgp_config.h:471
int GetVnIndexByRouteTarget(const RouteTarget &rtarget) const
virtual void UpdateAllRoutes()=0
boost::shared_ptr< TraceBuffer< SandeshTrace > > SandeshTraceBufferPtr
Definition: sandesh_trace.h:18
void Delete(DBEntryBase *)
virtual const BgpInstanceConfig * FindInstance(const std::string &name) const =0
virtual Address::Family family() const =0
BgpServer * server()
uint32_t as_t
Definition: bgp_common.h:21
SandeshTraceBufferPtr LocateTraceBuffer(const std::string &name)
Definition: ipeer.h:186
void RemoveTable(DBTableBase *tbl_base)
Definition: db.cc:87
void ProcessServiceChainConfig()
RouteTableFamilyList vrf_tables_by_family_
RouteTargetList import_
boost::dynamic_bitset bmap_
void RetryDelete()
Definition: lifetime.cc:71
int GetTaskId(const std::string &name)
Definition: task.cc:856
void CreateMvpnManagers()
Definition: mvpn_table.cc:123
boost::scoped_ptr< DeleteActor > deleter_
virtual bool LocateServiceChain(RoutingInstance *rtinstance, const ServiceChainConfig &config)=0
bool has_pnf() const
Definition: bgp_config.h:451
RoutingInstanceTraceBufferMap trace_buffer_active_
virtual void UpdateStaticRouteConfig()=0
as_t local_autonomous_system() const
Definition: bgp_server.h:207
bool virtual_network_allow_transit() const
size_t GetEnvRoutingInstanceDormantTraceBufferThreshold() const
void CreateRoutingInstanceNeighbors(const BgpInstanceConfig *config)
RoutingPolicyMgr * routing_policy_mgr()
Definition: bgp_server.h:106
void DeleteRouteTarget(bool import, std::vector< std::string > *change_list, RouteTargetList::iterator it)
boost::intrusive_ptr< const BgpAttr > BgpAttrPtr
Definition: bgp_attr.h:991
virtual size_t Size() const
Definition: db_table.cc:507
void DestroyDBTable(DBTable *table)
bool IsAggregateRoute(const BgpTable *table, const BgpRoute *route) const
IRouteAggregator * route_aggregator(Address::Family family) const
RoutingInstance * CreateRoutingInstance(const BgpInstanceConfig *config)
void DisableNeighborConfigListProcessing()
void DeleteMvpnRTargetRoute(as_t old_asn, Ip4Address old_ip)
int index() const
Definition: bgp_config.h:509
bool virtual_network_pbb_evpn_enable_
bool ProcessInstanceConfigList(int idx)
const uint64_t GetInfeasiblePathCount() const
Definition: bgp_table.h:165
void DestroyRoutingInstance(RoutingInstance *rtinstance)
const ServiceChainConfig * service_chain_info(SCAddress::Family family) const
Definition: bgp_config.cc:379
const ExtCommunityList & communities() const
Definition: community.h:180
bool IsDeleted() const
Definition: lifetime.h:131
bool MayDelete() const
void PeerResurrect(std::string name)
Definition: peer_manager.cc:64
ExtCommunityDB * extcomm_db()
Definition: bgp_server.h:187
static TaskScheduler * GetInstance()
Definition: task.cc:547
void Reset(LifetimeActor *actor)
Definition: lifetime.h:82
void UpdateRoutingPolicyConfig()
tbb::spin_rw_mutex rw_mutex_
BgpConfigManager * config_manager()
Definition: bgp_server.h:100
#define RTINSTANCE_TRACE_BUF
IServiceChainMgr * service_chain_mgr(SCAddress::Family family)
Definition: bgp_server.h:134
boost::intrusive_ptr< const ExtCommunity > ExtCommunityPtr
Definition: community.h:448
#define RTINSTANCE_LOG_FLAG_ALL
boost::scoped_ptr< DeleteActor > deleter_
uint32_t SendTableStatsUve()
RoutingPolicy::PolicyResult ExecuteRoutingPolicy(const RoutingPolicy *policy, const BgpRoute *route, const BgpPath *path, BgpAttr *attr) const
boost::function< void(std::string, int)> RoutingInstanceCb
size_t peer_manager_size() const
LifetimeRef< RoutingInstance > manager_delete_ref_
std::string routing_instance
Definition: bgp_config.h:327
SandeshTraceBufferPtr trace_buffer() const
#define CHECK_CONCURRENCY(...)
BgpServer * server_
bool virtual_network_allow_transit_
RouteTargetList export_
void EnableInstanceConfigListProcessing()
bool IsContributingRoute(const BgpTable *table, const BgpRoute *route) const
VirtualNetworksMap virtual_networks_
bool HasRoutingInstanceActiveTraceBuf(const std::string &name) const
DeleteActor(RoutingInstanceMgr *manager)
IPeer * GetPeer()
Definition: bgp_path.h:76
bool HasExportTarget(const ExtCommunity *extcomm) const
const BgpInstanceConfig * config() const
const std::string & name() const
Definition: db_table.h:110
RoutingInstance * GetRoutingInstanceLocked(const std::string &name)
static RouteTarget FromString(const std::string &str, boost::system::error_code *error=NULL)
void InsertRoutingInstance(RoutingInstance *rtinstance)
#define ROUTING_INSTANCE_DORMANT_TRACE_BUFFER_THRESHOLD_1K
void InstanceTargetAdd(RoutingInstance *rti)
BgpTable * VpnTableCreate(Address::Family vpn_family)
std::pair< bool, bool > PolicyResult
void LocateRoutingInstance(const BgpInstanceConfig *config)
void AddRTargetRoute(as_t asn, const RouteTarget &rtarget)
bool ProcessRoutingPolicy(const BgpRoute *route, BgpPath *path) const
LifetimeActor * deleter()
void UnregisterInstanceOpCallback(int id)
boost::asio::ip::address_v4 Ip4Address
Definition: address.h:14
std::vector< TaskTrigger * > instance_config_triggers_
std::map< std::string, BgpTable * > RouteTableList
uint32_t SubClusterId() const
Definition: bgp_route.cc:755
size_t GetPendingRiboutsCount(size_t *markers) const
Definition: bgp_table.cc:1088
tbb::mutex & mutex()
static std::string GetVrfFromTableName(const std::string table)
const BgpAttr * GetOriginalAttr() const
Definition: bgp_path.h:88
virtual DBTablePartBase * GetTablePartition(const DBRequestKey *key)
Definition: db_table.cc:436
virtual ~RoutingInstanceMgr()
InstanceOpListenersList callbacks_
static std::string FamilyToString(Family fmly)
Definition: address.cc:63
const RoutingInstanceMgr * manager() const
bool virtual_network_pbb_evpn_enable() const
virtual void FlushAggregateRouteConfig()=0
uint32_t bgp_identifier() const
Definition: bgp_server.h:208
bool DeleteVirtualNetworkMapping(const std::string &virtual_network, const std::string &instance_name)
#define ROUTING_INSTANCE_COLLECTOR_INFO(info)
bool IsMasterRoutingInstance() const
const uint64_t GetPrimaryPathCount() const
Definition: bgp_table.h:161
RoutingPolicyAttachList routing_policies_
virtual void ProcessStaticRouteConfig()=0
const ExtCommunity * ext_community() const
Definition: bgp_attr.h:915
const AggregateRouteList & aggregate_routes(Address::Family family) const
Definition: bgp_config.cc:390
const RoutingInstance * GetInstanceByVnIndex(int vn_index) const
std::pair< RoutingPolicyPtr, uint32_t > RoutingPolicyInfo
Definition: bgp_common.h:46
void Join(BgpTable *table, const RouteTarget &rt, bool import)
void ClearFamilyRouteTarget(Address::Family vrf_family, Address::Family vpn_family)
BgpAttrDB * attr_db()
Definition: bgp_server.h:181
bool IsPolicyReject() const
Definition: bgp_path.h:118
uint32_t generation() const
RoutingInstanceConfigList neighbor_config_list_
IStaticRouteMgr * static_route_mgr(Address::Family family)
bool CreateVirtualNetworkMapping(const std::string &virtual_network, const std::string &instance_name)
int GetOriginVnForAggregateRoute(Address::Family family) const
void ProcessIdentifierUpdate(as_t asn)
std::string GetVirtualNetworkByVnIndex(int vn_index) const
BgpTable * table()
Definition: bgp_route.cc:424
static bool is_route_target(const ExtCommunityValue &val)
Definition: community.h:265
bool IsServiceChainRoute(const BgpRoute *route) const
bool empty() const
const std::string GetVirtualNetworkName() const
RoutingInstanceMgr * mgr_
const RoutingPolicyConfigList & routing_policy_list() const
Definition: bgp_config.h:497
#define RTINSTANCE_LOG(type, rtinstance, level, flags,...)
bool HasRoutingInstanceDormantTraceBuf(const std::string &name) const
size_t GetMvpnProjectManagerCount(const std::string &network) const
virtual void set_routing_instance(RoutingInstance *rtinstance)
Definition: bgp_table.cc:81
RoutingInstanceMgr(BgpServer *server)
RoutingInstanceIterator begin()
SandeshTraceBufferPtr RoutingInstanceTraceBuf
IStaticRouteMgr * LocateStaticRouteMgr(Address::Family family)
boost::intrusive_ptr< RoutingPolicy > RoutingPolicyPtr
Definition: bgp_common.h:28
RouteTableList vrf_tables_by_name_
virtual void Add(DBEntry *entry)
RoutingInstanceTraceBufferList trace_buffer_dormant_list_
int vxlan_id() const
Definition: bgp_config.h:479
void FlushAllRTargetRoutes(as_t asn)
#define RTINSTANCE_LOG_WARNING_MESSAGE(server, flags,...)
void Notify(DBEntryBase *entry)
const NeighborList & neighbor_list() const
Definition: bgp_config.h:434
void InstanceVnIndexAdd(RoutingInstance *rti)
void Leave(BgpTable *table, const RouteTarget &rt, bool import)
bool deleted() const
int virtual_network_index() const
Definition: bgp_config.h:459
const std::string & name() const
Definition: bgp_config.h:432
virtual void ProcessPathTunnelEncapsulation(const BgpPath *path, BgpAttr *attr, ExtCommunityDB *extcomm_db, const BgpTable *table) const =0
boost::scoped_ptr< IStaticRouteMgr > inet6_static_route_mgr_
bool virtual_network_allow_transit() const
Definition: bgp_config.h:464
virtual void ProcessAggregateRouteConfig()=0
virtual bool IsReplicated() const
Definition: bgp_path.h:91
virtual bool MayDelete() const
virtual void FlushStaticRouteConfig()=0
void AddMvpnRTargetRoute(as_t asn)
PeerManager * LocatePeerManager()
std::set< RouteTarget > RouteTargetList
void UnregisterIdentifierUpdateCallback(int listener)
Definition: bgp_server.cc:963
bool always_subscribe() const
void ASNUpdateCallback(as_t old_asn, as_t old_local_asn)
void SetTableStatsUve(Address::Family family, const std::map< std::string, RoutingTableStats > &stats_map, RoutingInstanceStatsData *instance_info) const
const StaticRouteList & static_routes(Address::Family family) const
Definition: bgp_config.cc:359
RoutingInstanceList::iterator RoutingInstanceIterator
void ApplyRoutingPolicy(RoutingInstance *instance)
SandeshTraceBufferPtr GetActiveTraceBuffer(const std::string &name) const
void ProcessRouteAggregationConfig()
SandeshTraceBufferPtr GetTraceBuffer(const std::string &name)
void SetAttr(const BgpAttrPtr attr, const BgpAttrPtr original_attr)
Definition: bgp_path.h:82
int HardwareThreadCount()
Definition: task.h:276
void UpdateRoutingInstance(RoutingInstance *rtinstance, const BgpInstanceConfig *config)
int index() const
size_t GetEnvRoutingInstanceDormantTraceBufferCapacity() const
virtual bool MayDelete() const
std::string routing_policy_
Definition: bgp_common.h:37
void set_index(int index)
std::vector< RoutingInstanceConfigList > instance_config_lists_
void RemoveTable(BgpTable *tbl)
std::unique_ptr< RouteDistinguisher > rd_
SandeshTraceBufferPtr SandeshTraceBufferCreate(const std::string &buf_name, size_t buf_size, bool trace_enable=true)
Definition: sandesh_trace.h:46
RTargetGroupMgr * rtarget_group_mgr()
Definition: bgp_server.h:110
const uint64_t GetSecondaryPathCount() const
Definition: bgp_table.h:162
void InstanceTargetRemove(const RoutingInstance *rti)
const std::string & localname() const
Definition: bgp_server.cc:678