diff --git a/docs/source/conf.py b/docs/source/conf.py
index 8a6ca804f98730651c57120454e1b8622ad2381a..c5abddea21d14a9540fd28ddd7965533ae33d93c 100644
--- a/docs/source/conf.py
+++ b/docs/source/conf.py
@@ -58,7 +58,11 @@ html_static_path = ['_static']
 # start the server and dump the schema
 with tempfile.NamedTemporaryFile(delete=False) as f:
 
-    bogus_config = {'inventory': 'http://bogus'}
+    bogus_config = {
+        'inventory': 'http://bogus',
+        'reporting': 'https://bogus',
+        'correlator_exchange': 'bogus',
+    }
     with open(f.name, 'w') as f:
         json.dump(bogus_config, f)
         f.flush()
diff --git a/mapping_provider/__init__.py b/mapping_provider/__init__.py
index 1000f2af4fa33a441d0a75abe1a8ccbc64525f64..068b038ea5fd9e8c58bff3a47850f8dd610cd92c 100644
--- a/mapping_provider/__init__.py
+++ b/mapping_provider/__init__.py
@@ -1,11 +1,60 @@
 """
 Default entry point for the FastAPI application.
 """
+import contextlib
+import logging
+import tempfile
+import threading
+from collections.abc import AsyncIterator
+from functools import partial
 
 from fastapi import FastAPI
 
 from mapping_provider import config, environment
 from mapping_provider.api import common, map
+from mapping_provider.backends import cache, correlator, inventory
+
+logger = logging.getLogger(__name__)
+
+
+@contextlib.asynccontextmanager
+async def lifespan(app: FastAPI, app_config: config.Configuration) -> AsyncIterator[None]:
+
+    if not app_config.rmq:
+        return  # don't start any background tasks
+
+    with tempfile.TemporaryDirectory() as _tmp_working_dir:
+
+        cache.init(_tmp_working_dir)
+
+        stop_event = threading.Event()
+        _correlator_thread = threading.Thread(
+            target=correlator.consume_status,
+            daemon=True,
+            kwargs={
+                'correlator_state_broadcast_exchange_name': app_config.correlator_exchange,
+                'rmq_params': app_config.rmq,
+                'stop_event': stop_event,
+            })
+        _correlator_thread.start()
+
+        _inventory_thread = threading.Thread(
+            target=inventory.worker_proc,
+            daemon=True,
+            kwargs={
+                'inventory_base_uri': app_config.inventory,
+                'reporting_base_uri': app_config.reporting,
+                'refresh_frequency_seconds': 300,
+                'stop_event': stop_event,
+            })
+        _inventory_thread.start()
+
+        yield None  # wait here until the app is shutting down (mypy needs a value to be yielded)
+
+        stop_event.set()
+        _correlator_thread.join(timeout=10)
+        _inventory_thread.join(timeout=10)
+        logger.info("background threads joined")
 
 
 def create_app() -> FastAPI:
@@ -21,7 +70,9 @@ def create_app() -> FastAPI:
     app = FastAPI(
         title="Mapping provider",
         description="Mapping provider endpoints for GÉANT maps",
+        lifespan=partial(lifespan, app_config=app_config),
     )
     app.include_router(common.router)
     app.include_router(map.router, prefix='/map')
+
     return app
diff --git a/mapping_provider/api/map.py b/mapping_provider/api/map.py
index a2b8461b13323a022fd89729faf36cc10a5daf7e..a022f77c09e7a5db28bf5b168858fcc88c070c67 100644
--- a/mapping_provider/api/map.py
+++ b/mapping_provider/api/map.py
@@ -6,10 +6,12 @@ from fastapi import APIRouter
 from pydantic import BaseModel
 
 from mapping_provider import config
+from mapping_provider.backends import services
 
 router = APIRouter()
 
 
+
 class Site(BaseModel):
     latitude: float
     longitude: float
@@ -41,47 +43,6 @@ class RouterList(BaseModel):
     routers: list[Router]
 
 
-class Endpoint(BaseModel):
-    hostname: str
-    interface: str
-
-    @classmethod
-    def from_inprov_endpoint(cls, endpoint: dict[str, Any]) -> 'Endpoint':
-        return cls(
-            hostname = endpoint['hostname'],
-            interface = endpoint['interface'],
-        )
-
-class Overlays(BaseModel):
-    speed: int
-
-    @classmethod
-    def from_inprov_overlays(cls, overlays: dict[str, Any]) -> 'Overlays':
-        return cls(
-            speed = overlays['speed'],
-        )
-
-class Service(BaseModel):
-    sid: str
-    name: str
-    type: str
-    endpoints: list[Endpoint]
-    overlays: Overlays
-
-    @classmethod
-    def from_inprov_service(cls, service: dict[str, Any]) -> 'Service':
-        return cls(
-            sid = service['sid'],
-            name = service['name'],
-            type = service['type'],
-            endpoints = list(map(Endpoint.from_inprov_endpoint, service['endpoints'])),
-            overlays = Overlays.from_inprov_overlays(service['overlays']),
-        )
-
-class ServiceList(BaseModel):
-    services: list[Service]
-
-
 INPROV_SITE_LIST_SCHEMA = {
     '$schema': 'https://json-schema.org/draft/2020-12/schema',
 
@@ -198,21 +159,8 @@ def get_routers() -> RouterList:
 
 
 @router.get("/trunks")
-def get_trunks() -> ServiceList:
+def get_trunks() -> services.ServiceList:
     """
     handler for /trunks
     """
-
-    # TODO: catch/handle the usual exceptions
-
-    app_params = config.load()
-    rv = requests.get(
-        f'{app_params.inventory}/map/services/IP TRUNK',
-        headers={'Accept': 'application/json'})
-    rv.raise_for_status()
-    service_list_json = rv.json()
-    jsonschema.validate(service_list_json, INPROV_SERVICE_LIST_SCHEMA)
-
-    rsp_services = map(Service.from_inprov_service, service_list_json)
-    return ServiceList(services=list(rsp_services))
-
+    return services.build_service_info_list(service_type='IP TRUNK')
diff --git a/mapping_provider/backends/__init__.py b/mapping_provider/backends/__init__.py
new file mode 100644
index 0000000000000000000000000000000000000000..e69de29bb2d1d6434b8b29ae775ad8c2e48c5391
diff --git a/mapping_provider/backends/cache.py b/mapping_provider/backends/cache.py
new file mode 100644
index 0000000000000000000000000000000000000000..a4cc5ffc950f5052c5c42070dbba519d93797b8f
--- /dev/null
+++ b/mapping_provider/backends/cache.py
@@ -0,0 +1,42 @@
+"""
+Trivial caching module for the mapping provider.
+
+The global variable `cache_dir` is set during FastAPI server startup.
+
+Could be replaced with a proper caching module in the future, or maybe
+just a simple dict.
+"""
+import json
+import logging
+import os
+from typing import Any
+
+logger = logging.getLogger(__name__)
+_cache_dir: str | None = None
+
+
+def init(cache_dir: str) -> None:
+    global _cache_dir
+    assert _cache_dir is None, "cache_dir has already been initialized"
+    _cache_dir = cache_dir
+    logger.debug(f"set cache directory: {_cache_dir}")
+
+
+def set(filename: str, data: dict[str, Any]) -> None:
+    """
+    data must be a JSON-serializable dict.
+    """
+    assert _cache_dir is not None, "cache_dir hasn't been initialized"
+    with open(os.path.join(_cache_dir, filename), 'w') as f:
+        f.write(json.dumps(data))
+    logger.debug(f"wrote cached data: {filename}")
+
+
+def get(filename: str) -> Any:
+    """
+    Loads the cached data, parses it as json & returns the object.
+    """
+    assert _cache_dir is not None, "cache_dir hasn't been initialized"
+    with open(os.path.join(_cache_dir, filename)) as f:
+        logger.debug(f"reading cached data: {filename}")
+        return json.load(f)
diff --git a/mapping_provider/backends/correlator.py b/mapping_provider/backends/correlator.py
new file mode 100644
index 0000000000000000000000000000000000000000..d9ec3b710cd3c03db2bd227d4b735236640f7df6
--- /dev/null
+++ b/mapping_provider/backends/correlator.py
@@ -0,0 +1,157 @@
+import logging
+import os
+import socket
+import threading
+import time
+from typing import TYPE_CHECKING, Any
+
+if TYPE_CHECKING:
+    from mapping_provider.config import RMQConnectionParams
+
+from pika.exchange_type import ExchangeType
+
+from . import cache
+from .rmq.exchange import RabbitMQClient, default_rmq_connection_params
+
+logger = logging.getLogger(__name__)
+
+CACHED_CORRELATOR_STATE_FILENAME = 'correlator-state.json'
+ALARM_STATE_MESSAGE_SCHEMA = {
+    "$schema": "https://json-schema.org/draft/2020-12/schema",
+    "definitions": {
+        "list-of-strings": {
+            # shorthand for a repeated type ...
+            "type": "array",
+            "items": {"type": "string"},
+        },
+        "location": {
+            "type": "object",
+            "properties": {
+                "site": {"type": "string"},
+                "equipment": {"type": "string"}
+            },
+        },
+        "severity": {
+            "type": "string",
+            # TODO: gen from AlarmSeverity
+            "enum": ["HIDE", "WARNING", "MINOR", "MAJOR", "CRITICAL"],
+        },
+        "endpoint": {
+            "type": "object",
+            "properties": {
+                "uuid": {"type": "string"},
+                "type": {"type": "string"},
+                "name": {"type": "string"},
+                "projects": {"$ref": "#/definitions/list-of-strings"},
+                "alarm": {"type": "string"},
+                "init_time": {"type": "number"},
+                "last_activity_ts": {"type": "number"},
+                "services": {"type": "array", "items": {"type": "object"}},
+                "locations": {
+                    "type": "array",
+                    "items": {"$ref": "#/definitions/location"},
+                },
+                # not needed - sanity checks only
+                "event_history": {"$ref": "#/definitions/list-of-strings"},
+                "up": {"type": "boolean"},
+                # skipping validation of type-specific params
+                # such as peer, router, interfaces, snmp, asn, etc
+            },
+            "required": [
+                "uuid",
+                "type",
+                "name",
+                "alarm",
+                "projects",
+                "init_time",
+                "last_activity_ts",
+                "locations",
+                "event_history",
+                "up",
+            ],
+        },
+        "alarm": {
+            "type": "object",
+            "properties": {
+                "uuid": {"type": "string"},
+                "db_id": {"type": "integer"},
+                "phase": {
+                    "type": "string",
+                    "enum": ["PENDING", "FINALIZED", "KILL_ME"],
+                },
+                "final_severity": {
+                    # this field is null until phase is FINALIZED
+                    "oneOf": [{"$ref": "#/definitions/severity"}, {"type": "null"}]
+                },
+                "severity": {"$ref": "#/definitions/severity"},
+                "state": {
+                    "type": "string",
+                    "enum": ["OPEN", "CLOSED"],  # TODO: gen from AlarmState
+                },
+                # note: list-of-strings is in _ENDPOINT_SCHEMA_DEFS
+                "endpoints": {"$ref": "#/definitions/list-of-strings"},
+                "description": {"type": "string"},
+                "devoured": {"type": "array", "items": {"type": "integer"}},
+            },
+            "required": [
+                "uuid",
+                "db_id",
+                "phase",
+                "severity",
+                "final_severity",
+                "state",
+                "endpoints",
+                "description",
+            ],
+        },
+    },
+    "type": "object",
+    "properties": {
+        "alarms": {"type": "array", "items": {"$ref": "#/definitions/alarm"}},
+        "endpoints": {"type": "array", "items": {"$ref": "#/definitions/endpoint"}},
+    },
+    "required": ["alarms", "endpoints"],
+}
+
+
+def handle_correlator_state_broadcast(message: dict[str, Any]) -> None:
+    cache.set(CACHED_CORRELATOR_STATE_FILENAME, message)
+
+
+def consume_status(
+        correlator_state_broadcast_exchange_name: str,
+        rmq_params: 'RMQConnectionParams',
+        stop_event: threading.Event | None = None) -> None:
+    """
+    Consume the correlator state broadcast exchange forever.
+    When a message is received, update the global availability state cache.
+
+    :param correlator_state_broadcast_exchange_name:
+        The name of the correlator state broadcast exchange.
+    :param rmq_params: RabbitMQ connection parameters.
+    """
+
+    cp = default_rmq_connection_params(
+        hostname=rmq_params.brokers,
+        username=rmq_params.username,
+        password=rmq_params.password,
+        vhost=rmq_params.vhost)
+
+    queue_name = (
+        f"mapping-provider-{socket.getfqdn()}"
+        f"-{os.getpid()}.{threading.get_ident()}.{time.time()}"
+    )
+
+    client = RabbitMQClient(
+        connection_params=cp,
+        exchange_name=correlator_state_broadcast_exchange_name,
+        exchange_type=ExchangeType.fanout,
+        queue_name=queue_name,
+        exclusive=True,
+        reconnect_on_idle_timeout=120,
+        stop_event=stop_event)
+
+    client.consume_forever(
+        callback=handle_correlator_state_broadcast,
+        json=True,
+        schema=ALARM_STATE_MESSAGE_SCHEMA)
diff --git a/mapping_provider/backends/inventory.py b/mapping_provider/backends/inventory.py
new file mode 100644
index 0000000000000000000000000000000000000000..85e1727163b1100b3d13ea6b9cac17faaeecd450
--- /dev/null
+++ b/mapping_provider/backends/inventory.py
@@ -0,0 +1,93 @@
+import concurrent.futures
+import logging
+import time
+from threading import Event
+from typing import Any
+
+import requests
+
+from . import cache
+
+logger = logging.getLogger(__name__)
+
+INPROV_POLLER_INTERFACES_CACHE_FILENAME = 'inprov-poller-interfaces.json'
+REPORTING_SCID_CURRENT_CACHE_FILENAME = 'reporting-scid-current.json'
+INPROV_MAP_SERVICES_CACHE_FILENAME = 'inprov-map-services.json'
+
+
+def _load_and_cache_json(
+        key: str,
+        url: str,
+        cache_filename: str) -> dict[str, Any]:
+    """
+    Load the JSON from the URL, return and cache it.
+
+    :param key: key to return with the loaded data for distinguishing futures
+    :param url: URL to load the data from
+    :param cache_filename: filename to cache the data under
+    """
+    # TODO: proper error handling
+    # TODO: maybe try to return cached data if http fails?
+    rv = requests.get(url)
+    rv.raise_for_status()
+
+    rsp_object = rv.json()
+    cache.set(cache_filename, rsp_object)
+    return {
+        'key': key,
+        'value': rsp_object
+    }
+
+
+def _load_all_inventory(inventory_base_uri: str, reporting_base_uri: str) -> dict[str, Any]:
+    """
+    Load and process service info from inventory+reporting provider.
+
+    :param inventory_base_uri: base URI of the inventory provider
+    :param reporting_base_uri: base URI of the reporting provider
+    :return: list of services
+    """
+
+    with concurrent.futures.ThreadPoolExecutor(max_workers=1) as executor:
+        futures = [
+            executor.submit(
+                _load_and_cache_json,
+                key='poller-interfaces',
+                url=f'{inventory_base_uri}/poller/interfaces',
+                cache_filename=INPROV_POLLER_INTERFACES_CACHE_FILENAME),
+            executor.submit(
+                _load_and_cache_json,
+                key='map-services',
+                url=f'{inventory_base_uri}/map/services',
+                cache_filename=INPROV_MAP_SERVICES_CACHE_FILENAME),
+            executor.submit(
+                _load_and_cache_json,
+                key='scid-current',
+                url=f'{reporting_base_uri}/scid/current',
+                cache_filename=REPORTING_SCID_CURRENT_CACHE_FILENAME),
+        ]
+        responses = {}
+        for _f in concurrent.futures.as_completed(futures):
+            responses[_f.result()['key']] = _f.result()['value']
+
+    return responses
+
+
+def worker_proc(
+        inventory_base_uri: str,
+        reporting_base_uri: str,
+        refresh_frequency_seconds: int,
+        stop_event: Event | None = None) -> None:
+
+    def _should_stop() -> bool:
+        return stop_event.is_set() if stop_event else False
+
+    while not _should_stop():
+
+        _load_all_inventory(inventory_base_uri, reporting_base_uri)
+
+        # wait and the restart the loop
+        if stop_event:
+            stop_event.wait(timeout=refresh_frequency_seconds)
+        else:
+            time.sleep(refresh_frequency_seconds)
diff --git a/mapping_provider/backends/rmq/__init__.py b/mapping_provider/backends/rmq/__init__.py
new file mode 100644
index 0000000000000000000000000000000000000000..e69de29bb2d1d6434b8b29ae775ad8c2e48c5391
diff --git a/mapping_provider/backends/rmq/exchange.py b/mapping_provider/backends/rmq/exchange.py
new file mode 100644
index 0000000000000000000000000000000000000000..ef3f5fe004d2a4e396e9ea4195518746bb3b76c7
--- /dev/null
+++ b/mapping_provider/backends/rmq/exchange.py
@@ -0,0 +1,562 @@
+"""
+
+copied from: dashboard-v3-python v0.226, dashboard.messaging.exchange
+updated typehints to satisfy mypy, and linted with changes suggested by ruff
+
+"""
+import json
+import logging
+import threading
+import time
+from collections.abc import Callable, Generator, Iterator, Sequence
+from json import JSONDecodeError
+from typing import Any
+
+import jsonschema
+import pika
+import pika.channel
+from pika.adapters.blocking_connection import BlockingChannel
+from pika.exceptions import AMQPError
+from pika.exchange_type import ExchangeType
+
+from .queue import setup_channel
+
+logger = logging.getLogger(__name__)
+
+
+def now() -> float:
+    return time.monotonic()
+
+
+def default_rmq_connection_params(
+    hostname: str | Sequence[str],
+    username: str,
+    password: str,
+    vhost: str,
+    port: int = 5672,
+) -> Sequence[pika.ConnectionParameters]:
+    """
+    build a list of pika.ConnectionParameters objects for connecting
+    to the cluster
+
+    :param hostname: hostname or list of hostnames
+    :param username: username (same for all hostnames)
+    :param password: password (same for all hostnames)
+    :param vhost: connection vhost
+    :param port: port (default value = 5672, same for all hostnames)
+    :return: list of pika.ConnectionParameters
+    """
+    hostnames = [hostname] if isinstance(hostname, str) else hostname
+    logger.debug(f"rmq hostnames: {hostnames}")
+    return [
+        pika.ConnectionParameters(
+            host=h,
+            port=port,
+            virtual_host=vhost,
+            credentials=pika.PlainCredentials(username, password),
+        )
+        for h in hostnames
+    ]
+
+
+class RMQResponse:
+    def __init__(
+        self,
+        body: bytes,
+        client: "RabbitMQClient",
+        delivery_tag: int = 0,
+        reply_to: str | None = None
+    ):
+        self.body = body
+        self.client = client
+        self.delivery_tag = delivery_tag
+        self.reply_to = reply_to
+
+    def ack(self) -> None:
+        # TODO: Handle AMQP error when acking fails
+        self.client.maybe_ack(self.delivery_tag)
+
+    def json(self, schema: dict[str, Any] | None = None) -> Any:
+        """try and load the response body as a json object.
+        :param schema: Optional. A jsonschema dictionary to validate the json response
+        if the json parsing or validation fails, this method will ensure that the
+        message is still acked
+        """
+        try:
+            result = json.loads(self.body)
+            if schema is not None:
+                jsonschema.validate(result, schema)
+        except (JSONDecodeError, jsonschema.ValidationError):
+            self.ack()  # Maybe we should actually nack the message here
+            raise
+        return result
+
+    def reply(self, body: str | bytes) -> None:
+        self.client.send_message(
+            body=body,
+            exchange_name="",
+            exchange_type=ExchangeType.direct,
+            routing_key=self.reply_to,
+        )
+
+
+class RabbitMQClient:
+    """
+    A RabbitMQClient can connect to RabbitMQ and persisently maintain that connection.
+    It will reconnect on connection failures. It has two modes of operation for
+    consuming a queue. The first is by explicitly requesting messages through the
+    ``get_message`` method:
+
+    .. code-block:: python
+
+        consumer = RabbitMQConsumer(cp, 'exchange', 'queue', exchange_type='fanout')
+        while True:
+            response = consumer.get_message()
+            ... # handle message
+            response.ack()
+
+    or through it's run_forever mode:
+
+    .. code-block:: python
+
+        def mycallback(message: dict):
+            pass
+
+        consumer = RabbitMQConsumer(cp, 'exchange', 'queue', exchange_type='fanout')
+        consumer.run_forever(mycallback, json=True)
+
+    The consumer is not thread safe and only a single message may be handled at a time
+
+    For sending messages (producing), you can use the `send_message()` method. This
+    method will ensure that a message is sent, by reconnecting to rabbitmq in case of
+    a failure.
+    """
+
+    STOP_CHECK_FREQUENCY_S = 5
+    PAUSE_BEFORE_RECONNECT_S = 5
+    DEFAULT_PREFETCH_COUNT = 50
+    connection: pika.BlockingConnection | None = None
+    channel: BlockingChannel | None = None
+    consumer: Iterator[Any] | None = None
+    # consumer: Generator[Any, None, None] | None = None
+    last_message_ts = None
+    _close_time = None
+
+    def __init__(
+        self,
+        connection_params: pika.ConnectionParameters | Sequence[pika.ConnectionParameters],
+        exchange_name: str,
+        exchange_type: ExchangeType,
+        queue_name: str | None = None,
+        routing_keys: str | Sequence[str] | None = None,
+        exclusive: bool = False,
+        single_active_consumer: bool = False,
+        quorum_queue: bool = False,
+        prefetch_count: int = DEFAULT_PREFETCH_COUNT,
+        auto_ack: bool = False,
+        reconnect_on_idle_timeout: float | None = None,
+        reconnect_callback: Callable[[], None] | None= None,
+        error_callback: Callable[[Exception], None] | None = None,
+        stop_event: threading.Event | None = None,
+        pause_before_reconnect: float | None = PAUSE_BEFORE_RECONNECT_S,
+    ):
+        """
+        :param connection_params: rmq connection parameters
+        :param exchange_name: rmq exchange name
+        :param queue_name: rmq queue name
+        :param exchange_type: rmw exchange type, either 'direct' or 'fanout'
+        :param routing_keys: Either a single string or a sequence of strings that will
+            be used as routing key for 'direct' exchanges. Default: None
+        :param exclusive: is this an exclusive queue? Exclusive queues are destroying on
+            disconnect. Default: False
+        :param single_active_consumer: The queue has can have a maximum of 1 active
+            consumer. If multiple consumers are connecting to the same queue, they do
+            not receive any messages until the current active consumer disconnects for
+            some reason and they become the active consumer. Default: False.
+        :param prefetch_count: Limit the number of messages to prefetch from the broker.
+            This is highly recommended. Set to None to disable and let the broker
+            decide. Default: ``DEFAULT_PREFETCH_COUNT``
+        :param auto_ack: automatically acknowledge messages. Default: False.
+        :param reconnect_callback: Optional callback that will be called when
+            reconnecting. Default: None
+        :param error_callback: Optional callback that will be called when an AMQPEror
+            is raised or an invalid json message is received. Default: None
+        :param reconnect_on_timeout: Maximum idle time between subsequent
+            messages before triggering a reconnect. Default: None
+        :param pause_before_reconnect: Sleep a number of seconds between disconnecting
+            and reconnecting. Supply a value that evaluates to False (0, None, False) to
+            disable sleeping. Default: ``PAUSE_BEFORE_RECONNECT_S``.
+        :param stop_event: A `threading.Event` that will be checked periodically to
+            determine whether the consumer should stop. Default: None
+        """
+
+        self.connection_params = self._ensure_connection_params(connection_params)
+        self.exchange_name = exchange_name
+        self.queue_name = queue_name
+        self.exchange_type = exchange_type
+
+        self.routing_keys: Sequence[str] = []  # for mypy
+        if routing_keys is None:
+            self.routing_keys = []
+        elif isinstance(routing_keys, str):
+            self.routing_keys = [routing_keys]
+        elif isinstance(routing_keys, Sequence):
+            self.routing_keys = routing_keys
+        else:
+            raise AssertionError("impossible - only here for mypy clarity")
+
+        self.exclusive = exclusive
+        self.single_active_consumer = single_active_consumer
+        self.quorum_queue = quorum_queue
+        self.prefetch_count = prefetch_count
+        self.auto_ack = auto_ack
+        self.reconnect_on_idle_timeout = reconnect_on_idle_timeout
+        self.reconnect_callback = reconnect_callback
+        self.error_callback = error_callback
+        self.stop_event = stop_event
+        self.pause_before_reconnect = pause_before_reconnect
+
+    @staticmethod
+    def _ensure_connection_params(
+        connection_params: dict[str, Any] | pika.ConnectionParameters | Sequence[pika.ConnectionParameters]
+    ) -> pika.ConnectionParameters | Sequence[pika.ConnectionParameters]:
+        if not isinstance(connection_params, dict):
+            return connection_params
+
+        if "hostname" in connection_params:
+            hostname = connection_params["hostname"]
+        elif "hostnames" in connection_params:
+            hostname = connection_params["hostnames"]
+        else:
+            raise ValueError(
+                "Connection parameters must contain either 'hostname' or 'hostnames'"
+            )
+        return default_rmq_connection_params(
+            hostname,
+            username=connection_params["username"],
+            password=connection_params["password"],
+            vhost=connection_params["vhost"],
+        )
+
+    def connection_str(self) -> str:
+        result = self.exchange_name
+        if self.queue_name:
+            result += f"/{self.queue_name}"
+        if self.routing_keys and self.routing_keys[0]:
+            result += f" with routing key(s): {','.join(self.routing_keys)}"
+        return result
+
+    def __enter__(self) -> "RabbitMQClient":
+        return self
+
+    def __exit__(self, *args: Any, **kwargs: Any) -> None:
+        self.close()
+
+    def __del__(self) -> None:
+        self.close()
+
+    def _connect(self, as_consumer: bool = True) -> tuple[pika.BlockingConnection, BlockingChannel, str | None]:
+        if self.connection is not None:
+            raise RuntimeError("Already connected")
+
+        if self._close_time is not None:
+            logger.warning(f"Detected rmq disconnect from {self.connection_str()}")
+            if self.reconnect_callback is not None:
+                self.reconnect_callback()
+
+        self._pause_before_reconnect()
+        logger.info(f"Connecting to rmq {self.connection_str()}")
+
+        connection = pika.BlockingConnection(self.connection_params)
+        channel, queue = setup_channel(
+            connection=connection,
+            exchange_name=self.exchange_name,
+            exchange_type=self.exchange_type,
+            queue_name=self.queue_name if as_consumer else None,
+            exclusive=self.exclusive,
+            single_active_consumer=self.single_active_consumer,
+            routing_keys=self.routing_keys,
+            prefetch_count=self.prefetch_count,
+            force_quorum_queue=self.quorum_queue,
+        )
+
+        return connection, channel, queue
+
+    def connect_consumer(self, timeout: float | None = None) -> None:
+        """
+        Create a channel and bind to the exchange/queue, setting the internal `consumer`
+        attribute
+
+        :param timeout: an optional timeout in seconds. The consumer will
+        yield None if no message is received within ``timeout`` seconds. default:
+        RabbitMQClient.STOP_CHECK_FREQUENCY_S
+
+        """
+        if self.consumer is not None:
+            return
+        timeout = timeout if timeout is not None else self.STOP_CHECK_FREQUENCY_S
+
+        self.connection, self.channel, self.queue_name = self._connect(as_consumer=True)
+
+        assert self.queue_name  # should be defined by _connect
+        self.consumer = self.channel.consume(
+            queue=self.queue_name, auto_ack=self.auto_ack, inactivity_timeout=timeout
+        )
+
+    def connect_publisher(self) -> None:
+        if self.connection is not None:
+            return
+        self.connection, self.channel, _ = self._connect(as_consumer=False)
+
+    def close(self) -> None:
+        if self.connection and self.connection.is_open:
+            self.connection.close()
+        self.consumer = None
+        self.channel = None
+        self.connection = None
+        self._close_time = now()
+
+    def consume_queue(self,
+                      json: bool = False,
+                      schema: dict[str, Any] | None = None,
+                      timeout: float | None = None,
+                      as_response: bool = False) -> Generator[Any]:
+        """
+        :param json: set to True to json decode all messages before invoking the
+            callback. This is ignored if ``as_response`` is set to True. Default False
+        :param schema: An optional jsonschema to validate the message against. Requires
+            the json parameter to be set to True
+        :param timeout: Optional timeout in seconds. See ``RabbitMQClient.get_message``.
+            In case of a timeout, this function will yield ``None``
+        :param as_response: yield ``RMQResponse`` objects instead of raw bytes or json
+            dictionary
+        """
+        if schema is not None and not json:
+            raise ValueError("Must set json to True when supplying a json schema")
+        with self:
+            while self._should_continue():
+                try:
+                    response = self.get_message(timeout=timeout, reset_last_ts=False)
+                except TimeoutError:
+                    yield None
+                    continue
+                except CancelledError:
+                    return
+                if as_response:
+                    yield response
+                elif json:
+                    try:
+                        yield response.json(schema=schema)
+                    except (JSONDecodeError, jsonschema.ValidationError) as e:
+                        logger.exception("error parsing message")
+                        self._handle_recoverable_error(e)
+                        continue
+                else:
+                    yield response.body
+
+                try:
+                    response.ack()
+                except AMQPError as e:
+                    logger.exception("Error while acknowledging message")
+                    self._handle_recoverable_error(e)
+                    self.close()  # trigger reconnect
+
+    def consume_forever(
+        self,
+        callback: Callable[[Any], None],
+        json: bool = False,
+        schema: dict[str, Any] | None = None,
+        timeout: float | None = None,
+        as_response: bool = False
+    ) -> None:
+        """
+        See RabbitMQClient.consume_queue for other other paramters
+
+        :param callback: a function that takes a message coming from the queue as a
+            single argument
+        """
+        for result in self.consume_queue(
+            json=json, schema=schema, timeout=timeout, as_response=as_response
+        ):
+            callback(result)
+
+    def get_message(
+        self, timeout: float | None = None, reset_last_ts: bool | None = None
+    ) -> RMQResponse:
+        """
+        Get a message from the queue, reconnecting when necessary. This may block
+        indefinitely.
+        :param timeout: Optional timeout in seconds. If given, this method will raise
+            `TimeoutError` if the timeout expired before a message was received. The
+            connection will be kept open. Warning: setting a large timeout may make
+            the program less responsive, since it will override the default timeout
+            (``RabbitMQClient.STOP_CHECK_FREQUENCY_S``)
+        :param reset_last_ts: whether or not to reset the last time a message was
+            received (RabbitMQClient.last_message_ts) at the beginning of this function.
+            Setting this to False will ensure that this function will correctly detect
+            when the connection has been idle for too long over multiple calls that do
+            not yield a message, but when the function does return because of a timeout.
+            By default this is set to False if a timeout is given. If no timeout is
+            given, this is by default set to True.
+        :return: An RMQResponse or None. If it is a valid response, the `content`
+            attribute is set the raw body of the message. It is set to None if returning
+            after the RabbitMQClient.stop_event is set
+        :raises TimeoutError: If a given custom timeout was reached while waiting for
+            messages
+        :raises Cancelled: After a ``RabbitMQClient.stop_event`` was set
+        """
+        if reset_last_ts is None:
+            reset_last_ts = timeout is None
+
+        if not self.last_message_ts or reset_last_ts:
+            self.last_message_ts = now()
+
+        while self._should_continue():
+            try:
+                self.connect_consumer(timeout=timeout)
+                try:
+                    assert self.consumer is not None
+
+                    method, properties, body = next(self.consumer)
+                except StopIteration:
+                    # Consumer was cancelled by broker
+                    logger.warning(f"Broker closed connection {self.connection_str()}")
+                    self.close()
+                    continue
+
+                if not self._should_continue():
+                    break
+
+                if body is not None:  # STOP_CHECK_FREQUENCY_S timeout
+                    self.last_message_ts = now()
+                    return RMQResponse(
+                        body=body,
+                        client=self,
+                        delivery_tag=method.delivery_tag,
+                        reply_to=properties.reply_to,
+                    )
+
+                if self._is_idle_for_too_long():
+                    logger.warning(
+                        f"No message received from '{self.connection_str()}' in"
+                        f" {self.reconnect_on_idle_timeout} seconds, reconnecting"
+                    )
+                    self.last_message_ts = now()
+                    self.close()
+                    continue
+
+                if timeout is not None:
+                    raise TimeoutError
+
+            except AMQPError as e:
+                logger.exception(
+                    f"An error occured while reading '{self.connection_str()}'"
+                )
+                self._handle_recoverable_error(e)
+                self.close()
+
+        raise CancelledError
+
+    def send_message(
+        self,
+        body: str | bytes,
+        exchange_name: str | None = None,
+        exchange_type: ExchangeType | None = None,
+        routing_key: str | None = None,
+        properties: pika.BasicProperties | None = None,
+    ) -> None:
+        """
+        Send a message to the exchange, retrying on AMQPError to ensure delivery
+        :param body: the message body (str or bytes)
+        :param exchange_name: Override exchange name. Default: None
+        :param exchange_type: Override exchange type. Default: None
+        :param routing_key: Override routing key. Default: None
+        :param properties: Additional pika.spec.BasicProperties message properties.
+            Default: None
+        """
+        if exchange_name is None:
+            exchange_name = self.exchange_name
+        if not exchange_type:
+            exchange_type = self.exchange_type
+
+        if routing_key is None:
+            routing_keys = self.routing_keys
+        else:
+            routing_keys = [routing_key]
+
+        if len(routing_keys) != 1:
+            raise RuntimeError("Can only publish messages with a single routing key")
+
+        if exchange_name != "" and (
+            (exchange_name, exchange_type) != (self.exchange_name, self.exchange_type)
+        ):
+            self.connect_publisher()
+            assert self.channel is not None
+            self.channel.exchange_declare(
+                exchange=exchange_name, exchange_type=exchange_type
+            )
+
+        while self._should_continue():
+            self.connect_publisher()
+            assert self.channel is not None
+
+            try:
+                self.channel.basic_publish(
+                    exchange=exchange_name,
+                    routing_key=routing_keys[0],
+                    # mypy won't allow str|bytes here, so ...
+                    body=body if isinstance(body, bytes) else body.encode('utf-8'),
+                    properties=properties,
+                )
+
+            except AMQPError as e:
+                logger.exception(
+                    f"An error occured sending a message to {exchange_name}"
+                    + f" with routing key '{routing_key}'"
+                    if routing_key
+                    else ""
+                )
+                self._handle_recoverable_error(e)
+                self.close()
+
+    def _should_continue(self) -> bool:
+        return not (self.stop_event and self.stop_event.is_set())
+
+    def _is_idle_for_too_long(self) -> bool:
+        idle_time = (
+            now() - self.last_message_ts if self.last_message_ts is not None else 0
+        )
+        return (
+            self.reconnect_on_idle_timeout is not None
+            and idle_time > self.reconnect_on_idle_timeout
+        )
+
+    def _pause_before_reconnect(self) -> None:
+        if not self.pause_before_reconnect or self._close_time is None:
+            return
+        sleep_time = self._close_time + self.pause_before_reconnect - now()
+        if sleep_time > 0:
+            time.sleep(sleep_time)
+
+    def maybe_ack(self, tag: int) -> None:
+        if self.auto_ack:
+            return  # noop
+        assert self.channel, "channel should be defined by _connect"
+        self.channel.basic_ack(delivery_tag=tag)
+
+    def _handle_recoverable_error(self, exception: Exception) -> None:
+        if self.error_callback:
+            self.error_callback(exception)
+
+
+class TimeoutError(Exception):
+    """Raised whenever RabbitMQClient.get_message was called with a ``timeout`` and
+    that timeout occured while waiting for a message"""
+
+    pass
+
+
+class CancelledError(RuntimeError):
+    """Raised whenever RabbitMQClient.stop_event was set while waiting for a message"""
+
+    pass
diff --git a/mapping_provider/backends/rmq/queue.py b/mapping_provider/backends/rmq/queue.py
new file mode 100644
index 0000000000000000000000000000000000000000..1aa8ffdf67d8df126cc8ad79275c6c03390df8b9
--- /dev/null
+++ b/mapping_provider/backends/rmq/queue.py
@@ -0,0 +1,153 @@
+"""
+
+copied from: dashboard-v3-python v0.226, dashboard.messaging.queue
+updated typehints to satisfy mypy, and linted with changes suggested by ruff
+
+"""
+
+import logging
+import os
+from collections.abc import Sequence
+from typing import Any
+
+from pika.adapters.blocking_connection import BlockingChannel, BlockingConnection
+from pika.exceptions import ChannelClosedByBroker
+from pika.exchange_type import ExchangeType
+
+DASHBOARD_USE_QUORUM_QUEUE = os.getenv(
+    "DASHBOARD_USE_QUORUM_QUEUE", ""
+).lower() not in {"0", "", "false"}
+
+logger = logging.getLogger(__name__)
+
+
+def loose_queue_declare(
+    channel: BlockingChannel,
+    queue: str = "",
+    exclusive: bool = False,
+    single_active_consumer: bool = False,
+    force_quorum_queue: bool = False,
+) -> str | None:
+    """declare a queue (either classic or quorum, depending on the USE_QUORUM_QUEUE
+    global variable and if it is a ``dashboard.*`` queue). In case of a failure that
+    the queue already exists as a different type, this function fails silently.
+
+    :param channel: the channel to use
+    :param queue: the queue name. If empty string, the broker will create a unique queue
+        name (default: '')
+    :param kwargs: additional parameters to pass to ``channel.queue_declare``
+    """
+    durable = False
+    arguments: dict[str, Any] = {}
+    if force_quorum_queue or (
+        DASHBOARD_USE_QUORUM_QUEUE and queue.startswith("dashboard.")
+    ):
+        durable = True
+        arguments["x-queue-type"] = "quorum"
+    if single_active_consumer:
+        arguments["x-single-active-consumer"] = True
+    try:
+        result = channel.queue_declare(
+            queue, durable=durable, exclusive=exclusive, arguments=arguments or None
+        )
+        assert isinstance(result.method.queue, str)  # for mypy
+        return result.method.queue
+
+    except ChannelClosedByBroker as e:
+        if e.reply_code == 406:  # PRECONDITION_FAILED due to incompatible queue type
+            requested_type, existing_type = "classic", "quorum"
+            if DASHBOARD_USE_QUORUM_QUEUE:
+                requested_type, existing_type = existing_type, requested_type
+            logger.warning(
+                f"Trying to declare {requested_type} queue '{queue}'"
+                f" but queue already exists as {existing_type} queue"
+            )
+            return None
+        raise
+
+
+def setup_channel(
+    connection: BlockingConnection,
+    exchange_name: str,
+    exchange_type: ExchangeType = ExchangeType.fanout,
+    queue_name: str | None = None,
+    queue_declare: bool = True,
+    exclusive: bool = False,
+    single_active_consumer: bool = False,
+    routing_keys: Sequence[str] = [],
+    prefetch_count: int | None = None,
+    force_quorum_queue: bool = False,
+) -> tuple[BlockingChannel, str | None]:
+    """Setup a channel and declare the exchange and optionally the queue.
+
+    :param connection: A ``pika`` ``BlockingConnection``
+    :param exchange_name: the exchange to declare
+    :param exchange_type: the exchange type (default: ``fanout``)
+    :param queue_name: The queue to bind to, if given. Can be set to empty string to
+        get a temporary queue from the broker. When queue_name=None, the channel can
+        only be used for publishing (default: None)
+    :param queue_declare: Whether to declare the queue before binding (default: True)
+    :param exclusive: Whether this should be declared as an exclusive queue (default:
+        False)
+    :param routing_keys: Optional routing keys to bind to the queue.
+    :returns: A tuple (channel: ``BlockingChannel``, queue_name: Optional[str])
+    """
+    channel = connection.channel()
+    if prefetch_count is not None:
+        channel.basic_qos(prefetch_count=prefetch_count)
+
+    if exchange_name != "":  # cannot declare default exchange
+        channel.exchange_declare(exchange=exchange_name, exchange_type=exchange_type)
+
+    if queue_name is None:
+        return channel, None
+
+    if queue_name == "" and not queue_declare:
+        raise ValueError("must set queue_declare=True when supplying empty queue name")
+    if queue_name == "" and not exclusive:
+        raise ValueError("must set exclusive=True for anonymous queues")
+    if exclusive and single_active_consumer:
+        raise ValueError("Exclusive queues cannot have single active consumer")
+
+    if queue_declare:
+        if exclusive:
+            # Short circuit exclusive queues that are never quorum and never
+            # pre-exist
+            result = channel.queue_declare(queue_name, exclusive=True)
+            queue_name = result.method.queue
+        else:
+            queue_name = loose_queue_declare(
+                channel,
+                queue_name,
+                exclusive=exclusive,
+                single_active_consumer=single_active_consumer,
+                force_quorum_queue=force_quorum_queue,
+            )
+
+            # if a queue declare fails, the channel is in an unusable state.
+            # Start over but skip the declare
+            if queue_name is None:
+                return setup_channel(
+                    connection=connection,
+                    exchange_name=exchange_name,
+                    exchange_type=exchange_type,
+                    queue_name=queue_name,
+                    queue_declare=False,
+                    exclusive=exclusive,
+                    routing_keys=routing_keys,
+                    prefetch_count=prefetch_count,
+                    single_active_consumer=single_active_consumer,
+                    force_quorum_queue=force_quorum_queue,
+                )
+
+    assert queue_name, "queue name must not be empty here"
+ 
+    if not routing_keys:
+        # in case no routing keys are provided (as for fanout exchanges),
+        # ensure the queue is still bound to the exchange
+         channel.queue_bind(exchange=exchange_name, queue=queue_name)
+
+    for rk in routing_keys:
+        channel.queue_bind(exchange=exchange_name, queue=queue_name, routing_key=rk)
+
+    return channel, queue_name
diff --git a/mapping_provider/backends/services.py b/mapping_provider/backends/services.py
new file mode 100644
index 0000000000000000000000000000000000000000..6abf52336b30368962310ed5391fbf1d7cd9e59e
--- /dev/null
+++ b/mapping_provider/backends/services.py
@@ -0,0 +1,94 @@
+import logging
+from collections.abc import Generator
+
+from pydantic import BaseModel
+
+from . import cache, correlator, inventory
+
+logger = logging.getLogger(__name__)
+
+
+class Endpoint(BaseModel):
+    equipment: str
+    interface: str
+
+
+class Overlays(BaseModel):
+    speed: int
+    up: bool
+
+
+class Service(BaseModel):
+    sid: str
+    scid: str
+    name: str
+    type: str
+    endpoints: list[Endpoint]
+    overlays: Overlays
+
+
+class ServiceList(BaseModel):
+    services: list[Service]
+
+
+def _services(service_type: str | None = None) -> Generator[Service]:
+    """
+    load the cached backend data and yield map service records
+
+    only return operational services that match the service type, if provided
+    """
+    # TOOD: maybe remove loading of inventory/poller/interfaces & /map/services
+    try:
+        # inprov_map_services = cache.get(inventory.INPROV_MAP_SERVICES_CACHE_FILENAME)
+        scid_current = cache.get(inventory.REPORTING_SCID_CURRENT_CACHE_FILENAME)
+        # poller_interfaces = cache.get(inventory.INPROV_POLLER_INTERFACES_CACHE_FILENAME)
+        correlator_state = cache.get(correlator.CACHED_CORRELATOR_STATE_FILENAME)
+    except FileNotFoundError:
+        logger.exception('not enough data available to build the service list')
+        return
+
+    def _get_down_correlator_services() -> Generator[str]:
+        for _e in correlator_state['endpoints']:
+            if _e['up']:
+                continue
+            for _s in _e['services']:
+                if 'sid' in _s:
+                    yield _s['sid']
+
+
+    down_service_sids = set(_get_down_correlator_services())
+
+    for _s in scid_current:
+
+        if _s['status'] != 'operational':
+            continue
+
+        if service_type and _s['service_type'] != service_type:
+            continue
+
+        overlays = Overlays(
+            speed = _s['speed'],
+            up = _s['sid'] not in down_service_sids,
+        )
+
+        endpoints = []
+        for _e in _s['endpoints']:
+            equipment = _e['hostname'] if 'hostname' in _e else _e['equipment']
+            interface = _e['interface'] if 'interface' in _e else _e['port']
+            endpoints.append(Endpoint(equipment=equipment, interface=interface))
+
+        yield Service(
+            sid = _s['sid'],
+            scid = _s['scid'],
+            name = _s['name'],
+            type = _s['service_type'],
+            endpoints = endpoints,
+            overlays = overlays,
+        )
+
+
+def build_service_info_list(service_type: str | None = None) -> ServiceList:
+    """
+    return a list of mappable info about all operational services
+    """  
+    return ServiceList(services=list(_services(service_type)))
diff --git a/mapping_provider/config.py b/mapping_provider/config.py
index cf67282db6fa7984c799f83a9dd85b9383838dad..c67b2d25be778b69e6d931b42c0b2bbb1c6f2833 100644
--- a/mapping_provider/config.py
+++ b/mapping_provider/config.py
@@ -3,6 +3,13 @@ import os
 from pydantic import BaseModel, Field, HttpUrl
 
 
+class RMQConnectionParams(BaseModel):
+    brokers: list[str]
+    username: str
+    password: str
+    vhost: str
+
+
 class SentryConfig(BaseModel):
     dsn: str
     environment: str
@@ -20,6 +27,9 @@ class SentryConfig(BaseModel):
 class Configuration(BaseModel):
     sentry: SentryConfig | None = None
     inventory: HttpUrl
+    reporting: HttpUrl
+    rmq: RMQConnectionParams | None = None
+    correlator_exchange: str = 'dashboard.alarms.broadcast'
 
 
 def load() -> Configuration:
diff --git a/pyproject.toml b/pyproject.toml
index 5962c7c74f4fddd876eb57b2d80c771c0b39a4d2..0c59d10f535b1f9c20c9b302fbaac3cb8bbc4789 100644
--- a/pyproject.toml
+++ b/pyproject.toml
@@ -10,3 +10,10 @@ python_version = "3.13"
 strict = true
 warn_unused_ignores = true
 warn_return_any = true
+
+[tool.coverage.run]
+source = ["mapping_provider"]
+omit = [
+    "mapping_provider/backends/rmq/*",
+    "test/*"
+]
\ No newline at end of file
diff --git a/requirements.txt b/requirements.txt
index 0c99b1de0cb6985c5f38d93aa260d46242f3c856..8032e99e89c48566a30f9498fc5e43ff6e8fbbba 100644
--- a/requirements.txt
+++ b/requirements.txt
@@ -3,6 +3,7 @@ uvicorn[standard]
 requests
 jsonschema
 sentry_sdk
+pika
 
 httpx  # required for fastapi TestClient
 pytest
diff --git a/setup.py b/setup.py
index b0fd259282caceba9920789bbe3e94fc7259e70c..c0653f22dcf32f66fdaf09c171150fe57132b175 100644
--- a/setup.py
+++ b/setup.py
@@ -7,8 +7,7 @@ setup(
     author="GÉANT",
     author_email="info@geant.org",
     license="MIT",
-    packages=find_packages(where="mapping_provider"),
-    package_dir={"": "mapping_provider"},
+    packages=find_packages(exclude=["test"]),
     include_package_data=True,
     python_requires=">=3.10",
     install_requires=[
@@ -16,7 +15,8 @@ setup(
         "uvicorn[standard]",
         "requests",
         "jsonschema",
-        "sentry_sdk",        
+        "sentry_sdk",
+        "pika"
     ],
     long_description=open("README.md", encoding="utf-8").read(),
     long_description_content_type="text/markdown",
@@ -26,4 +26,4 @@ setup(
         "License :: OSI Approved :: MIT License",
         "Operating System :: OS Independent",
     ],
-)
\ No newline at end of file
+)
diff --git a/test/common.py b/test/common.py
new file mode 100644
index 0000000000000000000000000000000000000000..6eeed165455dd53e3164ab6ffd5ccb55bcf19464
--- /dev/null
+++ b/test/common.py
@@ -0,0 +1,9 @@
+import json
+import os
+
+DATA_DIR = os.path.join(os.path.dirname(__file__), 'data')
+
+
+def load_test_data(filename: str) -> dict:
+    with open(os.path.join(DATA_DIR, filename)) as f:
+        return json.load(f)
\ No newline at end of file
diff --git a/test/conftest.py b/test/conftest.py
index 4e7c4f211775a3d0ff490a372c3df867dec0fc8d..60edf83fc32c2e749fea6da7e9efe45a98c336f3 100644
--- a/test/conftest.py
+++ b/test/conftest.py
@@ -7,6 +7,9 @@ import pytest
 from fastapi.testclient import TestClient
 
 from mapping_provider import create_app
+from mapping_provider.backends import cache, correlator, inventory
+
+from .common import load_test_data
 
 
 @pytest.fixture
@@ -16,7 +19,19 @@ def dummy_config():
             'dsn': 'https://token@hostname.geant.org:1111/a/b',
             'environment': 'unit tests'
         },
-        'inventory': 'https://dummy-hostname.dummy.domain'
+        'inventory': 'https://inventory.bogus.domain',
+        'reporting': 'http://reporting.another-bogus.domain',
+        # no rmq param to skip correlator thread
+        # 'rmq': {
+        #     'brokers': [
+        #         'test-noc-alarms01.geant.org',
+        #         'test-noc-alarms02.geant.org',
+        #         'test-noc-alarms03.geant.org'
+        #     ],
+        #     'username': 'guest',
+        #     'password': 'guest',
+        #     'vhost': '/'
+        # }
     }
 
 
@@ -31,5 +46,24 @@ def dummy_config_filename(dummy_config):
 @pytest.fixture
 def client(dummy_config_filename):
     os.environ['SETTINGS_FILENAME'] = dummy_config_filename
-    with patch('sentry_sdk.init') as _mock_sentry_init:
-        return TestClient(create_app())
+
+    with tempfile.TemporaryDirectory() as tmp_dir:
+
+        # there's no rmq in the test config data, so cache won't be initialized
+        cache.init(tmp_dir)
+        cache.set(inventory.INPROV_MAP_SERVICES_CACHE_FILENAME, load_test_data('inprov-services.json'))
+        cache.set(inventory.REPORTING_SCID_CURRENT_CACHE_FILENAME, load_test_data('scid-current.json'))
+        cache.set(inventory.INPROV_POLLER_INTERFACES_CACHE_FILENAME, load_test_data('poller-interfaces.json'))
+        cache.set(correlator.CACHED_CORRELATOR_STATE_FILENAME, load_test_data('correlator-state.json'))
+ 
+        with patch('sentry_sdk.init') as _mock_sentry_init:
+            yield TestClient(create_app())
+
+
+@pytest.fixture(autouse=True)
+def run_around_tests():
+    assert cache._cache_dir is None  # test env sanity check
+    yield
+
+    # make sure cache is set to unused before the next test
+    cache._cache_dir = None
diff --git a/test/data/correlator-state.json b/test/data/correlator-state.json
new file mode 100644
index 0000000000000000000000000000000000000000..ad03c01959dad4cba1f1ef197c7c4435f9815d47
--- /dev/null
+++ b/test/data/correlator-state.json
@@ -0,0 +1,1186 @@
+{
+  "endpoints": [
+    {
+      "type": "BGPIXEndpoint",
+      "uuid": "d10dd830-5e7e-4eb7-ba8d-4b0ef384bce1",
+      "name": "ix::lo0.rt1.fra.de.geant.net::2001:07f8:0000:0000:0000:1f8b:0000:0001",
+      "projects": [],
+      "alarm": "dc0d008d-0f5b-4ad0-952d-d497ed2f3d83",
+      "last_activity_ts": 1747999953.9639006,
+      "services": [],
+      "init_time": 1742988129.563753,
+      "locations": [
+        {
+          "site": "FRANKFURT",
+          "equipment": "RT1.FRA.DE"
+        }
+      ],
+      "contacts": [],
+      "event_history": [
+        "9bfbe5f9-44f3-44dc-8177-aa782331cc80",
+        "77321624-4010-4f67-8fca-5bbcb4c7f437",
+        "3fce03e1-fce6-48cf-9b5a-b14262a6d19c",
+        "b43b8bbc-cd07-4407-8d91-ecc9c3427327"
+      ],
+      "up": false,
+      "group_peers": [
+        "185.6.36.28",
+        "193.188.137.21",
+        "193.188.137.51",
+        "193.203.0.164",
+        "193.203.0.165",
+        "195.66.224.140",
+        "2001:07f8:0000:0000:0000:1f8b:0000:0001",
+        "2001:07f8:0000:0000:0000:1f8b:0000:0002",
+        "2001:07f8:0001:0000:0000:a500:8075:0001",
+        "2001:07f8:0001:0000:0000:a500:8075:0002",
+        "2001:07f8:0004:0000:0000:0000:1f8b:0001",
+        "2001:07f8:000b:0100:01d1:a5d0:8075:0112",
+        "2001:07f8:000b:0100:01d1:a5d0:8075:0212",
+        "2001:07f8:0014:0000:0000:0000:006b:0001",
+        "2001:07f8:0018:0000:0000:0000:0000:0028",
+        "2001:07f8:0030:0000:0002:0001:0000:8075",
+        "2001:07f8:0030:0000:0002:0002:0000:8075",
+        "2001:07f8:0035:0000:0000:0000:8075:0001",
+        "2001:07f8:0035:0000:0000:0000:8075:0002",
+        "217.29.66.112",
+        "217.29.66.212",
+        "80.249.209.20",
+        "80.249.209.21",
+        "80.81.194.52",
+        "80.81.195.11"
+      ],
+      "router_peers": [
+        "2001:07f8:0000:0000:0000:002a:0000:0001",
+        "2001:07f8:0000:0000:0000:02ca:0000:0001",
+        "2001:07f8:0000:0000:0000:02ca:0000:0002",
+        "2001:07f8:0000:0000:0000:02ca:0000:0003",
+        "2001:07f8:0000:0000:0000:02ca:0000:0004",
+        "2001:07f8:0000:0000:0000:0847:0000:0001",
+        "2001:07f8:0000:0000:0000:0a4b:0000:0001",
+        "2001:07f8:0000:0000:0000:0b5a:0000:0001",
+        "2001:07f8:0000:0000:0000:0b5a:0000:0002",
+        "2001:07f8:0000:0000:0000:0c89:0000:0003",
+        "2001:07f8:0000:0000:0000:0c89:0000:0004",
+        "2001:07f8:0000:0000:0000:0c90:0000:0001",
+        "2001:07f8:0000:0000:0000:0c97:0000:0001",
+        "2001:07f8:0000:0000:0000:0ce7:0000:0002",
+        "2001:07f8:0000:0000:0000:1026:0000:0002",
+        "2001:07f8:0000:0000:0000:1518:0000:0001",
+        "2001:07f8:0000:0000:0000:1918:0000:0001",
+        "2001:07f8:0000:0000:0000:193d:0000:0001",
+        "2001:07f8:0000:0000:0000:193d:0000:0002",
+        "2001:07f8:0000:0000:0000:1a05:0000:0001",
+        "2001:07f8:0000:0000:0000:1b1b:0000:0001",
+        "2001:07f8:0000:0000:0000:1cae:0000:0001",
+        "2001:07f8:0000:0000:0000:1f8b:0000:0001",
+        "2001:07f8:0000:0000:0000:1f8b:0000:0002",
+        "2001:07f8:0000:0000:0000:201a:0000:0001",
+        "2001:07f8:0000:0000:0000:201a:0000:0002",
+        "2001:07f8:0000:0000:0000:201c:0000:0001",
+        "2001:07f8:0000:0000:0000:201c:0000:0002",
+        "2001:07f8:0000:0000:0000:206e:0000:0001",
+        "2001:07f8:0000:0000:0000:206e:0000:0002",
+        "2001:07f8:0000:0000:0000:20d0:0000:0001",
+        "2001:07f8:0000:0000:0000:20ea:0000:0001",
+        "2001:07f8:0000:0000:0000:20ea:0000:0002",
+        "2001:07f8:0000:0000:0000:2107:0000:0001",
+        "2001:07f8:0000:0000:0000:2167:0000:0001",
+        "2001:07f8:0000:0000:0000:2167:0000:0002",
+        "2001:07f8:0000:0000:0000:2170:0000:0001",
+        "2001:07f8:0000:0000:0000:2170:0000:0002",
+        "2001:07f8:0000:0000:0000:21d1:0000:0001",
+        "2001:07f8:0000:0000:0000:21e2:0000:0001",
+        "2001:07f8:0000:0000:0000:2204:0000:0001",
+        "2001:07f8:0000:0000:0000:2204:0000:0002",
+        "2001:07f8:0000:0000:0000:2306:0000:0001",
+        "2001:07f8:0000:0000:0000:232a:0000:0001",
+        "2001:07f8:0000:0000:0000:2331:0000:0001",
+        "2001:07f8:0000:0000:0000:2846:0000:0001",
+        "2001:07f8:0000:0000:0000:2846:0000:0002",
+        "2001:07f8:0000:0000:0000:3022:0000:0001",
+        "2001:07f8:0000:0000:0000:3122:0000:0001",
+        "2001:07f8:0000:0000:0000:316e:0000:0001",
+        "2001:07f8:0000:0000:0000:32e6:0000:0001",
+        "2001:07f8:0000:0000:0000:32e6:0000:0002",
+        "2001:07f8:0000:0000:0000:33e5:0000:0001",
+        "2001:07f8:0000:0000:0000:3417:0000:0001",
+        "2001:07f8:0000:0000:0000:3417:0000:0002",
+        "2001:07f8:0000:0000:0000:3466:0000:0001",
+        "2001:07f8:0000:0000:0000:3466:0000:0002",
+        "2001:07f8:0000:0000:0000:36ed:0000:0001",
+        "2001:07f8:0000:0000:0000:36ed:0000:0002",
+        "2001:07f8:0000:0000:0000:3f89:0000:0001",
+        "2001:07f8:0000:0000:0000:3f89:0000:0002",
+        "2001:07f8:0000:0000:0000:3f94:0000:0001",
+        "2001:07f8:0000:0000:0000:3f94:0000:0002",
+        "2001:07f8:0000:0000:0000:407d:0000:0001",
+        "2001:07f8:0000:0000:0000:407d:0000:0002",
+        "2001:07f8:0000:0000:0000:46ba:0000:0001",
+        "2001:07f8:0000:0000:0000:4c5f:0000:0001",
+        "2001:07f8:0000:0000:0000:4cdf:0000:0001",
+        "2001:07f8:0000:0000:0000:4ff9:0000:0001",
+        "2001:07f8:0000:0000:0000:5125:00f1:0001",
+        "2001:07f8:0000:0000:0000:51c4:0000:0001",
+        "2001:07f8:0000:0000:0000:51cc:0000:0028",
+        "2001:07f8:0000:0000:0000:51cc:0000:0168",
+        "2001:07f8:0000:0000:0000:51cc:0001:0168",
+        "2001:07f8:0000:0000:0000:616c:0000:0001",
+        "2001:07f8:0000:0000:0000:616c:0000:0002",
+        "2001:07f8:0000:0000:0000:6181:0000:0001",
+        "2001:07f8:0000:0000:0000:6319:0000:0001",
+        "2001:07f8:0000:0000:0000:7581:0000:0001",
+        "2001:07f8:0000:0000:0000:7597:0000:0001",
+        "2001:07f8:0000:0000:0000:787c:0000:0001",
+        "2001:07f8:0000:0000:0000:799d:0000:0001",
+        "2001:07f8:0000:0000:0000:7b29:0000:0001",
+        "2001:07f8:0000:0000:0000:7c9a:0000:0001",
+        "2001:07f8:0000:0000:0000:7f4e:0000:0001",
+        "2001:07f8:0000:0000:0000:7f4e:0000:0002",
+        "2001:07f8:0000:0000:0000:80a6:0000:0001",
+        "2001:07f8:0000:0000:0000:80a6:0000:0002",
+        "2001:07f8:0000:0000:0000:80a6:0000:0003",
+        "2001:07f8:0000:0000:0000:80a6:0000:0004",
+        "2001:07f8:0000:0000:0000:813a:0000:0001",
+        "2001:07f8:0000:0000:0000:8463:0000:0001",
+        "2001:07f8:0000:0000:0000:8463:0000:0002",
+        "2001:07f8:0000:0000:0000:88a8:0000:0001",
+        "2001:07f8:0000:0000:0000:8dff:0000:0001",
+        "2001:07f8:0000:0000:0000:8dff:0000:0002",
+        "2001:07f8:0000:0000:0000:8e6b:0000:0001",
+        "2001:07f8:0000:0000:0000:8e6b:0000:0002",
+        "2001:07f8:0000:0000:0000:8f54:0000:0001",
+        "2001:07f8:0000:0000:0000:9a94:0000:0001",
+        "2001:07f8:0000:0000:0000:b599:0000:0001",
+        "2001:07f8:0000:0000:0000:b599:0000:0002",
+        "2001:07f8:0000:0000:0000:c188:0000:0001",
+        "2001:07f8:0000:0000:0000:c695:0000:0001",
+        "2001:07f8:0000:0000:0000:d361:0000:0001",
+        "2001:07f8:0000:0000:0000:d361:0000:0002",
+        "2001:07f8:0000:0000:0000:d6d2:0000:0001",
+        "2001:07f8:0000:0000:0000:dd59:0000:0001",
+        "2001:07f8:0000:0000:0000:e278:0000:0001",
+        "2001:07f8:0000:0000:0000:e2c9:0000:0001",
+        "2001:07f8:0000:0000:0002:16cb:0000:0001",
+        "2001:07f8:0000:0000:0003:0b64:0000:0002",
+        "2001:07f8:0000:0000:0006:0eba:0000:0001",
+        "2001:07f8:0000:0000:0006:0eba:0000:0002",
+        "80.81.192.10",
+        "80.81.192.104",
+        "80.81.192.110",
+        "80.81.192.115",
+        "80.81.192.117",
+        "80.81.192.123",
+        "80.81.192.125",
+        "80.81.192.13",
+        "80.81.192.152",
+        "80.81.192.160",
+        "80.81.192.162",
+        "80.81.192.164",
+        "80.81.192.165",
+        "80.81.192.168",
+        "80.81.192.172",
+        "80.81.192.176",
+        "80.81.192.187",
+        "80.81.192.191",
+        "80.81.192.195",
+        "80.81.192.204",
+        "80.81.192.209",
+        "80.81.192.223",
+        "80.81.192.224",
+        "80.81.192.228",
+        "80.81.192.236",
+        "80.81.192.239",
+        "80.81.192.243",
+        "80.81.192.245",
+        "80.81.192.255",
+        "80.81.192.28",
+        "80.81.192.38",
+        "80.81.192.5",
+        "80.81.192.61",
+        "80.81.192.67",
+        "80.81.192.73",
+        "80.81.192.86",
+        "80.81.192.87",
+        "80.81.193.115",
+        "80.81.193.117",
+        "80.81.193.123",
+        "80.81.193.129",
+        "80.81.193.13",
+        "80.81.193.141",
+        "80.81.193.156",
+        "80.81.193.164",
+        "80.81.193.183",
+        "80.81.193.191",
+        "80.81.193.202",
+        "80.81.193.209",
+        "80.81.193.223",
+        "80.81.193.228",
+        "80.81.193.246",
+        "80.81.193.252",
+        "80.81.193.34",
+        "80.81.193.61",
+        "80.81.193.63",
+        "80.81.193.67",
+        "80.81.193.69",
+        "80.81.193.81",
+        "80.81.193.84",
+        "80.81.193.86",
+        "80.81.193.87",
+        "80.81.194.107",
+        "80.81.194.12",
+        "80.81.194.121",
+        "80.81.194.138",
+        "80.81.194.151",
+        "80.81.194.152",
+        "80.81.194.156",
+        "80.81.194.161",
+        "80.81.194.165",
+        "80.81.194.167",
+        "80.81.194.171",
+        "80.81.194.180",
+        "80.81.194.181",
+        "80.81.194.182",
+        "80.81.194.202",
+        "80.81.194.21",
+        "80.81.194.218",
+        "80.81.194.237",
+        "80.81.194.244",
+        "80.81.194.26",
+        "80.81.194.40",
+        "80.81.194.42",
+        "80.81.194.44",
+        "80.81.194.52",
+        "80.81.194.57",
+        "80.81.194.99",
+        "80.81.195.11",
+        "80.81.195.120",
+        "80.81.195.141",
+        "80.81.195.144",
+        "80.81.195.147",
+        "80.81.195.151",
+        "80.81.195.152",
+        "80.81.195.168",
+        "80.81.195.176",
+        "80.81.195.184",
+        "80.81.195.207",
+        "80.81.195.213",
+        "80.81.195.219",
+        "80.81.195.22",
+        "80.81.195.231",
+        "80.81.195.26",
+        "80.81.195.33",
+        "80.81.195.40",
+        "80.81.195.54",
+        "80.81.195.55",
+        "80.81.195.60",
+        "80.81.196.168",
+        "80.81.196.21",
+        "80.81.196.235",
+        "80.81.196.252",
+        "80.81.196.28",
+        "80.81.196.4",
+        "80.81.196.79",
+        "80.81.196.80",
+        "80.81.197.4"
+      ],
+      "peer": "2001:07f8:0000:0000:0000:1f8b:0000:0001",
+      "peer_description": "Microsoft AS8075",
+      "peer_router": "rt1.fra.de.geant.net",
+      "snmp": {
+        "hostname": "rt1.fra.de.geant.net",
+        "community": "0pBiFbD",
+        "oid": ".1.3.6.1.4.1.2636.5.1.1.2.1.1.1.2.10.2.32.1.7.248.0.0.0.0.0.0.81.229.0.0.0.1.2.32.1.7.248.0.0.0.0.0.0.31.139.0.0.0.1"
+      },
+      "device_name": "rt1.fra.de.geant.net"
+    },
+    {
+      "type": "BGPIXEndpoint",
+      "uuid": "2dc0ef6b-273b-4b39-b90f-4dc45963709a",
+      "name": "ix::lo0.rt1.mar.fr.geant.net::2001:07f8:0036:0000:0000:0f10:0000:0001",
+      "projects": [],
+      "alarm": "0de27fd4-3be8-41db-976f-46efaf7a2ea5",
+      "last_activity_ts": 1747999998.5876493,
+      "services": [],
+      "init_time": 1742988196.751406,
+      "locations": [
+        {
+          "site": "MARSEILLE",
+          "equipment": "RT1.MAR.FR"
+        }
+      ],
+      "contacts": [],
+      "event_history": [
+        "e01b3243-78e0-4571-90e4-f9e75deaa04f",
+        "f3c4caa5-aef7-4219-b3aa-3e7190668059",
+        "e2b23b18-d99d-4bcb-818c-c70e741e6383",
+        "6ab33119-b39c-4276-8639-401f40c94ae9"
+      ],
+      "up": false,
+      "group_peers": [
+        "185.1.192.15",
+        "185.1.192.87",
+        "185.1.47.21",
+        "185.1.47.42",
+        "185.6.36.60",
+        "185.6.36.61",
+        "193.203.0.126",
+        "193.203.0.33",
+        "195.66.225.238",
+        "195.66.225.239",
+        "2001:07f8:0000:0000:0000:002a:0000:0001",
+        "2001:07f8:0001:0000:0000:a500:0042:0001",
+        "2001:07f8:0001:0000:0000:a500:3856:0001",
+        "2001:07f8:0004:0000:0000:0000:002a:0001",
+        "2001:07f8:0004:0000:0000:0000:0f10:0001",
+        "2001:07f8:0018:0000:0000:0000:0000:0060",
+        "2001:07f8:0018:0000:0000:0000:0000:0061",
+        "2001:07f8:0030:0000:0001:0001:0000:0042",
+        "2001:07f8:0030:0000:0001:0001:0000:3856",
+        "2001:07f8:0036:0000:0000:002a:0000:0001",
+        "2001:07f8:0036:0000:0000:0f10:0000:0001",
+        "2001:07f8:00a0:0000:0000:002a:0000:0001",
+        "2001:07f8:00a0:0000:0000:0f10:0000:0001",
+        "80.249.208.250",
+        "80.249.209.250",
+        "80.81.194.42"
+      ],
+      "router_peers": [
+        "185.1.47.113",
+        "185.1.47.115",
+        "185.1.47.121",
+        "185.1.47.125",
+        "185.1.47.2",
+        "185.1.47.21",
+        "185.1.47.252",
+        "185.1.47.253",
+        "185.1.47.26",
+        "185.1.47.36",
+        "185.1.47.38",
+        "185.1.47.4",
+        "185.1.47.42",
+        "185.1.47.48",
+        "185.1.47.54",
+        "185.1.47.55",
+        "185.1.47.61",
+        "185.1.47.69",
+        "185.1.47.79",
+        "185.1.47.85",
+        "185.1.47.9",
+        "185.1.47.92",
+        "2001:07f8:0036:0000:0000:002a:0000:0001",
+        "2001:07f8:0036:0000:0000:0ce7:0000:0001",
+        "2001:07f8:0036:0000:0000:0f10:0000:0001",
+        "2001:07f8:0036:0000:0000:1b1b:0000:0001",
+        "2001:07f8:0036:0000:0000:2306:0000:0001",
+        "2001:07f8:0036:0000:0000:2846:0000:0001",
+        "2001:07f8:0036:0000:0000:2846:0000:0002",
+        "2001:07f8:0036:0000:0000:32e6:0000:0001",
+        "2001:07f8:0036:0000:0000:3417:0000:0001",
+        "2001:07f8:0036:0000:0000:3a3b:0000:0001",
+        "2001:07f8:0036:0000:0000:407d:0000:0001",
+        "2001:07f8:0036:0000:0000:407d:0000:0002",
+        "2001:07f8:0036:0000:0000:50ed:00fc:0001",
+        "2001:07f8:0036:0000:0000:50ed:00fd:0001",
+        "2001:07f8:0036:0000:0000:787c:0000:0001",
+        "2001:07f8:0036:0000:0000:799d:0000:0001",
+        "2001:07f8:0036:0000:0000:80a6:0000:0001",
+        "2001:07f8:0036:0000:0000:80a6:0000:0002",
+        "2001:07f8:0036:0000:0000:d361:0000:0001",
+        "2001:07f8:0036:0000:0003:0b64:0000:0001",
+        "2001:07f8:0036:0000:0006:0eba:0000:0001",
+        "2001:07f8:0036:0000:0006:0eba:0000:0002"
+      ],
+      "peer": "2001:07f8:0036:0000:0000:0f10:0000:0001",
+      "peer_description": "Packet_Clearing_House AS3856",
+      "peer_router": "rt1.mar.fr.geant.net",
+      "snmp": {
+        "hostname": "rt1.mar.fr.geant.net",
+        "community": "0pBiFbD",
+        "oid": ".1.3.6.1.4.1.2636.5.1.1.2.1.1.1.2.9.2.32.1.7.248.0.54.0.0.0.0.81.229.0.0.0.1.2.32.1.7.248.0.54.0.0.0.0.15.16.0.0.0.1"
+      },
+      "device_name": "rt1.mar.fr.geant.net"
+    },
+    {
+      "type": "BGPIXEndpoint",
+      "uuid": "ce81e6fc-b69a-467b-a4f6-f210f62724cf",
+      "name": "ix::lo0.rt1.mar.fr.geant.net::185.1.47.21",
+      "projects": [],
+      "alarm": "7257d16b-acf3-4eac-b8d7-23f4879cac9e",
+      "last_activity_ts": 1747999979.5441952,
+      "services": [],
+      "init_time": 1745405891.062826,
+      "locations": [
+        {
+          "site": "MARSEILLE",
+          "equipment": "RT1.MAR.FR"
+        }
+      ],
+      "contacts": [],
+      "event_history": [
+        "871c84f8-ced3-4dea-b0d7-a4f49faf92a5",
+        "a1a11b4f-26c4-4e48-a7b8-4c5d2a1266de",
+        "0356a2ab-db83-41f4-9e93-f1efe94c6446",
+        "fb15b283-4935-42d2-8350-9e2ca5342e28"
+      ],
+      "up": false,
+      "group_peers": [
+        "185.1.192.15",
+        "185.1.192.87",
+        "185.1.47.21",
+        "185.1.47.42",
+        "185.6.36.60",
+        "185.6.36.61",
+        "193.203.0.126",
+        "193.203.0.33",
+        "195.66.225.238",
+        "195.66.225.239",
+        "2001:07f8:0000:0000:0000:002a:0000:0001",
+        "2001:07f8:0001:0000:0000:a500:0042:0001",
+        "2001:07f8:0001:0000:0000:a500:3856:0001",
+        "2001:07f8:0004:0000:0000:0000:002a:0001",
+        "2001:07f8:0004:0000:0000:0000:0f10:0001",
+        "2001:07f8:0018:0000:0000:0000:0000:0060",
+        "2001:07f8:0018:0000:0000:0000:0000:0061",
+        "2001:07f8:0030:0000:0001:0001:0000:0042",
+        "2001:07f8:0030:0000:0001:0001:0000:3856",
+        "2001:07f8:0036:0000:0000:002a:0000:0001",
+        "2001:07f8:0036:0000:0000:0f10:0000:0001",
+        "2001:07f8:00a0:0000:0000:002a:0000:0001",
+        "2001:07f8:00a0:0000:0000:0f10:0000:0001",
+        "80.249.208.250",
+        "80.249.209.250",
+        "80.81.194.42"
+      ],
+      "router_peers": [
+        "185.1.47.113",
+        "185.1.47.115",
+        "185.1.47.121",
+        "185.1.47.125",
+        "185.1.47.2",
+        "185.1.47.21",
+        "185.1.47.252",
+        "185.1.47.253",
+        "185.1.47.26",
+        "185.1.47.36",
+        "185.1.47.38",
+        "185.1.47.4",
+        "185.1.47.42",
+        "185.1.47.48",
+        "185.1.47.54",
+        "185.1.47.55",
+        "185.1.47.61",
+        "185.1.47.69",
+        "185.1.47.79",
+        "185.1.47.85",
+        "185.1.47.9",
+        "185.1.47.92",
+        "2001:07f8:0036:0000:0000:002a:0000:0001",
+        "2001:07f8:0036:0000:0000:0ce7:0000:0001",
+        "2001:07f8:0036:0000:0000:0f10:0000:0001",
+        "2001:07f8:0036:0000:0000:1b1b:0000:0001",
+        "2001:07f8:0036:0000:0000:2306:0000:0001",
+        "2001:07f8:0036:0000:0000:2846:0000:0001",
+        "2001:07f8:0036:0000:0000:2846:0000:0002",
+        "2001:07f8:0036:0000:0000:32e6:0000:0001",
+        "2001:07f8:0036:0000:0000:3417:0000:0001",
+        "2001:07f8:0036:0000:0000:3a3b:0000:0001",
+        "2001:07f8:0036:0000:0000:407d:0000:0001",
+        "2001:07f8:0036:0000:0000:407d:0000:0002",
+        "2001:07f8:0036:0000:0000:50ed:00fc:0001",
+        "2001:07f8:0036:0000:0000:50ed:00fd:0001",
+        "2001:07f8:0036:0000:0000:787c:0000:0001",
+        "2001:07f8:0036:0000:0000:799d:0000:0001",
+        "2001:07f8:0036:0000:0000:80a6:0000:0001",
+        "2001:07f8:0036:0000:0000:80a6:0000:0002",
+        "2001:07f8:0036:0000:0000:d361:0000:0001",
+        "2001:07f8:0036:0000:0003:0b64:0000:0001",
+        "2001:07f8:0036:0000:0006:0eba:0000:0001",
+        "2001:07f8:0036:0000:0006:0eba:0000:0002"
+      ],
+      "peer": "185.1.47.21",
+      "peer_description": "Packet_Clearing_House AS3856",
+      "peer_router": "rt1.mar.fr.geant.net",
+      "snmp": {
+        "hostname": "rt1.mar.fr.geant.net",
+        "community": "0pBiFbD",
+        "oid": ".1.3.6.1.4.1.2636.5.1.1.2.1.1.1.2.9.1.185.1.47.34.1.185.1.47.21"
+      },
+      "device_name": "rt1.mar.fr.geant.net"
+    },
+    {
+      "type": "BGPIXEndpoint",
+      "uuid": "e0d6c37b-9289-41fe-8aa4-bf6b4f521f44",
+      "name": "ix::lo0.rt1.mil2.it.geant.net::2001:07f8:000b:0100:01d1:a5d1:6004:0001",
+      "projects": [],
+      "alarm": "ff5c8a7a-de85-429f-8699-5347fba6d40d",
+      "last_activity_ts": 1747999933.8936088,
+      "services": [],
+      "init_time": 1747899142.498491,
+      "locations": [
+        {
+          "site": "MILAN 2 CALDERA",
+          "equipment": "RT1.MIL2.IT"
+        }
+      ],
+      "contacts": [],
+      "event_history": [
+        "0ae9136a-cb29-4aee-9099-5ffe315c8750",
+        "af6180ec-ff74-4368-8248-3c4926aaf2f4",
+        "30e4ea58-10ff-430c-9b76-e78b92378fc2",
+        "408e48bd-fd6b-422e-8630-2773bd91e9d2"
+      ],
+      "up": false,
+      "group_peers": [
+        "2001:07f8:000b:0100:01d1:a5d1:6004:0001",
+        "217.29.66.1"
+      ],
+      "router_peers": [
+        "2001:07f8:000b:0100:01d1:a519:9524:0055",
+        "2001:07f8:000b:0100:01d1:a539:6986:0160",
+        "2001:07f8:000b:0100:01d1:a5d0:2635:0020",
+        "2001:07f8:000b:0100:01d1:a5d0:2906:0186",
+        "2001:07f8:000b:0100:01d1:a5d0:2906:0187",
+        "2001:07f8:000b:0100:01d1:a5d0:3303:0017",
+        "2001:07f8:000b:0100:01d1:a5d0:5400:0119",
+        "2001:07f8:000b:0100:01d1:a5d0:6939:0125",
+        "2001:07f8:000b:0100:01d1:a5d0:8075:0112",
+        "2001:07f8:000b:0100:01d1:a5d0:8075:0212",
+        "2001:07f8:000b:0100:01d1:a5d0:8220:0068",
+        "2001:07f8:000b:0100:01d1:a5d0:8551:0102",
+        "2001:07f8:000b:0100:01d1:a5d0:8674:0057",
+        "2001:07f8:000b:0100:01d1:a5d0:8674:0357",
+        "2001:07f8:000b:0100:01d1:a5d0:9002:0116",
+        "2001:07f8:000b:0100:01d1:a5d0:9009:0064",
+        "2001:07f8:000b:0100:01d1:a5d1:0310:0028",
+        "2001:07f8:000b:0100:01d1:a5d1:0310:0029",
+        "2001:07f8:000b:0100:01d1:a5d1:2654:0006",
+        "2001:07f8:000b:0100:01d1:a5d1:3030:0056",
+        "2001:07f8:000b:0100:01d1:a5d1:3030:0228",
+        "2001:07f8:000b:0100:01d1:a5d1:3335:0167",
+        "2001:07f8:000b:0100:01d1:a5d1:6004:0001",
+        "2001:07f8:000b:0100:01d1:a5d1:6004:0253",
+        "2001:07f8:000b:0100:01d1:a5d1:6004:0254",
+        "2001:07f8:000b:0100:01d1:a5d1:6276:0067",
+        "2001:07f8:000b:0100:01d1:a5d1:6509:0016",
+        "2001:07f8:000b:0100:01d1:a5d1:6509:0074",
+        "2001:07f8:000b:0100:01d1:a5d1:9551:0201",
+        "2001:07f8:000b:0100:01d1:a5d1:9679:0010",
+        "2001:07f8:000b:0100:01d1:a5d2:0940:0166",
+        "2001:07f8:000b:0100:01d1:a5d2:0940:0214",
+        "2001:07f8:000b:0100:01d1:a5d2:0940:0233",
+        "2001:07f8:000b:0100:01d1:a5d2:4961:0151",
+        "2001:07f8:000b:0100:01d1:a5d2:6415:0020",
+        "2001:07f8:000b:0100:01d1:a5d3:2934:0131",
+        "2001:07f8:000b:0100:01d1:a5d3:2934:0156",
+        "2001:07f8:000b:0100:01d1:a5d3:6351:0047",
+        "2001:07f8:000b:0100:01d1:a5d3:6692:0041",
+        "2001:07f8:000b:0100:01d1:a5d4:6489:0017",
+        "2001:07f8:000b:0100:01d1:a5d4:6489:0018",
+        "2001:07f8:000b:0100:01d1:a5d4:9544:0051",
+        "2001:07f8:000b:0100:01d1:a5d5:4113:0077",
+        "2001:07f8:000b:0100:01d1:a5d5:4113:0078",
+        "2001:07f8:000b:0100:01d1:a5d5:7976:0217",
+        "2001:07f8:000b:0100:01d1:a5d6:0798:0028",
+        "217.29.66.1",
+        "217.29.66.112",
+        "217.29.66.116",
+        "217.29.66.119",
+        "217.29.66.125",
+        "217.29.66.131",
+        "217.29.66.156",
+        "217.29.66.166",
+        "217.29.66.167",
+        "217.29.66.17",
+        "217.29.66.186",
+        "217.29.66.187",
+        "217.29.66.20",
+        "217.29.66.201",
+        "217.29.66.212",
+        "217.29.66.214",
+        "217.29.66.217",
+        "217.29.66.228",
+        "217.29.66.232",
+        "217.29.66.253",
+        "217.29.66.254",
+        "217.29.66.28",
+        "217.29.66.47",
+        "217.29.66.51",
+        "217.29.66.57",
+        "217.29.66.6",
+        "217.29.66.67",
+        "217.29.66.68",
+        "217.29.66.74",
+        "217.29.67.10",
+        "217.29.67.102",
+        "217.29.67.151",
+        "217.29.67.16",
+        "217.29.67.160",
+        "217.29.67.17",
+        "217.29.67.18",
+        "217.29.67.20",
+        "217.29.67.28",
+        "217.29.67.29",
+        "217.29.67.41",
+        "217.29.67.55",
+        "217.29.67.56",
+        "217.29.67.57",
+        "217.29.67.64",
+        "217.29.67.77",
+        "217.29.67.78",
+        "217.29.67.88"
+      ],
+      "peer": "2001:07f8:000b:0100:01d1:a5d1:6004:0001",
+      "peer_description": "MIX AS16004",
+      "peer_router": "rt1.mil2.it.geant.net",
+      "snmp": {
+        "hostname": "rt1.mil2.it.geant.net",
+        "community": "0pBiFbD",
+        "oid": ".1.3.6.1.4.1.2636.5.1.1.2.1.1.1.2.9.2.32.1.7.248.0.11.1.0.1.209.165.210.9.101.1.131.2.32.1.7.248.0.11.1.0.1.209.165.209.96.4.0.1"
+      },
+      "device_name": "rt1.mil2.it.geant.net"
+    },
+    {
+      "type": "BGPIXEndpoint",
+      "uuid": "dc636ec3-10d3-4a1c-989b-656cfd7c7a5e",
+      "name": "ix::lo0.rt1.mil2.it.geant.net::217.29.66.1",
+      "projects": [],
+      "alarm": "ff5c8a7a-de85-429f-8699-5347fba6d40d",
+      "last_activity_ts": 1747999962.961334,
+      "services": [],
+      "init_time": 1747899172.710716,
+      "locations": [
+        {
+          "site": "MILAN 2 CALDERA",
+          "equipment": "RT1.MIL2.IT"
+        }
+      ],
+      "contacts": [],
+      "event_history": [
+        "ee42124c-7ce4-4409-b939-437e16af6205",
+        "e0733753-c97d-4568-931f-7e29f1961e9f",
+        "d7d8e061-3f65-459e-a17c-bd629cf8ffb0",
+        "03d93d31-fde8-4532-93ad-6937d0929185"
+      ],
+      "up": false,
+      "group_peers": [
+        "2001:07f8:000b:0100:01d1:a5d1:6004:0001",
+        "217.29.66.1"
+      ],
+      "router_peers": [
+        "2001:07f8:000b:0100:01d1:a519:9524:0055",
+        "2001:07f8:000b:0100:01d1:a539:6986:0160",
+        "2001:07f8:000b:0100:01d1:a5d0:2635:0020",
+        "2001:07f8:000b:0100:01d1:a5d0:2906:0186",
+        "2001:07f8:000b:0100:01d1:a5d0:2906:0187",
+        "2001:07f8:000b:0100:01d1:a5d0:3303:0017",
+        "2001:07f8:000b:0100:01d1:a5d0:5400:0119",
+        "2001:07f8:000b:0100:01d1:a5d0:6939:0125",
+        "2001:07f8:000b:0100:01d1:a5d0:8075:0112",
+        "2001:07f8:000b:0100:01d1:a5d0:8075:0212",
+        "2001:07f8:000b:0100:01d1:a5d0:8220:0068",
+        "2001:07f8:000b:0100:01d1:a5d0:8551:0102",
+        "2001:07f8:000b:0100:01d1:a5d0:8674:0057",
+        "2001:07f8:000b:0100:01d1:a5d0:8674:0357",
+        "2001:07f8:000b:0100:01d1:a5d0:9002:0116",
+        "2001:07f8:000b:0100:01d1:a5d0:9009:0064",
+        "2001:07f8:000b:0100:01d1:a5d1:0310:0028",
+        "2001:07f8:000b:0100:01d1:a5d1:0310:0029",
+        "2001:07f8:000b:0100:01d1:a5d1:2654:0006",
+        "2001:07f8:000b:0100:01d1:a5d1:3030:0056",
+        "2001:07f8:000b:0100:01d1:a5d1:3030:0228",
+        "2001:07f8:000b:0100:01d1:a5d1:3335:0167",
+        "2001:07f8:000b:0100:01d1:a5d1:6004:0001",
+        "2001:07f8:000b:0100:01d1:a5d1:6004:0253",
+        "2001:07f8:000b:0100:01d1:a5d1:6004:0254",
+        "2001:07f8:000b:0100:01d1:a5d1:6276:0067",
+        "2001:07f8:000b:0100:01d1:a5d1:6509:0016",
+        "2001:07f8:000b:0100:01d1:a5d1:6509:0074",
+        "2001:07f8:000b:0100:01d1:a5d1:9551:0201",
+        "2001:07f8:000b:0100:01d1:a5d1:9679:0010",
+        "2001:07f8:000b:0100:01d1:a5d2:0940:0166",
+        "2001:07f8:000b:0100:01d1:a5d2:0940:0214",
+        "2001:07f8:000b:0100:01d1:a5d2:0940:0233",
+        "2001:07f8:000b:0100:01d1:a5d2:4961:0151",
+        "2001:07f8:000b:0100:01d1:a5d2:6415:0020",
+        "2001:07f8:000b:0100:01d1:a5d3:2934:0131",
+        "2001:07f8:000b:0100:01d1:a5d3:2934:0156",
+        "2001:07f8:000b:0100:01d1:a5d3:6351:0047",
+        "2001:07f8:000b:0100:01d1:a5d3:6692:0041",
+        "2001:07f8:000b:0100:01d1:a5d4:6489:0017",
+        "2001:07f8:000b:0100:01d1:a5d4:6489:0018",
+        "2001:07f8:000b:0100:01d1:a5d4:9544:0051",
+        "2001:07f8:000b:0100:01d1:a5d5:4113:0077",
+        "2001:07f8:000b:0100:01d1:a5d5:4113:0078",
+        "2001:07f8:000b:0100:01d1:a5d5:7976:0217",
+        "2001:07f8:000b:0100:01d1:a5d6:0798:0028",
+        "217.29.66.1",
+        "217.29.66.112",
+        "217.29.66.116",
+        "217.29.66.119",
+        "217.29.66.125",
+        "217.29.66.131",
+        "217.29.66.156",
+        "217.29.66.166",
+        "217.29.66.167",
+        "217.29.66.17",
+        "217.29.66.186",
+        "217.29.66.187",
+        "217.29.66.20",
+        "217.29.66.201",
+        "217.29.66.212",
+        "217.29.66.214",
+        "217.29.66.217",
+        "217.29.66.228",
+        "217.29.66.232",
+        "217.29.66.253",
+        "217.29.66.254",
+        "217.29.66.28",
+        "217.29.66.47",
+        "217.29.66.51",
+        "217.29.66.57",
+        "217.29.66.6",
+        "217.29.66.67",
+        "217.29.66.68",
+        "217.29.66.74",
+        "217.29.67.10",
+        "217.29.67.102",
+        "217.29.67.151",
+        "217.29.67.16",
+        "217.29.67.160",
+        "217.29.67.17",
+        "217.29.67.18",
+        "217.29.67.20",
+        "217.29.67.28",
+        "217.29.67.29",
+        "217.29.67.41",
+        "217.29.67.55",
+        "217.29.67.56",
+        "217.29.67.57",
+        "217.29.67.64",
+        "217.29.67.77",
+        "217.29.67.78",
+        "217.29.67.88"
+      ],
+      "peer": "217.29.66.1",
+      "peer_description": "MIX AS16004",
+      "peer_router": "rt1.mil2.it.geant.net",
+      "snmp": {
+        "hostname": "rt1.mil2.it.geant.net",
+        "community": "0pBiFbD",
+        "oid": ".1.3.6.1.4.1.2636.5.1.1.2.1.1.1.2.9.1.217.29.66.183.1.217.29.66.1"
+      },
+      "device_name": "rt1.mil2.it.geant.net"
+    },
+    {
+      "type": "LinkEndpoint",
+      "uuid": "36127add-aa7d-4986-9082-2535967286cc",
+      "name": "mx1.bud.hu.geant.net::ae7",
+      "projects": [
+        "GEANT"
+      ],
+      "alarm": "3e159382-fedd-43c6-974f-cb3866b60b51",
+      "last_activity_ts": 1747999927.6877005,
+      "services": [
+        {
+          "name": "BUC-BUD-IPTRUNK",
+          "circuit_type": "service",
+          "service_type": "IP TRUNK",
+          "status": "operational",
+          "project": "GEANT",
+          "sid": "GS-00021"
+        }
+      ],
+      "init_time": 1747999918.633631,
+      "locations": [
+        {
+          "site": "BUDAPEST",
+          "equipment": "MX1.BUD.HU"
+        }
+      ],
+      "contacts": [
+        "GEANTINCIDENTS@LISTS.GEANT.ORG"
+      ],
+      "event_history": [
+        "798d88d4-d5be-48bf-80ab-c64089150a38",
+        "2e0fa67f-ff34-4036-90de-a25bb33441ff"
+      ],
+      "up": true,
+      "router": "mx1.bud.hu.geant.net",
+      "interface": "ae7",
+      "circuits": [
+        "BUC-BUD-IPTRUNK"
+      ],
+      "direct_circuits": [],
+      "bundle": [],
+      "bundle_members": [
+        "et-9/0/2",
+        "et-9/0/5"
+      ],
+      "snmp": {
+        "hostname": "mx1.bud.hu.geant.net",
+        "community": "0pBiFbD",
+        "index": 847,
+        "oids": [
+          "1.3.6.1.2.1.2.2.1.7.847",
+          "1.3.6.1.2.1.2.2.1.8.847"
+        ]
+      },
+      "device_name": "mx1.bud.hu.geant.net"
+    },
+    {
+      "type": "LinkEndpoint",
+      "uuid": "0c421518-5e36-44f8-9d6c-9f41b1ad37cc",
+      "name": "mx1.bud.hu.geant.net::et-9/0/5",
+      "projects": [
+        "GEANT"
+      ],
+      "alarm": "3e159382-fedd-43c6-974f-cb3866b60b51",
+      "last_activity_ts": 1747999920.423115,
+      "services": [
+        {
+          "name": "BUC-BUD-IPTRUNK",
+          "circuit_type": "service",
+          "service_type": "IP TRUNK",
+          "status": "operational",
+          "project": "GEANT",
+          "sid": "GS-00021"
+        }
+      ],
+      "init_time": 1747999918.653631,
+      "locations": [
+        {
+          "site": "BUDAPEST",
+          "equipment": "MX1.BUD.HU"
+        }
+      ],
+      "contacts": [
+        "GEANTINCIDENTS@LISTS.GEANT.ORG"
+      ],
+      "event_history": [
+        "5f2fcba6-b730-4f99-bc86-36b7bbca4762",
+        "69412673-5cae-4f7b-af2e-3376cc27d446"
+      ],
+      "up": true,
+      "router": "mx1.bud.hu.geant.net",
+      "interface": "et-9/0/5",
+      "circuits": [
+        "BUC-BUD-IPTRUNK"
+      ],
+      "direct_circuits": [],
+      "bundle": [
+        "ae7"
+      ],
+      "bundle_members": [],
+      "snmp": {
+        "hostname": "mx1.bud.hu.geant.net",
+        "community": "0pBiFbD",
+        "index": 1129,
+        "oids": [
+          "1.3.6.1.2.1.2.2.1.7.1129",
+          "1.3.6.1.2.1.2.2.1.8.1129"
+        ]
+      },
+      "device_name": "mx1.bud.hu.geant.net"
+    },
+    {
+      "type": "LinkEndpoint",
+      "uuid": "c59efe06-2da6-4e61-885c-85c9bb961df5",
+      "name": "mx1.bud.hu.geant.net::et-9/0/2",
+      "projects": [
+        "GEANT"
+      ],
+      "alarm": "3e159382-fedd-43c6-974f-cb3866b60b51",
+      "last_activity_ts": 1747999920.2875888,
+      "services": [
+        {
+          "name": "BUC-BUD-IPTRUNK",
+          "circuit_type": "service",
+          "service_type": "IP TRUNK",
+          "status": "operational",
+          "project": "GEANT",
+          "sid": "GS-00021"
+        }
+      ],
+      "init_time": 1747999918.641631,
+      "locations": [
+        {
+          "site": "BUDAPEST",
+          "equipment": "MX1.BUD.HU"
+        }
+      ],
+      "contacts": [
+        "GEANTINCIDENTS@LISTS.GEANT.ORG"
+      ],
+      "event_history": [
+        "23bf1bd4-7941-44ac-9d08-95bf4742b388",
+        "77d282ae-bebe-4824-81f1-b4ff0fa71761"
+      ],
+      "up": true,
+      "router": "mx1.bud.hu.geant.net",
+      "interface": "et-9/0/2",
+      "circuits": [
+        "BUC-BUD-IPTRUNK"
+      ],
+      "direct_circuits": [],
+      "bundle": [
+        "ae7"
+      ],
+      "bundle_members": [],
+      "snmp": {
+        "hostname": "mx1.bud.hu.geant.net",
+        "community": "0pBiFbD",
+        "index": 1128,
+        "oids": [
+          "1.3.6.1.2.1.2.2.1.7.1128",
+          "1.3.6.1.2.1.2.2.1.8.1128"
+        ]
+      },
+      "device_name": "mx1.bud.hu.geant.net"
+    },
+    {
+      "type": "LinkEndpoint",
+      "uuid": "a56b8761-0435-4974-b5a3-b966ca9f700d",
+      "name": "rt1.buc.ro.geant.net::ae7",
+      "projects": [
+        "GEANT"
+      ],
+      "alarm": "3e159382-fedd-43c6-974f-cb3866b60b51",
+      "last_activity_ts": 1747999951.1176512,
+      "services": [
+        {
+          "name": "BUC-BUD-IPTRUNK",
+          "circuit_type": "service",
+          "service_type": "IP TRUNK",
+          "status": "operational",
+          "project": "GEANT",
+          "sid": "GS-00021"
+        }
+      ],
+      "init_time": 1747999948.635053,
+      "locations": [
+        {
+          "site": "BUCHAREST 2",
+          "equipment": "RT1.BUC.RO"
+        }
+      ],
+      "contacts": [
+        "GEANTINCIDENTS@LISTS.GEANT.ORG"
+      ],
+      "event_history": [
+        "aac7affd-384d-40d4-834d-82702b6f3a5e",
+        "cea22e67-b179-4bd4-a2d1-8216541e1c27"
+      ],
+      "up": true,
+      "router": "rt1.buc.ro.geant.net",
+      "interface": "ae7",
+      "circuits": [
+        "BUC-BUD-IPTRUNK"
+      ],
+      "direct_circuits": [],
+      "bundle": [],
+      "bundle_members": [
+        "et-1/0/5",
+        "et-1/1/5"
+      ],
+      "snmp": {
+        "hostname": "rt1.buc.ro.geant.net",
+        "community": "0pBiFbD",
+        "index": 672,
+        "oids": [
+          "1.3.6.1.2.1.2.2.1.7.672",
+          "1.3.6.1.2.1.2.2.1.8.672"
+        ]
+      },
+      "device_name": "rt1.buc.ro.geant.net"
+    },
+    {
+      "type": "LinkEndpoint",
+      "uuid": "deaab807-bff0-40b5-b544-257cf583c2f7",
+      "name": "rt1.buc.ro.geant.net::et-1/0/5",
+      "projects": [
+        "GEANT"
+      ],
+      "alarm": "3e159382-fedd-43c6-974f-cb3866b60b51",
+      "last_activity_ts": 1747999950.5586994,
+      "services": [
+        {
+          "name": "BUC-BUD-IPTRUNK",
+          "circuit_type": "service",
+          "service_type": "IP TRUNK",
+          "status": "operational",
+          "project": "GEANT",
+          "sid": "GS-00021"
+        }
+      ],
+      "init_time": 1747999948.649855,
+      "locations": [
+        {
+          "site": "BUCHAREST 2",
+          "equipment": "RT1.BUC.RO"
+        }
+      ],
+      "contacts": [
+        "GEANTINCIDENTS@LISTS.GEANT.ORG"
+      ],
+      "event_history": [
+        "af89e66c-8ee4-4e83-a830-3981c175191d",
+        "d6e3388a-b9d9-45d3-8040-6f2ba6ba8bf9"
+      ],
+      "up": true,
+      "router": "rt1.buc.ro.geant.net",
+      "interface": "et-1/0/5",
+      "circuits": [
+        "BUC-BUD-IPTRUNK"
+      ],
+      "direct_circuits": [],
+      "bundle": [
+        "ae7"
+      ],
+      "bundle_members": [],
+      "snmp": {
+        "hostname": "rt1.buc.ro.geant.net",
+        "community": "0pBiFbD",
+        "index": 609,
+        "oids": [
+          "1.3.6.1.2.1.2.2.1.7.609",
+          "1.3.6.1.2.1.2.2.1.8.609"
+        ]
+      },
+      "device_name": "rt1.buc.ro.geant.net"
+    },
+    {
+      "type": "LinkEndpoint",
+      "uuid": "ae015560-f30b-44ad-bc79-6899ce1501d5",
+      "name": "rt1.buc.ro.geant.net::et-1/1/5",
+      "projects": [
+        "GEANT"
+      ],
+      "alarm": "3e159382-fedd-43c6-974f-cb3866b60b51",
+      "last_activity_ts": 1747999950.976269,
+      "services": [
+        {
+          "name": "BUC-BUD-IPTRUNK",
+          "circuit_type": "service",
+          "service_type": "IP TRUNK",
+          "status": "operational",
+          "project": "GEANT",
+          "sid": "GS-00021"
+        }
+      ],
+      "init_time": 1747999948.657855,
+      "locations": [
+        {
+          "site": "BUCHAREST 2",
+          "equipment": "RT1.BUC.RO"
+        }
+      ],
+      "contacts": [
+        "GEANTINCIDENTS@LISTS.GEANT.ORG"
+      ],
+      "event_history": [
+        "07e85630-8f6f-4c7a-b60f-e353d9b7a0b6",
+        "c8091b5c-64f9-46cb-a1c6-9c4d8bc2d160"
+      ],
+      "up": true,
+      "router": "rt1.buc.ro.geant.net",
+      "interface": "et-1/1/5",
+      "circuits": [
+        "BUC-BUD-IPTRUNK"
+      ],
+      "direct_circuits": [],
+      "bundle": [
+        "ae7"
+      ],
+      "bundle_members": [],
+      "snmp": {
+        "hostname": "rt1.buc.ro.geant.net",
+        "community": "0pBiFbD",
+        "index": 613,
+        "oids": [
+          "1.3.6.1.2.1.2.2.1.7.613",
+          "1.3.6.1.2.1.2.2.1.8.613"
+        ]
+      },
+      "device_name": "rt1.buc.ro.geant.net"
+    }
+  ],
+  "alarms": [
+    {
+      "uuid": "7257d16b-acf3-4eac-b8d7-23f4879cac9e",
+      "db_id": 104269503,
+      "endpoints": [
+        "ce81e6fc-b69a-467b-a4f6-f210f62724cf"
+      ],
+      "phase": "FINALIZED",
+      "final_severity": "MINOR",
+      "state": "OPEN",
+      "published": false,
+      "severity": "MINOR",
+      "description": "One or more IX peering down on rt1.mar.fr.geant.net affecting Packet_Clearing_House",
+      "devoured": []
+    },
+    {
+      "uuid": "ff5c8a7a-de85-429f-8699-5347fba6d40d",
+      "db_id": 104288962,
+      "endpoints": [
+        "e0d6c37b-9289-41fe-8aa4-bf6b4f521f44",
+        "dc636ec3-10d3-4a1c-989b-656cfd7c7a5e"
+      ],
+      "phase": "FINALIZED",
+      "final_severity": "WARNING",
+      "state": "OPEN",
+      "published": false,
+      "severity": "MAJOR",
+      "description": "Peering MIX not available via public peering",
+      "devoured": []
+    },
+    {
+      "uuid": "dc0d008d-0f5b-4ad0-952d-d497ed2f3d83",
+      "db_id": 104251376,
+      "endpoints": [
+        "d10dd830-5e7e-4eb7-ba8d-4b0ef384bce1"
+      ],
+      "phase": "FINALIZED",
+      "final_severity": "MINOR",
+      "state": "OPEN",
+      "published": false,
+      "severity": "MINOR",
+      "description": "One or more IX peering down on rt1.fra.de.geant.net affecting Microsoft",
+      "devoured": []
+    },
+    {
+      "uuid": "0de27fd4-3be8-41db-976f-46efaf7a2ea5",
+      "db_id": 104251373,
+      "endpoints": [
+        "2dc0ef6b-273b-4b39-b90f-4dc45963709a"
+      ],
+      "phase": "FINALIZED",
+      "final_severity": "MINOR",
+      "state": "OPEN",
+      "published": false,
+      "severity": "MINOR",
+      "description": "One or more IX peering down on rt1.mar.fr.geant.net affecting Packet_Clearing_House",
+      "devoured": []
+    },
+    {
+      "uuid": "3e159382-fedd-43c6-974f-cb3866b60b51",
+      "db_id": 104291427,
+      "endpoints": [
+        "0c421518-5e36-44f8-9d6c-9f41b1ad37cc",
+        "36127add-aa7d-4986-9082-2535967286cc",
+        "deaab807-bff0-40b5-b544-257cf583c2f7",
+        "ae015560-f30b-44ad-bc79-6899ce1501d5",
+        "a56b8761-0435-4974-b5a3-b966ca9f700d",
+        "c59efe06-2da6-4e61-885c-85c9bb961df5"
+      ],
+      "phase": "PENDING",
+      "final_severity": null,
+      "state": "CLOSED",
+      "published": false,
+      "severity": "CRITICAL",
+      "description": "BUC-BUD-IPTRUNK (interface ae7) Incident",
+      "devoured": []
+    }
+  ]
+}
\ No newline at end of file
diff --git a/test/data/poller-interfaces.json b/test/data/poller-interfaces.json
new file mode 100644
index 0000000000000000000000000000000000000000..656887235590b76cd8b133318f84d55d58b349bd
--- /dev/null
+++ b/test/data/poller-interfaces.json
@@ -0,0 +1,79554 @@
+[
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c8/1",
+      "2/x1/1/c8/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LJU-ZAG-IPTRUNK $GS-02372 | LJU-ZAG | ",
+    "circuits": [
+      {
+        "id": 747865,
+        "name": "LJU-ZAG-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 9,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-ZAG",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-ZAG",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/2.2200",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT HBKU #UK-HBKU $GS-00907 | ASN34945 |",
+    "circuits": [
+      {
+        "id": 661378,
+        "name": "UK-HBKU",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1342,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "HBKU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HBKU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/3/7.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-lis-pt-idrac |perfSONAR iDRAC",
+    "circuits": [
+      {
+        "id": 708306,
+        "name": "PS-LIS-PT-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 713,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-11/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CERN EXT-2 P_AE22 SRF20066 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1215,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-1/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 678,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 808,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 562,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.101",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT-IT GEANT-IT #AMS-OFFICE-TO-LON2-(FOR-EDUVPN)-L2CIRCUIT $GS-00652",
+    "circuits": [
+      {
+        "id": 705901,
+        "name": "AMS-OFFICE-TO-LON2-(FOR-EDUVPN)-L2CIRCUIT",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1548,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02192 |SCION server 1 external port",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1287,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-5/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | FRA-PAR-QFX | to QFX xe-0/0/17",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 819,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "2/x1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | BUC-SOF | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178498,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-SOF",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-SOF",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 646,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c18/2",
+      "1/x1/1/c24/1",
+      "1/x1/1/c24/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c18/2",
+      "1/x1/1/c24/1",
+      "1/x1/1/c24/2"
+    ],
+    "description": "LAG CUSTOMER ARNES | $GA-01866 | #ARNES-AP2-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.2102",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN RE_INTERCONNECT AARNET #AARNET-LON-LHCONE-AER $GS-00806 | ASN7575",
+    "circuits": [
+      {
+        "id": 709695,
+        "name": "AARNET-LON-LHCONE-AER",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 907,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "AARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 602,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "et-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE3 | LIS-POR | Infinera GRV1 1/1/3 Facing LISbon",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 553,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-POR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-POR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-23",
+    "bundle": [
+      "1/1/c2/3"
+    ],
+    "bundle-parents": [
+      "1/1/c2/3"
+    ],
+    "description": "LAG INFRASTRUCTURE DTN PROJECT | $GA-50069 | #DTN-LAG | DTN LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177303,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 603,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "1/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | AMS-BRU | to RT0.AMS port 1/1/C8/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916353,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-BRU",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-BRU",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 595,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-24",
+    "bundle": [
+      "1/x1/1/c4/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c4/2"
+    ],
+    "description": "LAG CUSTOMER MREN | $GA-01903 | #MREN-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177304,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MREN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MREN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae6",
+    "bundle": [
+      "et-0/1/5",
+      "et-1/1/5"
+    ],
+    "bundle-parents": [
+      "et-0/1/5",
+      "et-1/1/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02144 | BIL-MAD | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 837,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-MAD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-MAD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.1008",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT CSTNET #NL-NETHERLIGHT-CSTNET-KAUST-1 $GS-02392 | ASN7497 | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1739,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CSTNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CSTNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER PIONIER #PIONIER-AP1 $GS-00495 | ASN8501 |",
+    "circuits": [
+      {
+        "id": 661706,
+        "name": "PIONIER-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 791,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER URAN",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 569,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "1/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915971,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.402",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT RE_INTERCONNECT CANARIE UBUNTUNET #AMS-LON-MISC-UBUNTUNET-CANARIE-170352 $GS-00646 |",
+    "circuits": [
+      {
+        "id": 735618,
+        "name": "AMS-LON-MISC-UBUNTUNET-CANARIE-170352",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 819,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4073",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSECREDENDO-02654 $GS-02654",
+    "circuits": [
+      {
+        "id": 747544,
+        "name": "MSECREDENDO-02654",
+        "type": "EXPRESS ROUTE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE2 | Uplink to sw5.lon.uk.geant.net - xe-",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1473,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.2511",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA AUTOGOLE SAO-DUB | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 808,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1278,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:947",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET REDIRIS #HAM-MAD-02183 $GS-02183",
+    "circuits": [
+      {
+        "id": 747550,
+        "name": "HAM-MAD-02183",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 592,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-7/0/5",
+      "et-7/1/2",
+      "et-7/1/5"
+    ],
+    "bundle-parents": [
+      "et-7/0/5",
+      "et-7/1/2",
+      "et-7/1/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02526 | POZ-POZ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 854,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-POZ",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-POZ",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01691 | LON2-PRD-ESX03 ESXI Traffic LAG - No LACP",
+    "circuits": [
+      {
+        "id": 658679,
+        "name": "LON2-PRD-ESX03-ESXI-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 593,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE DTN-Project #DTN-PRA-10G-DATA $GA-02285 | Under testing ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 546,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "ae13",
+    "bundle": [
+      "et-0/0/0"
+    ],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "LAG CUSTOMER SANET SRF24007 $GA-02437 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 616,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SANET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SANET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.36",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEULB-02363 $GS-02363",
+    "circuits": [
+      {
+        "id": 744144,
+        "name": "MSEULB-02363",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1417,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/4.17",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #VIRGIN_MEDIA_EX1_LON2_TO_CAM_SRX_VLAN17-CH |",
+    "circuits": [
+      {
+        "id": 663138,
+        "name": "VIRGIN_MEDIA_EX1_LON2_TO_CAM_SRX_VLAN17-CH",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 549,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-9/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae7 | BUC-BUD",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1129,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE ORANGE P_AE31 SRF21047 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1273,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER AMS",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 530,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "AMS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "2/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178115,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/0.50",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX2-AMS-TO-FW-WAN |SRX-2 to FW WAN (VLAN 50)",
+    "circuits": [
+      {
+        "id": 663042,
+        "name": "SRX2-AMS-TO-FW-WAN",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 557,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-2/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC AMS-IX P_AE12 | INTERXION ID: NL102081 AMS-IX ID: mym6-mem-1540-6399",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 951,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.2002",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT INTERNET2 #INTERNET2-LON-LHCONE $GS-00830 | ASN11537",
+    "circuits": [
+      {
+        "id": 661750,
+        "name": "INTERNET2-LON-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 869,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | mx1-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1262,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae43.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 - DIRTY-IAS | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1361,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #psmp-par-fr-bwctl new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 727977,
+        "name": "PSMP-PAR-FR-BWCTL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1040,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01675 | FRA-PRD-ESX04 ESXI Traffic LAG",
+    "circuits": [
+      {
+        "id": 658522,
+        "name": "FRANKFURT 15-FRANKFURT 15-LAG-063(GEANT)",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 577,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae1.28",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/3/0",
+      "xe-1/3/1"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT EUMETSAT #POZ-EUMETSAT-SERVER-DATA-TRAFFIC $GS-02360 | POZ-EUMETSAT-1G",
+    "circuits": [
+      {
+        "id": 732103,
+        "name": "POZ-EUMETSAT-SERVER-DATA-TRAFFIC",
+        "type": "IP PEERING - R&E",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1077,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "EUMETSAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EUMETSAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 522,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae8",
+    "bundle": [
+      "et-2/1/5"
+    ],
+    "bundle-parents": [
+      "et-2/1/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01834 | AMS2-LON-AMT-LAG |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 704,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS2-LON-AMT-LAG",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS2-LON-AMT-LAG",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-1/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER NORDUNET P_ae33 | #NORDUNET-AP3-100GB",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 943,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 602,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-6",
+    "bundle": [
+      "2/1/c12/1"
+    ],
+    "bundle-parents": [
+      "2/1/c12/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01777 | ATH2-MIL2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177286,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-MIL2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-MIL2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 592,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-3/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT INTERNET2 P_ae19 | INTERNET2-400G to BOSTON",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 775,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY #SRX2-SRX1-CH-OFFICE|",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 514,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02193 |SCION server 2 internal port",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1280,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 572,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.510",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT INTERNET2 #NL-INTERNET2-VLAN510 $GS-00894 | ASN11537 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1736,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae25.333",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/2/6"
+    ],
+    "description": "SRV_IAS PRIVATE T-SYSTEMS #DE-TSYSTEMS-IAS $GS-00927 | ASN6878 |",
+    "circuits": [
+      {
+        "id": 732135,
+        "name": "DE-TSYSTEMS-IAS",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1142,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "T-SYSTEMS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "T-SYSTEMS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT NKN SRF20035 P_AE20 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1292,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "NKN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NKN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.3068",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE CANARIE #AMS-AMS-RARE-CANARIE-21013 $GS-00627 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1750,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "et-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE3 | LIS-POR | Infinera GRV1 1/1/4 Facing LISBON",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 554,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-POR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-POR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "1/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | KAU-POZ | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916353,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae32.303",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/5",
+      "et-8/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS IT REFRESH | T0 EXTERNAL PEERINGS",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1599,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1294,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae12",
+    "bundle": [
+      "et-8/1/2"
+    ],
+    "bundle-parents": [
+      "et-8/1/2"
+    ],
+    "description": "LAG CUSTOMER CARNET SRF9926179 $GA-01739 | CARNet AP2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 840,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CARNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CARNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae19",
+    "bundle": [
+      "xe-3/0/1"
+    ],
+    "bundle-parents": [
+      "xe-3/0/1"
+    ],
+    "description": "LAG CUSTOMER MICROSOFT EXPRESSROUTE #1 $GA-02522 | GEANT-EXRJ01-MAD31-PRI-07192024",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 657,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/0/2:0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 532,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-1/0/18",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE5 | 10_GBS to RT1.FRA.DE xe-0/3/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 637,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae29.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/1/5",
+      "xe-8/0/1"
+    ],
+    "description": "SRV_IAS UPSTREAM COGENT #COGENT-GWS-VIE $GS-00067 | ASN174",
+    "circuits": [
+      {
+        "id": 708322,
+        "name": "COGENT-GWS-VIE",
+        "type": "GWS - UPSTREAM",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1140,
+    "dashboards": [
+      "IAS_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COGENT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4084",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS Customer BELNET MICROSOFT #BELNET-KULEUVEN-EXPRESSROUTE-4084 $GS-01135  | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739669,
+        "name": "BELNET-KULEUVEN-EXPRESSROUTE-4084",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1669,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae12",
+    "bundle": [
+      "et-4/1/0"
+    ],
+    "bundle-parents": [
+      "et-4/1/0"
+    ],
+    "description": "LAG PUBLIC NIX SRF9934393 $GA-01828 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 918,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 598,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-3/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE2 SRF0000001 | mx2-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 702,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae10.1000",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-2/1/5",
+      "et-11/1/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER GARR #GARR-AP1 $GS-00462 | ASN137 |",
+    "circuits": [
+      {
+        "id": 661320,
+        "name": "GARR-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 793,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:3506",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDIRIS BELNET #SLCIMEC-02514 $GS-02514",
+    "circuits": [
+      {
+        "id": 745330,
+        "name": "SLCIMEC-02514",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "et-0/0/5",
+      "et-0/1/2",
+      "et-0/1/5"
+    ],
+    "bundle-parents": [
+      "et-0/0/5",
+      "et-0/1/2",
+      "et-0/1/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02543 | PRA-PRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1021,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-PRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-PRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "irb.519",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SERVER-MGMT-AMS-NL-VRF-VLAN519 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1587,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "ae13.420",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER SANET #SANET-AP2 $GS-02438 | ASN2607 |",
+    "circuits": [
+      {
+        "id": 733189,
+        "name": "SANET-AP2",
+        "type": "GEANT IP",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 617,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SURFnet VLAN 100 - for Link to GEANT IT VRF via mx1.ams - Surfnet Service ID: 5836",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 517,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4070",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-HoGENT-ExpressRoute-VLAN4070 $GS-02574 | ",
+    "circuits": [
+      {
+        "id": 741111,
+        "name": "BELNET-HOGENT-EXPRESSROUTE-VLAN4070",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1686,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-7",
+    "bundle": [
+      "1/1/c9/2",
+      "1/1/c12/2",
+      "2/1/c9/2"
+    ],
+    "bundle-parents": [
+      "1/1/c9/2",
+      "1/1/c12/2",
+      "2/1/c9/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02547 | MIL2-MIL2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177287,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-MIL2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-MIL2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/0/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS | QFX2 C0 MGMT",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 526,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 562,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.3901",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #par-par-GEANTOpen-SINET-SINET-19033 $GS-00987 |",
+    "circuits": [
+      {
+        "id": 706599,
+        "name": "PAR-PAR-GEANTOPEN-SINET-SINET-19033",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1451,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-21.333",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c2/2"
+    ],
+    "description": "SRV_IAS CUSTOMER CYNET #CYNET-AP2-IAS IASGWS $GS-00525 | ASN3268 | ",
+    "circuits": [
+      {
+        "id": 745495,
+        "name": "CYNET-AP2-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "7",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CYNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CYNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4068",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSERIZIV-02520 $GS-02520",
+    "circuits": [
+      {
+        "id": 744225,
+        "name": "MSERIZIV-02520",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1304,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.9",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #NE-ESXI-DRAC-PAR-FR | ne-esxi-prod-par-1-idrac",
+    "circuits": [
+      {
+        "id": 739102,
+        "name": "NE-ESXI-DRAC-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1214,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae20.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/1/2",
+      "et-11/0/2"
+    ],
+    "description": "SRV_IAS PUBLIC LINX #IX-Peerings-in-LINX $GS-00951 |",
+    "circuits": [
+      {
+        "id": 708212,
+        "name": "IX-PEERINGS-IN-LINX",
+        "type": "IP PEERING - NON R&E (PUBLIC)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1019,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PUBLIC"
+    ],
+    "dashboard_info": {
+      "name": "LINX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LINX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "1/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | FRA-GEN | to GEN01-GRV2 port 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900097,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.11",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #NE-ESXI-TNMS-PAR-FR | ne-esxi-prod-par-1 TNMS-VMs Portgroup",
+    "circuits": [
+      {
+        "id": 739099,
+        "name": "NE-ESXI-TNMS-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1216,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Connected to 1-B-2-2-1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 589,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/3.906",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT INTERNET2 #lon-lon-MISC-GEANT-INTERNET2-9940197 $GS-00726 |",
+    "circuits": [
+      {
+        "id": 661593,
+        "name": "LON-LON-MISC-GEANT-INTERNET2-9940197",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1025,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COGENT  P_AE32 | Interxion ID: DE111558 | Cogent ID: 3-001176133",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 881,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COGENT - FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT - FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC BOD SRF0000001 $GA-01532 | JISC BoD Edinburgh eMusic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 749,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.2282",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER HEANET INTERNET2 #HEANET-00630 $GS-00630 |",
+    "circuits": [
+      {
+        "id": 747351,
+        "name": "HEANET-00630",
+        "type": "GEANT PLUS",
+        "status": "planned"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1748,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 609,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-23",
+    "bundle": [
+      "1/x1/1/c2/3"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/3"
+    ],
+    "description": "LAG CUSTOMER MARNET | $GA-01862 | #MARNET-AP2-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177303,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MARNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MARNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1472,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-NOAA $GS-01086",
+    "circuits": [
+      {
+        "id": 732670,
+        "name": "GRE-MULTICAST-TUNNEL-NOAA",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1209,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | RARE EDGECORE WEDGE100BF-32X xe-1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 750,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae21.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2"
+    ],
+    "description": "SRV_IAS CUSTOMER IUCC #IUCC-AP1-IAS IASGWS $GS-00532 | ASN378 |",
+    "circuits": [
+      {
+        "id": 730581,
+        "name": "IUCC-AP1-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 711,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "IUCC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "IUCC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "irb.3001",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-CONTROL-NAGIOS-PAR-FR-LOGICAL-INTERFACE-PAR-FR $GS-00864 | NAGIOS gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 712156,
+        "name": "TAAS-CONTROL-NAGIOS-PAR-FR",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 665,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4",
+      "et-3/1/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #FRA-FRA-IPTRUNK $GS-02461| FRA-FRA | RT0.FRA-RT1.FRA",
+    "circuits": [
+      {
+        "id": 739046,
+        "name": "FRA-FRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1377,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-FRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-FRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "2/1/c30/1"
+    ],
+    "bundle-parents": [
+      "2/1/c30/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01996 | KIE-POZ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-POZ",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-POZ",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.3001",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NETHERLIGHT QNREN #lon-par-GEANTOpen-Netherlight-QNREN-15032 $GS-00972 |",
+    "circuits": [
+      {
+        "id": 736886,
+        "name": "LON-PAR-GEANTOPEN-NETHERLIGHT-QNREN-15032",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1164,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "QNREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.mar.fr.geant.net",
+    "name": "lag-5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MAR-MAR-IPTRUNK $GS-02590 | MAR-MAR | MAR-MAR",
+    "circuits": [
+      {
+        "id": 742606,
+        "name": "MAR-MAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "irb.999",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS INFINERA #infinera-bud-hu-mgmt-vrf-vlan999",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 660,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "LAG CUSTOMER LAT | $GA-02074 | LAT-AP2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LAT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-2/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER REDIRIS P_AE15",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1031,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-1/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 529,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "lag-5",
+    "bundle": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01830 | PRA-VIE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177285,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-VIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-VIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.2695",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA AUTOGOLE HEAnet-DC-RNP-build7 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 822,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "ae10.360",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/1",
+      "xe-0/1/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER URAN #URAN-AP2-LHCONE $GS-00871 | ASN12687",
+    "circuits": [
+      {
+        "id": 714003,
+        "name": "URAN-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 616,
+    "dashboards": [
+      "EAP",
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.1623",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 SCION #par-par-SCION-INTERNET2-SCION-2 $GS-02309 |",
+    "circuits": [
+      {
+        "id": 736659,
+        "name": "PAR-PAR-SCION-INTERNET2-SCION-2",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1143,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.301",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_IAS CUSTOMER ENSTINET #NL-ENSTINET-IAS IASPS $GS-00579 | ASN6879 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1732,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ENSTINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ENSTINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-8/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS IT REFRESH P_AE32 | qfx1.ams.nl et-0/0/52",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1271,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae20.2265",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-5/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #AMS-LON-SINET-SINET-22074 $GS-02207 |",
+    "circuits": [
+      {
+        "id": 721397,
+        "name": "AMS-LON-SINET-SINET-22074",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1287,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae18",
+    "bundle": [
+      "et-8/0/2"
+    ],
+    "bundle-parents": [
+      "et-8/0/2"
+    ],
+    "description": "LAG CUSTOMER RESTENA SRF9922289 $GA-01952 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1159,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "RESTENA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/3/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Was PSMP Server",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 564,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "1/x1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | LJU-MIL2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916417,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "2/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | MIL2-THE | to et-0/0/2 RT1.THE.GR",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162114,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-THE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-THE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 517,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-0/0/40",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN            | pS Throughtput Tester Interface",
+    "circuits": [
+      {
+        "id": 716018,
+        "name": "PS-THROUGHTPUT-TESTER-INTERFACE-10GBE-2",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 686,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.2707",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV-L2CIRCUIT CUSTOMER PIONIER REDIRIS #PSNC-RedIRIS-SLICES-UPV/EHU $GS-02493|",
+    "circuits": [
+      {
+        "id": 739389,
+        "name": "PSNC-REDIRIS-SLICES-UPV/EHU",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 631,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae11.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/4"
+    ],
+    "description": "SRV_L3VPN CUSTOMER DFN #DFN-AP1-LHCONE $GS-00816 | ASN680",
+    "circuits": [
+      {
+        "id": 743292,
+        "name": "DFN-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 782,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae22.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_IAS PUBLIC DE-CIX #IX-Peerings-in-DE-CIX-MAR $GS-00948 |",
+    "circuits": [
+      {
+        "id": 740868,
+        "name": "IX-PEERINGS-IN-DE-CIX-MAR",
+        "type": "IP PEERING - NON R&E (PUBLIC)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 737,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PUBLIC"
+    ],
+    "dashboard_info": {
+      "name": "DE-CIX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DE-CIX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae20.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-5/1/2"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT SINET #NL-SINET $GS-00901 | ASN2907 | IETR & IP",
+    "circuits": [
+      {
+        "id": 734867,
+        "name": "NL-SINET",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1283,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/2.1213",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER HEANET GEANT #dub-fra-HEANET-RARE-20062 $GS-00689 |",
+    "circuits": [
+      {
+        "id": 747360,
+        "name": "DUB-FRA-HEANET-RARE-20062",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1450,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-5/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | MAD-MAR | connected to MAR01-GRV1 1/1/11",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 846,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae1 | MAD-MAD | to RT0.MAD 1/x1/1/c2/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 777,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.411",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ESNET #lon-lon-GEANTOpen-Esnet-Esnet-170391 $GS-00962 |",
+    "circuits": [
+      {
+        "id": 738643,
+        "name": "LON-LON-GEANTOPEN-ESNET-ESNET-170391",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 803,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "xe-0/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 561,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 609,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02279 | BRU-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRU-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRU-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.33",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEKULEUVEN-01134 $GS-01134",
+    "circuits": [
+      {
+        "id": 744267,
+        "name": "MSEKULEUVEN-01134",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1414,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae23.3060",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/3"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET ORACLE #ofcfodmob-02630 $GS-02630",
+    "circuits": [
+      {
+        "id": 744345,
+        "name": "OFCFODMOB-02630",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1715,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE5 SRF0000001 | RT1.MIL2 to SW2.MIL2 Connected to SW2.MIL2 xe-0/2/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 596,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "2/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | LON2-PAR | TO GRV2.LON2 - 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161665,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-20:2702",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION EENET #SCION-02357 $GS-02357",
+    "circuits": [
+      {
+        "id": 746464,
+        "name": "SCION-02357",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "EENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-6",
+    "bundle": [
+      "1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02388 | COR-LON2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177286,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-LON2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-LON2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-24.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c4/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER MREN #MREN-AP1 $GS-00491 | ASN40981 | ",
+    "circuits": [
+      {
+        "id": 747907,
+        "name": "MREN-AP1",
+        "type": "GEANT IP",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "20",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.937",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDIRIS GEANT #BIL-GEN-REDIRIS-RARE $GS-02288 |",
+    "circuits": [
+      {
+        "id": 726620,
+        "name": "BIL-GEN-REDIRIS-RARE",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 851,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 599,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.991",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE Access PARIS #FRA-TNMS | Internal network",
+    "circuits": [
+      {
+        "id": 732624,
+        "name": "FRA-TNMS",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1413,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae14",
+    "bundle": [
+      "et-1/1/5",
+      "et-8/0/2",
+      "et-8/1/2",
+      "et-8/1/5"
+    ],
+    "bundle-parents": [
+      "et-1/1/5",
+      "et-8/0/2",
+      "et-8/1/2",
+      "et-8/1/5"
+    ],
+    "description": "LAG CUSTOMER RENATER SRF9923751 $GA-01877 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 704,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4067",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-RVA-ONEM-ExpressRoute-VLAN4067 $GS-02432  | ",
+    "circuits": [
+      {
+        "id": 739670,
+        "name": "BELNET-RVA-ONEM-EXPRESSROUTE-VLAN4067",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1661,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae18",
+    "bundle": [
+      "et-10/1/0"
+    ],
+    "bundle-parents": [
+      "et-10/1/0"
+    ],
+    "description": "LAG PRIVATE FACEBOOK SRF9935091 $GA-01840 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 714,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/14",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE13    | LON2-PRD-ESX03 NIC2 PORT2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 665,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1277,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CYNET P_ae14 SRF23077 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 655,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CYNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CYNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/0/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT GEANT #AMS-POZ-RARE-P4-9951379 $GS-00661 | RARE P4 TESTBED",
+    "circuits": [
+      {
+        "id": 736091,
+        "name": "AMS-POZ-RARE-P4-9951379",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 798,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 563,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "2/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | GEN-GEN | to MX1.GEN.CH et-7/1/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162817,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/6.1304",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SWITCH KREONET #ams-fra-SCION-KREONET-SWITCH $GS-02292  |",
+    "circuits": [
+      {
+        "id": 734614,
+        "name": "AMS-FRA-SCION-KREONET-SWITCH",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1334,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1466,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 577,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE | ORACLE P_AE24 SRF20010 | ASN31898",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1464,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.2050",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NEA3R ESNET #lon-lon-GEANTOpen-ESNET-NEA3R $GS-02250 |",
+    "circuits": [
+      {
+        "id": 738640,
+        "name": "LON-LON-GEANTOPEN-ESNET-NEA3R",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1147,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NEA3R",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NEA3R",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae7",
+    "bundle": [
+      "et-1/0/2",
+      "et-1/0/5",
+      "et-1/1/2"
+    ],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-1/0/5",
+      "et-1/1/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02546 | MIL2-MIL2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 749,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-MIL2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-MIL2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "et-10/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1154,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/2/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 555,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.14",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #NORDUNET-TUNI-ExpressRoute-VLAN3912 $GS-01162 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707047,
+        "name": "NORDUNET-TUNI-EXPRESSROUTE-VLAN3912",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1398,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "ae10.333",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/1",
+      "xe-0/1/2"
+    ],
+    "description": "SRV_IAS CUSTOMER URAN #URAN-AP1-IAS IASPS $GS-00593 | ASN12687 |",
+    "circuits": [
+      {
+        "id": 713995,
+        "name": "URAN-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 589,
+    "dashboards": [
+      "EAP",
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.415",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ORACLE REDIRIS SRF22010 #fra-mad-ORACLE-REDIRIS-22010-VL415 $GS-02096",
+    "circuits": [
+      {
+        "id": 719496,
+        "name": "FRA-MAD-ORACLE-REDIRIS-22010-VL415",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1079,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ORACLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-20:3003",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER LAT SURF #EVLBI-JIVE-00662 $GS-00662",
+    "circuits": [
+      {
+        "id": 745967,
+        "name": "EVLBI-JIVE-00662",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.2265",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #AMS-LON-SINET-SINET-22074 $GS-02207 |",
+    "circuits": [
+      {
+        "id": 721397,
+        "name": "AMS-LON-SINET-SINET-22074",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1264,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-6 | FRA-PRA | TO RT1.PRA.CZ-et-0/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1196,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/15",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 532,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae21.4002",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/1/0"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT T-SYSTEMS #DE-T-SYSTEMS-R&E $GS-02330 | ASN6878 |",
+    "circuits": [
+      {
+        "id": 728924,
+        "name": "DE-T-SYSTEMS-R&E",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 923,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "T-SYSTEMS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "T-SYSTEMS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "et-10/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1152,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "2/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | GEN-MAR | to RT1.MAR et-4/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162114,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "et-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | KIE-POZ | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 609,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.3902",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #NORDUNET-JYV-ExpressRoute-VLAN3902 $GS-01157 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707076,
+        "name": "NORDUNET-JYV-EXPRESSROUTE-VLAN3902",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1193,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1582,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 789,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "xe-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 560,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-1/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 526,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae1.21",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/3/0",
+      "xe-1/3/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #hades-poz-pl-DRAC | HADES DRAC",
+    "circuits": [
+      {
+        "id": 727554,
+        "name": "HADES-POZ-PL-DRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 841,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "xe-3/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P6",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 659,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE GTS SRF0000001 | GTS link to Server 0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 577,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae7",
+    "bundle": [
+      "et-1/0/2"
+    ],
+    "bundle-parents": [
+      "et-1/0/2"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS $GA-02302 | AMS-AMT |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 960,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.6",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER REDIRIS MICROSOFT #REDIRIS-USC-ExpressRoute-VLAN409 $GS-01167 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 708369,
+        "name": "REDIRIS-USC-EXPRESSROUTE-VLAN409",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1390,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4061",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSESTAD-02245 $GS-02245",
+    "circuits": [
+      {
+        "id": 744266,
+        "name": "MSESTAD-02245",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1466,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae4",
+    "bundle": [
+      "et-5/0/2",
+      "et-5/0/5"
+    ],
+    "bundle-parents": [
+      "et-5/0/2",
+      "et-5/0/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE LAG-LIS-MAD $GA-02002 | LIS-MAD | 200G",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 540,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-MAD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-MAD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c8/1",
+      "1/x1/1/c8/2",
+      "1/x1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LJU-MIL2-IPTRUNK $GS-00051 | LJU-MIL2 | ",
+    "circuits": [
+      {
+        "id": 746146,
+        "name": "LJU-MIL2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-MIL2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-MIL2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-5/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic present",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 600,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.45",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSECREDENDO-02655 $GS-02655 | ",
+    "circuits": [
+      {
+        "id": 747921,
+        "name": "MSECREDENDO-02655",
+        "type": "EXPRESS ROUTE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 694,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 575,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #PSMP-MANAGEMENT-LON2-UK | uat-psmp.lon2.uk.geant.net MGMT",
+    "circuits": [
+      {
+        "id": 708222,
+        "name": "PSMP-MANAGEMENT-LON2-UK",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 670,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 546,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/6.1306",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SWITCH KREONET #fra-lon-SCION-SWITCH-KREONET $GS-02294 |",
+    "circuits": [
+      {
+        "id": 727332,
+        "name": "FRA-LON-SCION-SWITCH-KREONET",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1335,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KREONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "xe-0/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 569,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.1726",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION KAUST #ams-gen-KAUST-SCION $GS-02418| ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1743,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "2/1/c11/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | POZ-POZ | to MX1.POZ.PL et-7/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162305,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE |  psmp-lhc-mgmt-fra.de.geant.org pS MGMT (LHCONE)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 550,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER URAN SRF-21-059 P_AE10 | URAN Circuit ID: GEANT-KIV-IEV-1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 565,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "1/1/c11/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | POZ-PRA | to RT0.POZ 2/1/c8/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900161,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.2009",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER LAT SURF #LOFAR-00663 $GS-00663",
+    "circuits": [
+      {
+        "id": 745942,
+        "name": "LOFAR-00663",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1123,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae22.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/2/1",
+      "xe-4/2/2"
+    ],
+    "description": "SRV_INFRASTRUCTURE ACCESS | NEMO DDOS Detection 2",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 913,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae22.2033",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-10/0/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER WACREN NORDUNET #lon-lon-GEANTOPEN-NORDUNET-WACREN-20041 $GS-00979 |",
+    "circuits": [
+      {
+        "id": 705942,
+        "name": "LON-LON-GEANTOPEN-NORDUNET-WACREN-20041",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 981,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "WACREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/3/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Was PSMP Server",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 565,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae22.2704",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-10/0/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION EENET #lon-par-SCION-WACREN $GS-02495 | ",
+    "circuits": [
+      {
+        "id": 737889,
+        "name": "LON-PAR-SCION-WACREN",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1486,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | VIE-VIE | to RT0.VIE 1/1/c9/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 906,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "VIE-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "VIE-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS PERFSONAR SRF0000001 | psmp-lhc-owd-lon-uk.geant.org pS OWAMP (LHCONE)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1452,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02341 | HAM-POZ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-POZ",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-POZ",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/0/2:3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 538,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.520",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #snm-idrac-mgmt | IT Refresh iDRAC MGMT",
+    "circuits": [
+      {
+        "id": 736096,
+        "name": "SNM-IDRAC-MGMT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1609,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER NETHERLIGHT | Digital Realty CID: NL172398-4",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 655,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-23.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER MARNET #MARNET-AP2 $GS-00490 | ASN44224 | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "17",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-2/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | LR4 QSFP INSTALLED",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 927,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/6.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-lhc-gen-ch-owamp LHC new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 723642,
+        "name": "PS-LHC-GEN-CH-OWAMP",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1318,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "1/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915972,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.931",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER DFN REDIRIS SRF21028 $GS-00692 | #fra-mad-DFN-REDIRIS-21028",
+    "circuits": [
+      {
+        "id": 719501,
+        "name": "FRA-MAD-DFN-REDIRIS-21028",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1087,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-11/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 860,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/5.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX2-City-House-Network-Infrastructure |",
+    "circuits": [
+      {
+        "id": 719500,
+        "name": "SRX2-CITY-HOUSE-NETWORK-INFRASTRUCTURE",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 538,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-2/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 952,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "2/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | GEN-PAR | connected to GEN01.GRV5 port 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161921,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS PERFSONAR SRF0000001 | psmp-gn-mgmt-lon-uk.geant.org  pS MGMT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 757,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.1390",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER SWITCH #GEN-PAR-SCION-RENATER-SWITCH-20026 $GS-00717 |",
+    "circuits": [
+      {
+        "id": 714179,
+        "name": "GEN-PAR-SCION-RENATER-SWITCH-20026",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 833,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "et-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | PRA-PRA | to RT0.PRA 1/1/C9/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 886,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 669,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "2/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | POZ-PRA | to RT1.PRA.CZ et-2/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162177,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae21.140",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CERN REDCLARA #GEN-LIS-CERN-REDCLARA-22059 $GS-02176 |",
+    "circuits": [
+      {
+        "id": 720101,
+        "name": "GEN-LIS-CERN-REDCLARA-22059",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 702,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 530,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.4040",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT CANARIE #CANARIE-PAR-LHCONE-2 $GS-00810 | ASN6509",
+    "circuits": [
+      {
+        "id": 736735,
+        "name": "CANARIE-PAR-LHCONE-2",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1171,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CANARIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "irb.3003",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-throughput-network-par-fr $GS-00354 | Perfsonar test VMs - throughput measurement VLAN",
+    "circuits": [
+      {
+        "id": 712151,
+        "name": "PS-THROUGHPUT-NETWORK-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1458,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.12",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #NORDUNET-HHU-ExpressRoute-VLAN3910 $GS-01156 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 706560,
+        "name": "NORDUNET-HHU-EXPRESSROUTE-VLAN3910",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1396,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.23",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER GEANT  #GARR_UDMilano_ExpressRoute_Vlan4086 $GS-01148 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707643,
+        "name": "GARR-UDMILANO_EXPRESSROUTE_VLAN4086",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1406,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY To Switch Cluster vme.0 - switch chassis 0 mgmt - primary |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 515,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 643,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 597,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-5",
+    "bundle": [
+      "2/1/c8/2"
+    ],
+    "bundle-parents": [
+      "2/1/c8/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02607 | MIL2-THE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177285,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-THE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-THE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.35",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-02328 $GS-02328",
+    "circuits": [
+      {
+        "id": 747549,
+        "name": "AMS-HAM-MSE-02328",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 674,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MICROSOFT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | LR optic connected",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1309,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "1/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915972,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-PAR-FR $GS-00124 | DCN MANAGEMENT ",
+    "circuits": [
+      {
+        "id": 733980,
+        "name": "DCN-MANAGEMENT-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 711,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 566,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER HEANET | $GA-01889 | HEANET-AP2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae17.402",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/6"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER UBUNTUNET CANARIE #AMS-LON-MISC-UBUNTUNET-CANARIE-170352 $GS-00646 |",
+    "circuits": [
+      {
+        "id": 735618,
+        "name": "AMS-LON-MISC-UBUNTUNET-CANARIE-170352",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1345,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-5/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 599,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "2/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | LON2-PAR | TO GRV2.LON2 - 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162241,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-20:716",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER GRNET #SLCUTH-02490 $GS-02490|",
+    "circuits": [
+      {
+        "id": 745409,
+        "name": "SLCUTH-02490",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "1/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915971,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1457,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-11/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRENA P_AE20 SRF21081 | TTI - Vienna-Tbilisi 10G WL086745",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 868,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRENA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRENA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE SETCOR P_lag-26",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915972,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "et-7/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER LITNET P_AE10 | Connected to GRV6 1/1/3 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1052,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LITNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LITNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/6.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #par-fra-SUPERPOP-QFX-2-GEANT $GS-00079 |",
+    "circuits": [
+      {
+        "id": 729480,
+        "name": "FRA-PAR-SUPERPOP-QFX-2-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1122,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/1/c11/1",
+      "1/1/c11/2",
+      "1/1/c12/1",
+      "1/1/c12/2"
+    ],
+    "bundle-parents": [
+      "1/1/c11/1",
+      "1/1/c11/2",
+      "1/1/c12/1",
+      "1/1/c12/2"
+    ],
+    "description": "LAG CUSTOMER JISC | $GA-01760 | #JISC-AP2-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 913,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COLT $GA-01600 |Interxion CID: DE129481| COLT CID: 441303553 | EAP ASNET-AM GWS",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 871,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COLT - FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COLT - FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae48",
+    "bundle": [
+      "et-10/0/5",
+      "et-10/1/2"
+    ],
+    "bundle-parents": [
+      "et-10/0/5",
+      "et-10/1/2"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS A10-DDOS| TBC |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1613,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.2665",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA AUTOGOLE DUB-SAO.T8 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 818,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "et-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | BUC-SOF | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 666,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-SOF",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-SOF",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "et-3/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 753,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/2/7.908",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 GEANT #AMS-PAR-MISC-GEANT-INTERNET2-9940543 $GS-00654 |",
+    "circuits": [
+      {
+        "id": 705419,
+        "name": "AMS-PAR-MISC-GEANT-INTERNET2-9940543",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 929,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02188 |SCION server 1 external port",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1300,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LON-LON-IPTRUNK $GS-02467 | LON-LON | RT0.LON-MX1.LON",
+    "circuits": [
+      {
+        "id": 738586,
+        "name": "LON-LON-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-20:354",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT SINET DFN #AMS-HAM-JAXA-SINET-DFN-00640 $GS-00640",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-8",
+    "bundle": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01762 | LON2-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177288,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "irb.3004",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-CONTROL-FRANKFURT-VRF-VLAN3004-LOGICAL-INTERFACE $GS-00862 | RANCID gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 733012,
+        "name": "TAAS-CONTROL-FRANKFURT-VRF-VLAN3004",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1235,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 564,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE |DDOS SERVER 1 10Gb_2 | P_ae13",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1045,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ge-0/0/38",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX03 IDRAC",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 555,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915972,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae14.3151",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5",
+      "et-8/0/2",
+      "et-8/1/2",
+      "et-8/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER SINET #ams-gen-Grid5000-Renater-SINET-07201 $GS-00636 |",
+    "circuits": [
+      {
+        "id": 705429,
+        "name": "AMS-GEN-GRID5000-RENATER-SINET-07201",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 826,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae1 | MAR-MIL2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 674,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Was DE-CIX",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 654,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.2779",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NETHERLIGHT WIX #lon-lon-GEANTOpen-Netherlight-WIX $GS-00973 |",
+    "circuits": [
+      {
+        "id": 707103,
+        "name": "LON-LON-GEANTOPEN-NETHERLIGHT-WIX",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1591,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "WIX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.2511",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT SINET #SINET-PAR-LHCONE $GS-00859 | ASN2907",
+    "circuits": [
+      {
+        "id": 660633,
+        "name": "SINET-PAR-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 634,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 811,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "xe-11/0/0"
+    ],
+    "bundle-parents": [
+      "xe-11/0/0"
+    ],
+    "description": "LAG CUSTOMER MICROSOFT SRF19104 EXPRESSROUTE #1 $GA-01958 | GEANT-FRA32-09XGMR-CIS-1-PRI-11012019",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1201,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae22.1200",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-10/0/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NEA3R WACREN #lon-lon-GEANTOPEN-NEA3R-WACREN-190131 $GS-00982 |",
+    "circuits": [
+      {
+        "id": 709339,
+        "name": "LON-LON-GEANTOPEN-NEA3R-WACREN-190131",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1441,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NEA3R",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NEA3R",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae27.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5",
+      "et-8/3/0"
+    ],
+    "description": "SRV_IAS PRIVATE AKAMAI #AKAMAI-20940-AT $GS-00926 | ASN20940",
+    "circuits": [
+      {
+        "id": 708328,
+        "name": "AKAMAI-20940-AT",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 975,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "AKAMAI",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AKAMAI",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 588,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "2/x1/1/c8/1",
+      "2/x1/1/c8/2"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c8/1",
+      "2/x1/1/c8/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02373 | LJU-ZAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-ZAG",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-ZAG",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae10.1946",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_GCS CUSTOMER FCCN MICROSOFT #FCCN-IPP-ExpressRoute-Vlan1946 $GS-01143 | MANUALLY MIGRATED FROM MX1.LIS 25/08/21",
+    "circuits": [
+      {
+        "id": 706996,
+        "name": "FCCN-IPP-EXPRESSROUTE-VLAN1946",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 615,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02463 | GEN-GEN",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-GEN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-GEN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "2/x1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02008 | DUB-LON",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "DUB-LON",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "DUB-LON",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/15.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX1-AMS-TO-SURFNET-PRIMARY | Surfnet Primary - Service ID: 3287IP1",
+    "circuits": [
+      {
+        "id": 708298,
+        "name": "SRX1-AMS-TO-SURFNET-PRIMARY",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 537,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT SINGAREN P_AE12 SRF19005 | CAE1 100Gb LL TTI Circuit ID:WL065785 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1559,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae15",
+    "bundle": [
+      "et-0/0/2"
+    ],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "LAG RE_INTERCONNECT ITER $GA-02416 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 725,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ITER",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ITER",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae20.3153",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-5/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT SINET DFN #AMS-HAM-JAXA-SINET-DFN-00640 $GS-00640",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1292,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE WP7T2SF SRF0000001 | PAR BMS Server #4",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1194,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/5.333",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_IAS CUSTOMER SINGAREN #SINGAREN-IAS IASGWS $GS-02359 | ASN136968",
+    "circuits": [
+      {
+        "id": 729063,
+        "name": "SINGAREN-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 558,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae10.930",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-5/0/2",
+      "et-9/0/5",
+      "et-11/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC REDIRIS #LON-MAD-GOTO-REDIRIS-JISC-16018 $GS-00734 |",
+    "circuits": [
+      {
+        "id": 719523,
+        "name": "LON-MAD-GOTO-REDIRIS-JISC-16018",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1095,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c4/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER MREN P_lag-24",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916098,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MREN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MREN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-0/0/29",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae0     | RT1 xe-5/0/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 683,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4092",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet-NCCN-ExpressRoute-Vlan4092 $GS-01126 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739680,
+        "name": "BELNET-NCCN-EXPRESSROUTE-VLAN4092",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1676,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-20:2301",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER LAT SURF #LOFAR-02584 $GS-02584",
+    "circuits": [
+      {
+        "id": 745938,
+        "name": "LOFAR-02584",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.251",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER REDIRIS #REDIRIS-AP1 $GS-00498 | ASN766 |",
+    "circuits": [
+      {
+        "id": 719144,
+        "name": "REDIRIS-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 859,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02460 | FRA-FRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-FRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-FRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 602,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "ae7.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5",
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUC-BUD-IPTRUNK $GS-00021 | BUC-BUD | ",
+    "circuits": [
+      {
+        "id": 730444,
+        "name": "BUC-BUD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 675,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c9/2",
+      "1/1/c12/2",
+      "2/1/c9/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #PRA-PRA-IPTRUNK $GS-02545 | PRA-PRA | PRA-PRA-MGMT",
+    "circuits": [
+      {
+        "id": 739239,
+        "name": "PRA-PRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-PRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-PRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | NEMO DDOS SERVER link 1 Node 2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1282,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/5.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #PSMP-LHC-OWD-LON-UK-VLAN0 | psmp-lhc-owd-lon-uk.geant.org pS OWAMP (LHCONE)",
+    "circuits": [
+      {
+        "id": 708281,
+        "name": "PSMP-LHC-OWD-LON-UK-VLAN0",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1004,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae22",
+    "bundle": [
+      "xe-10/0/0"
+    ],
+    "bundle-parents": [
+      "xe-10/0/0"
+    ],
+    "description": "LAG RE_INTERCONNECT WACREN SRF18082 $GA-01838 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 718,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "WACREN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-5/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER REDIRIS P_AE16 SRF240691 | PP:0101:14103252, labeled as M21-43I-10 2 (direct)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 929,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.2128",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET INTERNET2 #lon-lon-GEANTOpen-NORDUNET-INTERNET2-17022 $GS-00974 |",
+    "circuits": [
+      {
+        "id": 661730,
+        "name": "LON-LON-GEANTOPEN-NORDUNET-INTERNET2-17022",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1590,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-3/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER MICROSOFT  EXPRESSROUTE #1 P_AE19 | Equinix CID: 22903011 | GEANT-EXRJ01-MAD31-PRI-07192024 --P15 in ODF3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 768,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/11",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 526,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Reserved for GTS Expansion",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 604,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS CORSA SRF0000001 | JRA MX to CORSA P5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1577,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-2/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC VIX P_AE10 | DR ID: AT188495 | VIX ID: 1298-1712938",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 935,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "et-0/0/2"
+    ],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "LAG CUSTOMER FCCN SRF9928603 $GA-02072 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 598,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "xe-3/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 532,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE |DDOS SERVER 1 10Gb_1 | P_ae13",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1044,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-20.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4",
+      "1/x1/1/c4/1",
+      "1/x1/1/c4/2",
+      "1/x1/1/c4/3",
+      "1/x1/1/c4/4"
+    ],
+    "description": "SRV_IAS CUSTOMER GRNET #GRNET-AP2-IAS IASGWS $GS-00531 | ASN5408 | ",
+    "circuits": [
+      {
+        "id": 745275,
+        "name": "GRNET-AP2-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "7",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 848,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO NORDUnet #NORDUnet-GEO-UK-1 |  SRF9928249 | NORDUNET 100G access to GeO",
+    "circuits": [
+      {
+        "id": 719819,
+        "name": "NORDUNET-GEO-UK-1",
+        "type": "GEANT OPEN PORT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1174,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3200",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT TEIN #TEIN-LON-LHCONE $GS-00867 | ASN24490",
+    "circuits": [
+      {
+        "id": 661919,
+        "name": "TEIN-LON-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 569,
+    "dashboards": [
+      "CAE1",
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "TEIN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TEIN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-10/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 912,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/2/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | MAR-MAR | to RT0.MAR 1/x1/1/c2/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 671,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c12/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #ATH2-MIL2-IPTRUNK $GS-00014 | ATH2-MIL2 | ",
+    "circuits": [
+      {
+        "id": 745507,
+        "name": "ATH2-MIL2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 7,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-MIL2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-MIL2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c4/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916100,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1041,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3220",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER SINGAREN #lon-poz-GEANTOpen-SINGAREN-CAE1-19113-VL3220-PIONIER $GS-00986 |",
+    "circuits": [
+      {
+        "id": 707007,
+        "name": "LON-POZ-GEANTOPEN-SINGAREN-CAE1-19113-VL3220-PIONIER",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 624,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-26",
+    "bundle": [
+      "1/x1/1/c2/4"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/4"
+    ],
+    "description": "LAG PRIVATE SETCOR | $GA-02000 | #SETCOR-PRIVATE-LAG | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177306,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 637,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-2/1/7",
+      "xe-2/2/7"
+    ],
+    "bundle-parents": [
+      "xe-2/1/7",
+      "xe-2/2/7"
+    ],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN | gen ch POP LAN",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1465,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE FW1-SNM",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1593,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-101.103",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-KAU-LT-VRF-VLAN103 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "9",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/0/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 525,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/7.104",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF SRF21105 $GS-00706 | #FRA-PRA-RARE-BMS8",
+    "circuits": [
+      {
+        "id": 737235,
+        "name": "FRA-PRA-RARE-BMS8",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 971,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE WP6T3 SRF20063 $GA-01326 | Formally JRA4T2 Server",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1569,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-9/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | MAD-MAR | connected to MAD01-GRV2 1/1/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1139,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/46",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE31    | MX1.LON2.UK xe-1/2/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 686,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02191 |SCION server 1 internal port",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1279,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-11/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-mgmt-vie.at.geant.org  pS MGMT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 861,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae19.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER UOM #UOM-AP2-100G $GS-02164 | ASN12046 | ",
+    "circuits": [
+      {
+        "id": 720396,
+        "name": "UOM-AP2-100G",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 626,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "UOM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UOM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.978",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER REDIRIS #PSNC-RedIRIS-SLICES-UC3M $GS-02492|",
+    "circuits": [
+      {
+        "id": 738289,
+        "name": "PSNC-REDIRIS-SLICES-UC3M",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 792,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 868,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae28.240",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET TENET #lon-lon-GEANTOPEN-NORDUNET-TENET-18075 $GS-00978 |",
+    "circuits": [
+      {
+        "id": 718107,
+        "name": "LON-LON-GEANTOPEN-NORDUNET-TENET-18075",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 681,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c8/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #COR-LON2-IPTRUNK $GS-02386 | COR-LON2 | ",
+    "circuits": [
+      {
+        "id": 738860,
+        "name": "COR-LON2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-LON2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-LON2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1459,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-lhc-gen-ch-bwctl LHC new | BWCTL CONTACT: ivan.garnizov@fau.de;",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1296,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "gr-4/0/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT IRANET #NL-IRANET $GS-01168 | ASN6736 |",
+    "circuits": [
+      {
+        "id": 735729,
+        "name": "NL-IRANET",
+        "type": "IP PEERING - R&E",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1473,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "IRANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "IRANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-5/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | MAD-MAR | connected to MAD01-GRV2 1/1/11",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 927,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "xe-3/2/2",
+      "xe-3/2/3"
+    ],
+    "bundle-parents": [
+      "xe-3/2/2",
+      "xe-3/2/3"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 $GA-01788 |mx2-sw1(ex3400",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 538,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c11/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LIS-PAR-IPTRUNK $GS-02633 | LIS-PAR | ",
+    "circuits": [
+      {
+        "id": 745054,
+        "name": "LIS-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 8,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | mx1-sw1-poz1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 570,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/0/1:1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 529,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae17",
+    "bundle": [
+      "xe-1/2/6"
+    ],
+    "bundle-parents": [
+      "xe-1/2/6"
+    ],
+    "description": "LAG RE_INTERCONNECT ASREN SRF9929569 $GA-01758 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 634,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ASREN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASREN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "et-7/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | POZ-POZ | to RT0.POZ.PL 2/1/c9/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1054,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.691",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_GCS CUSTOMER REDIRIS MICROSOFT #REDIRIS-ICN2-ExpressRoute-VLAN691 $GS-02559 | ",
+    "circuits": [
+      {
+        "id": 740766,
+        "name": "REDIRIS-ICN2-EXPRESSROUTE-VLAN691",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 938,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.2602",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA AUTOGOLE DUB-SAO | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 812,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-10/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS | A10 DDOS 100G #1 connected to X49",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 651,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae27.101",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-10/2/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER MAEEN INTERNET2 #LON-PAR-GEANTOpen-MAEEN-INTERNET2-21086 $GS-00728 |",
+    "circuits": [
+      {
+        "id": 736648,
+        "name": "LON-PAR-GEANTOPEN-MAEEN-INTERNET2-21086",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 968,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MAEEN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MAEEN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-0/0/19",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae0      | MX xe-4/0/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 536,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/5.3179",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINGAREN SINGAREN #lon-lon2-GEANT2-SingAREN-SingAREN-17085 $GS-00724 |",
+    "circuits": [
+      {
+        "id": 726769,
+        "name": "LON-LON2-GEANT2-SINGAREN-SINGAREN-17085",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 761,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-1/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 602,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.6",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER RedIRIS Microsoft #RedIRIS-USC-ExpressRoute-Vlan408 $GS-01165 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707129,
+        "name": "REDIRIS-USC-EXPRESSROUTE-VLAN408",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 589,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SURF AARNET #lon-lon-SURF-AARNET-19097 $GS-00721 |",
+    "circuits": [
+      {
+        "id": 705937,
+        "name": "LON-LON-SURF-AARNET-19097",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 933,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-4/1/7"
+    ],
+    "bundle-parents": [
+      "xe-4/1/7"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | mx1-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 631,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "gr-1/3/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN INFRASTRUCTURE ACCESS #FORTIGATE-TUNNEL-TO-CH-LON-UK $GS-02125 | Tunnel to Fortigate CH",
+    "circuits": [
+      {
+        "id": 717895,
+        "name": "FORTIGATE-TUNNEL-TO-CH-LON-UK",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1194,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "lag-5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #FRA-GEN-IPTRUNK $GS-00034 | FRA-GEN | ",
+    "circuits": [
+      {
+        "id": 739737,
+        "name": "FRA-GEN-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "irb.370",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN CUSTOMER SCION SRF22092 #SCION-SCION-GEN-INTERNAL-VPN-VL370 $GS-02214 |",
+    "circuits": [
+      {
+        "id": 723797,
+        "name": "SCION-SCION-GEN-INTERNAL-VPN-VL370",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1326,
+    "dashboards": [
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #GEN-MIL2-IPTRUNK $GS-00039 | GEN-MIL2 | ",
+    "circuits": [
+      {
+        "id": 740949,
+        "name": "GEN-MIL2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MIL2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MIL2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "2/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | MIL2-VIE | to RT0.VIE 1/1/c5/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161921,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COLT P_ae21 | COLT ID: 444032087 # DX9403282 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 918,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COLT - BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COLT - BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/5.46",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER ASREN ASREN #lon-lon2-GEANTOpen-ASREN-ASREN-190491 $GS-00984 |",
+    "circuits": [
+      {
+        "id": 707023,
+        "name": "LON-LON2-GEANTOPEN-ASREN-ASREN-190491",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 749,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ASREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae1.20",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/1/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-vie-at-idrac |perfSONAR iDRAC",
+    "circuits": [
+      {
+        "id": 742674,
+        "name": "PS-VIE-AT-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 735,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.2500",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA AUTOGOLE DUB-SAO2 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 814,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-uat-owd-fra.de.geant.org  pS OWAMP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1298,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | SPLUNK AMS PEER02 link 2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 633,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER KIAE P_AE16 | Digital Realty CID: NL158484 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 634,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KIAE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIAE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "2/1/c11/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | LJU-MIL2 | to RT1.LJU.SI et-1/0/2 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162305,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae13",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01685 | QFX.PAR.FR AE13",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 582,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01969 | BIL-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4082",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet-ZWEV-ExpressRoute-VLAN4082 $GS-01129 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739676,
+        "name": "BELNET-ZWEV-EXPRESSROUTE-VLAN4082",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1667,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-1/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 657,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-9/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | PAR-PAR | TO RT0.PAR  1/1/C19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 760,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PAR-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PAR-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae12.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/0"
+    ],
+    "description": "SRV_IAS PUBLIC NIX #IX-Peerings-in-NIX $GS-00953 |",
+    "circuits": [
+      {
+        "id": 708283,
+        "name": "IX-PEERINGS-IN-NIX",
+        "type": "IP PEERING - NON R&E (PUBLIC)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 921,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PUBLIC"
+    ],
+    "dashboard_info": {
+      "name": "NIX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NIX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "2/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | HAM-POZ | to MX1.POZ et-7/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162113,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae30.3015",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/0/5",
+      "xe-4/1/2",
+      "xe-4/2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #INFOBLOX-VPAR-PAR-FR $GS-00205 | Infoblox vPAR MGMT",
+    "circuits": [
+      {
+        "id": 734051,
+        "name": "INFOBLOX-VPAR-PAR-FR-MGMT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 916,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LON-LON2-IPTRUNK $GS-00052 | LON-LON2 | ",
+    "circuits": [
+      {
+        "id": 738842,
+        "name": "LON-LON2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "xe-3/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 657,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | LON2-LON2 | to xe-2/1/3 MX1.LON2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899586,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c4/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916098,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-AMS-NL $GS-00115| ",
+    "circuits": [
+      {
+        "id": 736086,
+        "name": "DCN-MANAGEMENT-AMS-NL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1020,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1279,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE2 | Uplink to sw5.lon.uk.geant.net - xe-",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1475,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COLT | P_AE29 Interxion CID: DE201067 | COLT ID: 444032093",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 853,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COLT - FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COLT - FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:2105",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET REDIRIS #BIL-HAM-02517 $GS-02517",
+    "circuits": [
+      {
+        "id": 747545,
+        "name": "BIL-HAM-02517",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4091",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEZWEV-01139 $GS-01139",
+    "circuits": [
+      {
+        "id": 744147,
+        "name": "MSEZWEV-01139",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "2/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | PRA-VIE | to RT0.PRA 2/1/c8/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162114,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "et-0/0/2"
+    ],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02146 | BRA-BRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 598,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae11",
+    "bundle": [
+      "xe-0/3/2"
+    ],
+    "bundle-parents": [
+      "xe-0/3/2"
+    ],
+    "description": "LAG PRIVATE GOOGLE $GA-01921 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1327,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.40",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEFEDPOL-02524 $GS-02524",
+    "circuits": [
+      {
+        "id": 744256,
+        "name": "MSEFEDPOL-02524",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1678,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae7.20",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #FRA-FRA-AMT-RELAYLINK-IAS $GS-02637 | ",
+    "circuits": [
+      {
+        "id": 747180,
+        "name": "FRA-FRA-AMT-RELAYLINK-IAS",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1714,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.2",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER FCCN MICROSOFT #FCCN-NOVESBE-ExpressRoute-VLAN1944 $GS-01144 | MANUALLY MIGRATED FROM MX1.LIS TO RT1.POR 25/08/21",
+    "circuits": [
+      {
+        "id": 706526,
+        "name": "FCCN-NOVESBE-EXPRESSROUTE-VLAN1944",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1386,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.1501",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET NORDUNET #HAM-LON-00719 $GS-00719",
+    "circuits": [
+      {
+        "id": 747551,
+        "name": "HAM-LON-00719",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 955,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE16 | QFX.LON2.UK xe-0/0/46",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1020,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1345,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.21",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-lon-uk-psmp-bwctl-vlan21 |psmp-gn-drac-lon-uk.geant.org pS iDRAC",
+    "circuits": [
+      {
+        "id": 740708,
+        "name": "PS-LON-UK-PSMP-BWCTL-VLAN21",
+        "type": "SERVER LINK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 756,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP P_AE30 | QFX xe-0/0/19",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1264,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE6     | LON2-PRD-ESX10 NIC1 PORT1",
+    "circuits": [
+      {
+        "id": 658620,
+        "name": "LON2-PRD-ESX10-NIC1-PORT1",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 520,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/2",
+      "1/x1/1/c2/3"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-ATH-GR-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "11",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-21.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c18/1"
+    ],
+    "description": "SRV_IAS CUSTOMER AMRES #AMRES-AP1-IAS IASPS $GS-00522 | ASN13092 | ",
+    "circuits": [
+      {
+        "id": 747849,
+        "name": "AMRES-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "13",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "AMRES",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMRES",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "et-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE1 | CHI-CHI | CHI-CHI-IP1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 619,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-CHI",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-CHI",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | SPLUNK LON2 PEER02 link Slot4 P1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1584,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.551",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER RESTENA #fra-par-SLICES-RESTENA-RENATER-VL551 $GS-02485 | ",
+    "circuits": [
+      {
+        "id": 737780,
+        "name": "FRA-PAR-SLICES-RESTENA-RENATER-VL551",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1205,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RESTENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | 10G-SR",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1026,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-2/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | BUC-CHI | ROEDUNET CID: BUC-CHI-040-3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 555,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "lag-5",
+    "bundle": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01858 | PRA-VIE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177285,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-VIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-VIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/15",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 531,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.1009",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT CSTNET #NL-NETHERLIGHT-CSTNET-KAUST-2 $GS-02393 | ASN7497 | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1740,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CSTNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CSTNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-3/0/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-lis-pt-management |perfSONAR MGMT",
+    "circuits": [
+      {
+        "id": 722334,
+        "name": "PS-LIS-PT-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 797,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-0/0/44",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | was | 10_GBS to MX1.FRA.DE xe-9/3/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 540,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae40",
+    "bundle": [
+      "xe-11/3/0"
+    ],
+    "bundle-parents": [
+      "xe-11/3/0"
+    ],
+    "description": "LAG PRIVATE ORACLE SRF21099 #2 $GA-02011 | FastConnect NREN Access",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1058,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "1/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20 | GRNET-AP1-IP6",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915969,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.3610",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT KAUST #NL-KAUST $GS-00895 | ASN50999 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1755,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "KAUST",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAUST",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/4.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-lhc-gen-ch-management |perfSONAR MGMT",
+    "circuits": [
+      {
+        "id": 723646,
+        "name": "PS-LHC-GEN-CH-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1317,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.3152",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER DFN SINET #fra-par-JAXA-DFN-SINET-14005 $GS-00703 |",
+    "circuits": [
+      {
+        "id": 706059,
+        "name": "FRA-PAR-JAXA-DFN-SINET-14005",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 895,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE WP6T3 SRF20064 $GA-01318 | Formally JRA4T2 Server",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1570,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae17.500",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/6"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ASREN #UK-ASREN $GS-00911 | ASN199354 |",
+    "circuits": [
+      {
+        "id": 661959,
+        "name": "UK-ASREN",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 608,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ASREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.3100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SURF AARNET #lon-lon-SURF-AARNET-19097 $GS-00721 |",
+    "circuits": [
+      {
+        "id": 705937,
+        "name": "LON-LON-SURF-AARNET-19097",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 590,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae10.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/2"
+    ],
+    "description": "SRV_IAS CUSTOMER FCCN #FCCN-AP1-IAS IASGWS $GS-00527 | ASN1930",
+    "circuits": [
+      {
+        "id": 661641,
+        "name": "FCCN-AP1-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 614,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER RENATER #RENATER-AP1-IPv4-LHCONE $GS-00853 | ASN2200",
+    "circuits": [
+      {
+        "id": 660442,
+        "name": "RENATER-AP1-IPV4-LHCONE",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 585,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae31",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01710 | MX1.LON2.UK AE16",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 609,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "1/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | RIG-TAR | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916353,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "RIG-TAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RIG-TAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #RIG-TAR-IPTRUNK $GS-02345 | RIG-TAR | ",
+    "circuits": [
+      {
+        "id": 746458,
+        "name": "RIG-TAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "RIG-TAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RIG-TAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae15.790",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET ITER #MAR-MAR-02645 $GS-02645 |",
+    "circuits": [
+      {
+        "id": 746076,
+        "name": "MAR-MAR-02645",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 865,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ITER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "xe-0/1/0",
+      "xe-0/1/1"
+    ],
+    "bundle-parents": [
+      "xe-0/1/0",
+      "xe-0/1/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02600 | BRA-BRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 532,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "et-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER SANET P_AE13 SRF9938825",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 628,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SANET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SANET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.2260",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINGAREN #AMS-LON-GEANTOPEN-SINET-SINGAREN-CAE1-19103-VL2260 $GS-00957 |",
+    "circuits": [
+      {
+        "id": 706922,
+        "name": "AMS-LON-GEANTOPEN-SINET-SINGAREN-CAE1-19103-VL2260",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 572,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae18",
+    "bundle": [
+      "xe-7/0/6"
+    ],
+    "bundle-parents": [
+      "xe-7/0/6"
+    ],
+    "description": "LAG RE_INTERCONNECT ARN SRF20032 $GA-02206 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 656,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ARN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae1.26",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/4",
+      "xe-3/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | PRA BMS SERVER 8 IDRAC",
+    "circuits": [
+      {
+        "id": 725643,
+        "name": "RARE-BMS-SERVER-2-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 955,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1588,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-22",
+    "bundle": [
+      "1/x1/1/c4/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c4/1"
+    ],
+    "description": "LAG CUSTOMER JISC | $GA-01550",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1342177302,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/2",
+      "et-8/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LIS-MAD-IPTRUNK $GS-00048 | LIS-MAD 200G |;",
+    "circuits": [
+      {
+        "id": 712769,
+        "name": "LIS-MAD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1160,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-MAD 200G",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-MAD 200G",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "2/x1/1/c8/2"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c8/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02387 | COR-LON2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-LON2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-LON2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:3915",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01161 $GS-01161",
+    "circuits": [
+      {
+        "id": 747633,
+        "name": "AMS-HAM-MSE-01161",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MICROSOFT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.2103",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT AARNET #UK-AARNET-AER $GS-00905 | ASN7575 | AER via NETHERLIGHT",
+    "circuits": [
+      {
+        "id": 709697,
+        "name": "UK-AARNET-AER",
+        "type": "IP PEERING - R&E",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 909,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "AARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-1/0/5",
+      "et-1/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #VIE-VIE-IPTRUNK $GS-02563| VIE-VIE | VIE-VIE-MGMT",
+    "circuits": [
+      {
+        "id": 740752,
+        "name": "VIE-VIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 760,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "VIE-VIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "VIE-VIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "ae5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUC-CHI-IPTRUNK $GS-00022| BUC-CHI | BUC-CHI-IPTRUNK",
+    "circuits": [
+      {
+        "id": 745144,
+        "name": "BUC-CHI-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 610,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4089",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEPREMIER-01137 $GS-01137",
+    "circuits": [
+      {
+        "id": 744264,
+        "name": "MSEPREMIER-01137",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-9/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | MAD-MAR | connected to MAD01-GRV2 1/1/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1144,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae15.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/1/0"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT MARWAN #UK-MARWAN $GS-02406 | ASN30983 |",
+    "circuits": [
+      {
+        "id": 733897,
+        "name": "UK-MARWAN",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 802,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "MARWAN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MARWAN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.1728",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION KAUST #ams-fra-KAUST-SCION $GS-02417| ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1744,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-9 | AMS-HAM | to RT0.AMS 2/1/c9/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900033,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-HAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-HAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE ORANGE P_AE32 SRF21047 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1260,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c18/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER AMRES P_lag-21",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916993,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "AMRES",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMRES",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #ZAG-ZAG-IPTRUNK $GS-50045 | ZAG-ZAG | ZAG-ZAG",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ZAG-ZAG",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ZAG-ZAG",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-2/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 645,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 566,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.4",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSESCIENSAN-02535 $GS-02535",
+    "circuits": [
+      {
+        "id": 744226,
+        "name": "MSESCIENSAN-02535",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1388,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bra.sk.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BRA-BRA-MGMT-IPTRUNK $GS-02602 | BRA-BRA | BRA-BRA-MGMT",
+    "circuits": [
+      {
+        "id": 743065,
+        "name": "BRA-BRA-MGMT-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-7/0/0",
+      "xe-7/0/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MAD-MAD-IPTRUNK $GS-02593| MAD-MAD | MAD-MAD",
+    "circuits": [
+      {
+        "id": 742615,
+        "name": "MAD-MAD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 982,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 588,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.3101",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SURF AARNET #lon-lon-SURF-AARNET-23009 $GS-02249 |",
+    "circuits": [
+      {
+        "id": 726158,
+        "name": "LON-LON-SURF-AARNET-23009",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1142,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.1125",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET INTERNET2 #IMINDS-00681 $GS-00681",
+    "circuits": [
+      {
+        "id": 744066,
+        "name": "IMINDS-00681",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 889,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX1-SRX2-AMS-OFFICE |",
+    "circuits": [
+      {
+        "id": 708185,
+        "name": "SRX1-SRX2-AMS-OFFICE",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 510,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.132",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ocvm-lon-uk-esxi | OC VM ESXi",
+    "circuits": [
+      {
+        "id": 740680,
+        "name": "OCVM-LON-UK-ESXI",
+        "type": "SERVER LINK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 717,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.2281",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER HEANET NETHERLIGHT #LOFAR-00632 $GS-00632 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1124,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae12.3552",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CSTNET CERN #gen-mar-IHEP-CERN-CSTNET $GS-02414 |",
+    "circuits": [
+      {
+        "id": 732309,
+        "name": "GEN-MAR-IHEP-CERN-CSTNET",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 713,
+    "dashboards": [
+      "IC1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CSTNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CSTNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/15",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE16    | LON2-PRD-ESX10 NIC1 PORT2",
+    "circuits": [
+      {
+        "id": 658554,
+        "name": "LON2-PRD-ESX10-NIC1-PORT2",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 529,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/2",
+      "et-4/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LIS-POR-IPTRUNK $GS-00050 | LIS-POR IP TRUNK",
+    "circuits": [
+      {
+        "id": 708705,
+        "name": "LIS-POR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 756,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-POR IP TRUNK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-POR IP TRUNK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.2004",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT ESNET #ESNET-PAR-LHCONE $GS-00823 | ASN293",
+    "circuits": [
+      {
+        "id": 661188,
+        "name": "ESNET-PAR-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 617,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "et-0/0/5",
+      "et-0/1/2",
+      "et-0/1/5",
+      "et-5/0/2"
+    ],
+    "bundle-parents": [
+      "et-0/0/5",
+      "et-0/1/2",
+      "et-0/1/5",
+      "et-5/0/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02171 | MAD-MAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 686,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "2/x1/1/c2/1",
+      "2/x1/1/c2/3"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c2/1",
+      "2/x1/1/c2/3"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae1.7",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/1/1",
+      "xe-5/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #NTP4.GEANT.NET",
+    "circuits": [
+      {
+        "id": 739307,
+        "name": "NTP4.GEANT.NET",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 891,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Was IUCC:  GNT-E10-005",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 551,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae13.104",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ESNET #CH-ESNET-IPV4 $GS-00872 | ASN293 | IPv4",
+    "circuits": [
+      {
+        "id": 730102,
+        "name": "CH-ESNET-IPV4",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1280,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4083",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-STADKORTRIJK-ExpressRoute-VLAN-4083 $GS-01128 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739677,
+        "name": "BELNET-STADKORTRIJK-EXPRESSROUTE-VLAN-4083",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1668,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE GTS SRF0000001 | MAD GTS Server #3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 582,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.140",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CERN REDCLARA #GEN-LIS-CERN-REDCLARA-22059 $GS-02176 |",
+    "circuits": [
+      {
+        "id": 720101,
+        "name": "GEN-LIS-CERN-REDCLARA-22059",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 791,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-21.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4",
+      "1/x1/1/c4/2"
+    ],
+    "description": "SRV_IAS PUBLIC INEX #IX-Peerings-in-INEX $GS-00950 |",
+    "circuits": [
+      {
+        "id": 747291,
+        "name": "IX-PEERINGS-IN-INEX",
+        "type": "IP PEERING - NON R&E (PUBLIC)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "7",
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PUBLIC"
+    ],
+    "dashboard_info": {
+      "name": "INEX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INEX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae4",
+    "bundle": [
+      "et-1/1/2"
+    ],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02585 | POR-POR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 627,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POR-POR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "POR-POR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.21",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEZWEV-01139 $GS-01139",
+    "circuits": [
+      {
+        "id": 744147,
+        "name": "MSEZWEV-01139",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1404,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 573,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.240",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #AMS-SINET-EDGE-DEVICE-IDRAC | SINET edge-device-iDRAC",
+    "circuits": [
+      {
+        "id": 736087,
+        "name": "AMS-SINET-EDGE-DEVICE-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1516,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mar.fr.geant.net",
+    "name": "1/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | MAR-MAR | to RT1.MAR xe-3/2/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1(ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.3921",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET RARE #AMS-HAM-02430 $GS-02430",
+    "circuits": [
+      {
+        "id": 747548,
+        "name": "AMS-HAM-02430",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1542,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE IT_INFRA | to QFX xe-0/0/0",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 672,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.2018",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT REDCLARA #REDCLARA-LIS-LHCONE $GS-00848 | ASN27750",
+    "circuits": [
+      {
+        "id": 713840,
+        "name": "REDCLARA-LIS-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 780,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.3222",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT INTERNET2 #NL-INTERNET2-MONTREAL $GS-00893 | ASN11537 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1752,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-1/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae1 | MAR-MIL2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 677,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-7.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #GEN-PAR-IPTRUNK $GS-00040 | GEN-PAR | ",
+    "circuits": [
+      {
+        "id": 739696,
+        "name": "GEN-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-11/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE DTN-Project 100G $GA-01379 | Under testing ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1203,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "et-5/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE4 | LIS-MAD | 200G",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 774,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "ae2.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-KIE2-UA $GS-00132 | DCN MANAGEMENT ",
+    "circuits": [
+      {
+        "id": 715041,
+        "name": "DCN-MANAGEMENT-KIE2-UA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 613,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/1/c11/1",
+      "1/1/c11/2",
+      "1/1/c12/1"
+    ],
+    "bundle-parents": [
+      "1/1/c11/1",
+      "1/1/c11/2",
+      "1/1/c12/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01776 | MAR-MIL2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MIL2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MIL2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-2/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 730,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-4/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE- WAS FRA-GEN",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1440,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 596,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae22.334",
+    "bundle": [],
+    "bundle-parents": [
+      "et-10/0/2",
+      "et-11/0/5"
+    ],
+    "description": "SRV_IAS CUSTOMER CERN #CERN-AP1-EXT2-IAS IASPS $GS-00561 | ASN513",
+    "circuits": [
+      {
+        "id": 701592,
+        "name": "CERN-AP1-EXT2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1238,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/2.22",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-lon2-uk-owamp-fpc2 | OWAMP CONTACT: ivan.garnizov@fau.de IMPLEMENTED: 20200501",
+    "circuits": [
+      {
+        "id": 677828,
+        "name": "PS-LON2-UK-OWAMP-FPC2",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 766,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "1/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915971,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae17",
+    "bundle": [
+      "xe-0/3/6"
+    ],
+    "bundle-parents": [
+      "xe-0/3/6"
+    ],
+    "description": "LAG RE_INTERCONNECT UBUNTUNET $GA-01917 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1340,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/0/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE3 SRF0000001 | rt1-sw2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 661,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.16",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-UKMO $GS-01089",
+    "circuits": [
+      {
+        "id": 732665,
+        "name": "GRE-MULTICAST-TUNNEL-UKMO",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1219,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 521,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.519",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT RE_INTERCONNECT NISN RENATER #lon-par-CNES-NISN-RENATER $GS-00736",
+    "circuits": [
+      {
+        "id": 709305,
+        "name": "LON-PAR-CNES-NISN-RENATER",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 762,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NISN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NISN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae16.101",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/1",
+      "xe-1/2/3",
+      "xe-2/0/7",
+      "xe-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT-IT GEANT-IT #AMS-OFFICE-TO-LON2-(FOR-EDUVPN)-L2CIRCUIT $GS-00652",
+    "circuits": [
+      {
+        "id": 705901,
+        "name": "AMS-OFFICE-TO-LON2-(FOR-EDUVPN)-L2CIRCUIT",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 563,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/2/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 600,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "et-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE2 | AMS-LON | AMS-LON-AW-TRUNK",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 631,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 607,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae21.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/1/0"
+    ],
+    "description": "SRV_L3VPN CUSTOMER ROEDUNET #ROEDUNET-AP2-LHCONE $GS-00858 | ASN2614",
+    "circuits": [
+      {
+        "id": 679572,
+        "name": "ROEDUNET-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 625,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ROEDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ROEDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 574,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "Reserved for New EX | 10G-LR |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 588,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae12.36",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/1/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER CARNET #CARNET-AP2 $GS-00441 | ASN2108 |",
+    "circuits": [
+      {
+        "id": 730104,
+        "name": "CARNET-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 841,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/1/c25/1"
+    ],
+    "bundle-parents": [
+      "1/1/c25/1"
+    ],
+    "description": "LAG CUSTOMER DFN | $GA-01894",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "2/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | BIL-PAR | to RT1.BIL.ES - et-2/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162177,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "xe-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 567,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "lag-6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #FRA-PRA-IPTRUNK $GS-00033 | FRA-PRA | ",
+    "circuits": [
+      {
+        "id": 740465,
+        "name": "FRA-PRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-PRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-PRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/0/4.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #par-lon2-SUPERPOP-QFX-GEANT $GS-00080 |",
+    "circuits": [
+      {
+        "id": 729412,
+        "name": "PAR-LON2-SUPERPOP-QFX-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 612,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-4/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 995,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "1/1/c11/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | MAR-MIL2 | to RT1.MAR.FR et-1/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900162,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-22.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER MARNET #MARNET-AP1 $GS-00489 | ASN44224 | ",
+    "circuits": [
+      {
+        "id": 744954,
+        "name": "MARNET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "4",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 591,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/0.50",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX1-AMS-TO-FW-WAN |",
+    "circuits": [
+      {
+        "id": 662969,
+        "name": "SRX1-AMS-TO-FW-WAN",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 554,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.3061",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET ORACLE #OFCFODMOB-02631 $GS-02631",
+    "circuits": [
+      {
+        "id": 744387,
+        "name": "OFCFODMOB-02631",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1701,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae13.421",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "SRV_IAS CUSTOMER SANET #SANET-AP1-IAS IASPS $GS-00546 | ASN2607 |",
+    "circuits": [
+      {
+        "id": 718909,
+        "name": "SANET-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 618,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-1/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 677,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | mx1-sw1-poz1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 571,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/2/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 642,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae18.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/1/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER KIFU #KIFU-AP2 $GS-00482 | ASN1955 |",
+    "circuits": [
+      {
+        "id": 734871,
+        "name": "KIFU-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 585,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE AzScienceNe P_AE37 Interxion CID: DE205548 | 202993",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 883,
+    "dashboards": [
+      "EAP"
+    ],
+    "dashboard_info": {
+      "name": "AZSCIENCENE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AZSCIENCENE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-5/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 830,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-6 | FRA-PRA | to RT0.FRA 1/1/C8/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899970,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 602,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae22",
+    "bundle": [
+      "et-2/0/0"
+    ],
+    "bundle-parents": [
+      "et-2/0/0"
+    ],
+    "description": "LAG CUSTOMER IUCC SRF9915965 $GA-01940 | IUCC-AP2-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 985,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "IUCC",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "IUCC",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-INPE $GS-01080",
+    "circuits": [
+      {
+        "id": 732666,
+        "name": "GRE-MULTICAST-TUNNEL-INPE",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1213,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.37",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSENCCN-02370 $GS-02370",
+    "circuits": [
+      {
+        "id": 744141,
+        "name": "MSENCCN-02370",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1418,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.30",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEMOBILIT-02169 $GS-02169",
+    "circuits": [
+      {
+        "id": 744269,
+        "name": "MSEMOBILIT-02169",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1412,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 548,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21",
+    "bundle": [
+      "1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER NORDUNET | $GA-01893 | NORDUNET LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177301,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 848,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.996",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #GEANT-OPERATIONS-LabConnectivity | GEANT MX1.LON Infinera VRF to Operations Lab",
+    "circuits": [
+      {
+        "id": 740707,
+        "name": "GEANT-OPERATIONS-LABCONNECTIVITY",
+        "type": "CORPORATE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 920,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/0/2.10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS DTN-PROJECT #DTN-LON-10G-DATA $GS-00146 | 10G Testing CONTACT: Richard.Hughes-Jones@geant.org",
+    "circuits": [
+      {
+        "id": 661522,
+        "name": "DTN-LON-10G-DATA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1161,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/3/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 611,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER NORDUNET #NORDUNET-AP2 $GS-00493 | ASN2603 | ",
+    "circuits": [
+      {
+        "id": 747589,
+        "name": "NORDUNET-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "12",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE8 | AMS-LON | AMS-LON-AW-TRUNK",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1560,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae1.25",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/4",
+      "xe-3/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | PRA BMS SERVER 5 IDRAC",
+    "circuits": [
+      {
+        "id": 725645,
+        "name": "RARE-BMS-SERVER-1-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 950,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae18",
+    "bundle": [
+      "xe-2/1/1",
+      "xe-2/2/1"
+    ],
+    "bundle-parents": [
+      "xe-2/1/1",
+      "xe-2/2/1"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | splunk-lon2-peer01.geant.org | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 635,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21.111",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c26/1"
+    ],
+    "description": "SRV_L3VPN CUSTOMER NORDUNET #NORDUNET-AP2-LHCONE $GS-02118 | ASN2603 | ",
+    "circuits": [
+      {
+        "id": 747591,
+        "name": "NORDUNET-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "13",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/1/4.2050",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER ESNET NEA3R #lon-lon-GEANTOpen-ESNET-NEA3R $GS-02250 |",
+    "circuits": [
+      {
+        "id": 738640,
+        "name": "LON-LON-GEANTOPEN-ESNET-NEA3R",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1520,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NEA3R",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NEA3R",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:1176",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET SCION #FED4FIRE-00682 $GS-00682",
+    "circuits": [
+      {
+        "id": 745343,
+        "name": "FED4FIRE-00682",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 549,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 583,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.220",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 TENET #lon-par-GEANTOPEN-INTERNET2-TENET-19004 $GS-00970 |",
+    "circuits": [
+      {
+        "id": 736663,
+        "name": "LON-PAR-GEANTOPEN-INTERNET2-TENET-19004",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1135,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CESNET",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 651,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 561,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "2/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | FRA-FRA | TO RT1.FRA.DE-et-3/1/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162817,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "lag-7",
+    "bundle": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02408 | POZ-PRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177287,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-PRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-PRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae28.201",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER TENET ESNET #lon-lon-GEANTOpen-Esnet-TENET-180871 $GS-00966 |",
+    "circuits": [
+      {
+        "id": 738644,
+        "name": "LON-LON-GEANTOPEN-ESNET-TENET-180871",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 644,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "TENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4080",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet-ARPGAN-ExpressRoute-VLAN4080 $GS-01122 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739674,
+        "name": "BELNET-ARPGAN-EXPRESSROUTE-VLAN4080",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1665,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01681 | FRA-PRD-ESX01 VM Traffic LAG",
+    "circuits": [
+      {
+        "id": 658532,
+        "name": "FRANKFURT 15-FRANKFURT 15-LAG-064(GEANT)",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 578,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/4.19",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #DASHBOARD-TEST-SERVICE-LON2-VIRGIN(DO-NOT-OPEN-TICKET)|",
+    "circuits": [
+      {
+        "id": 709123,
+        "name": "VIRGIN_MEDIA_EX1_LON2_TO_CAM_SRX_VLAN19-CH",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 532,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-7",
+    "bundle": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01823 | GEN-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177287,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae23",
+    "bundle": [
+      "xe-0/3/3"
+    ],
+    "bundle-parents": [
+      "xe-0/3/3"
+    ],
+    "description": "LAG PRIVATE ORACLE SRF21099 #NL-ORACLEFC-LAG-1 $GA-02009 | FastConnect NREN Access",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1311,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.buc.ro.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUC-BUC-IPTRUNK $GS-50060 | BUC-BUC | BUC-BUC",
+    "circuits": [
+      {
+        "id": 745576,
+        "name": "BUC-BUC-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.87",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER EUMETSAT #EUMET-BUCC-MAD-17042 $GS-00457 | VLAN 87 MONITORING 85",
+    "circuits": [
+      {
+        "id": 715042,
+        "name": "EUMET-BUCC-MAD-17042",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1055,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "EUMETSAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EUMETSAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae23.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/0/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_IAS CUSTOMER CESNET #CESNET-AP2-IAS IASPS $GS-00564 | ASN2852",
+    "circuits": [
+      {
+        "id": 731675,
+        "name": "CESNET-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1098,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.18",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #VIRGIN-MEDIA-EX1-LON2-TO-CAM-SRX-VLAN18 |",
+    "circuits": [
+      {
+        "id": 661962,
+        "name": "VIRGIN-MEDIA-EX1-LON2-TO-CAM-SRX-VLAN18",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1862,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae3.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/0/1",
+      "xe-2/0/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-MAD-ES | ",
+    "circuits": [
+      {
+        "id": 702127,
+        "name": "DCN-MANAGEMENT-MAD-ES",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 747,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae18.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/1/0"
+    ],
+    "description": "SRV_L3VPN CUSTOMER KIFU #KIFU-AP2-LHCONE $GS-02283 | ASN1955 |",
+    "circuits": [
+      {
+        "id": 734866,
+        "name": "KIFU-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 851,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-22:1640",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET SCION #SCION-02382 $GS-02382",
+    "circuits": [
+      {
+        "id": 745483,
+        "name": "SCION-02382",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-8/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE4 | LIS-MAD | 200G",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1141,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae14.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/0",
+      "et-10/1/2"
+    ],
+    "description": "SRV_IAS PUBLIC DE-CIX #IX-Peerings-in-DE-CIX-MAD $GS-00949 |",
+    "circuits": [
+      {
+        "id": 661295,
+        "name": "IX-PEERINGS-IN-DE-CIX-MAD",
+        "type": "IP PEERING - NON R&E (PUBLIC)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1106,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PUBLIC"
+    ],
+    "dashboard_info": {
+      "name": "DE-CIX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DE-CIX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-8/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | BUD-VIE | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1144,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c9/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #HAM-TAR-IPTRUNK $GS-02348 | HAM-TAR | ",
+    "circuits": [
+      {
+        "id": 746460,
+        "name": "HAM-TAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-TAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-TAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.37",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-MSER-NCCN-ExpressRoute-VLAN4065 $GS-02371 | ",
+    "circuits": [
+      {
+        "id": 739672,
+        "name": "BELNET-MSER-NCCN-EXPRESSROUTE-VLAN4065",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 676,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/2/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #par-lon2-SUPERPOP-QFX-2-GEANT $GS-00081 |",
+    "circuits": [
+      {
+        "id": 729417,
+        "name": "PAR-LON2-SUPERPOP-QFX-2-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1117,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4092",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEIMEC-02092 $GS-02092",
+    "circuits": [
+      {
+        "id": 744142,
+        "name": "MSEIMEC-02092",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3202",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT TEIN #UK-TEIN $GS-00924 | ASN24490 | Singapore",
+    "circuits": [
+      {
+        "id": 661949,
+        "name": "UK-TEIN",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 575,
+    "dashboards": [
+      "CAE1",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "TEIN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TEIN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 520,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.38",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS Customer Nordunet MICROSOFT #Nordunet-MSER-ExpressRoute-Vlan3918 $GS-02411  | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 732192,
+        "name": "NORDUNET-MSER-EXPRESSROUTE-VLAN3918",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1419,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 579,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-8/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 992,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #uat-ps-lon2-uk-bwctl | BWCTL CONTACT: ivan.garnizov@fau.de IMPLEMENTED: 20200225",
+    "circuits": [
+      {
+        "id": 708923,
+        "name": "UAT-PS-LON2-UK-BWCTL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 671,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "2/x1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | LJU-ZAG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178498,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.10",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #NE-ESXI-VMnetwork-PAR-FR | ne-esxi-prod-par-1 VMnetwork",
+    "circuits": [
+      {
+        "id": 739095,
+        "name": "NE-ESXI-VMNETWORK-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1215,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.4001",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_IAS PRIVATE NORDUNET #UK-NORDUNET-IX-2603 $GS-00944 | ASN2603 | NORDUnet peer UK",
+    "circuits": [
+      {
+        "id": 660550,
+        "name": "UK-NORDUNET-IX-2603",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1281,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 870,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN | Trunk to EX1.lon2.uk",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1021,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 933,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.400",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #NOKIA_DEMO_AMS | ",
+    "circuits": [
+      {
+        "id": 747232,
+        "name": "NOKIA_DEMO_AMS",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1764,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.420",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT DFN NKN #AMS-HAM-DFN-NKN-02211 $GS-02211",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1735,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.3018",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #AMS-PAR-SINET-SD-WAN-SINET-SINET-17091 $GS-00660 |",
+    "circuits": [
+      {
+        "id": 736074,
+        "name": "AMS-PAR-SINET-SD-WAN-SINET-SINET-17091",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1519,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/1/4.123",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET ESNET #lon-lon-GEANTOpen-ESnet-NORDUNET-15039-1 $GS-00963 |",
+    "circuits": [
+      {
+        "id": 738642,
+        "name": "LON-LON-GEANTOPEN-ESNET-NORDUNET-15039-1",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1509,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-11/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 743,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/2.702",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT GEANT #par-fra-DTN-generator $GS-00745 | RARE P4 TESTBED",
+    "circuits": [
+      {
+        "id": 733002,
+        "name": "PAR-FRA-DTN-GENERATOR",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1449,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.615",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT REDCLARA #PT-REDCLARA $GS-00903 | ASN27750 |",
+    "circuits": [
+      {
+        "id": 713837,
+        "name": "PT-REDCLARA",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 779,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-11/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-bw-vie.at.geant.org pS BWCTL",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 865,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.22",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-DMI $GS-02172",
+    "circuits": [
+      {
+        "id": 732672,
+        "name": "GRE-MULTICAST-TUNNEL-DMI",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1225,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.936",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDIRIS GEANT #AMS-BIL-REDIRIS-RARE $GS-02287 |",
+    "circuits": [
+      {
+        "id": 736075,
+        "name": "AMS-BIL-REDIRIS-RARE",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1534,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae20.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/0/3",
+      "xe-2/1/1"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT NKN #CH-NKN $GS-00874 | ASN9885 |",
+    "circuits": [
+      {
+        "id": 678060,
+        "name": "CH-NKN",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 892,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "NKN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NKN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c9/1",
+      "1/x1/1/c9/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #SOF-ZAG-IPTRUNK $GS-02367 | SOF-ZAG | ",
+    "circuits": [
+      {
+        "id": 747867,
+        "name": "SOF-ZAG-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 7,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-ZAG",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-ZAG",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/2.104",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF SRF21105 #FRA-PRA-RARE-BMS8 $GS-00706",
+    "circuits": [
+      {
+        "id": 737235,
+        "name": "FRA-PRA-RARE-BMS8",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1446,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 525,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.20",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet_ARTEV_ExpressRoute_VLAN4081 $GS-01123 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739675,
+        "name": "BELNET-ARTEV-EXPRESSROUTE-VLAN4081",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 601,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "et-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | PRA-PRA | to RT0.PRA 1/1/C12/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 897,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/3.500",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX1-City-House-Network-Infrastructure |",
+    "circuits": [
+      {
+        "id": 662973,
+        "name": "SRX1-CITY-HOUSE-NETWORK-INFRASTRUCTURE",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 544,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/5",
+      "et-0/1/2",
+      "et-0/1/5",
+      "et-5/0/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MAD-MAR-IPTRUNK $GS-00054| MAD-MAR | ",
+    "circuits": [
+      {
+        "id": 717047,
+        "name": "MAD-MAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 690,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.34",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSERIZIV-02520 $GS-02520",
+    "circuits": [
+      {
+        "id": 744225,
+        "name": "MSERIZIV-02520",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1415,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-101.103",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-COR-IE-VRF-VLAN103 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "8",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4086",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEFGOV-01132 $GS-01132",
+    "circuits": [
+      {
+        "id": 744263,
+        "name": "MSEFGOV-01132",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "ae10.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/1",
+      "xe-0/1/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER URAN #URAN-AP2 $GS-00521 | ASN12687 |",
+    "circuits": [
+      {
+        "id": 714000,
+        "name": "URAN-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 609,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:191",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET REDIRIS #HAM-MAD-02343 $GS-02343",
+    "circuits": [
+      {
+        "id": 747542,
+        "name": "HAM-MAD-02343",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 623,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 593,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 849,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae18.10",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_IAS PUBLIC BIX #IX-Peerings-in-BIX-BUD $GS-00956 |",
+    "circuits": [
+      {
+        "id": 663235,
+        "name": "IX-PEERINGS-IN-BIX-BUD",
+        "type": "IP PEERING - NON R&E (PUBLIC)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 527,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PUBLIC"
+    ],
+    "dashboard_info": {
+      "name": "BIX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-20.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c25/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER DFN #DFN-AP2 $GS-00453 | ASN680 | ",
+    "circuits": [
+      {
+        "id": 745579,
+        "name": "DFN-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae1.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/1/1",
+      "xe-5/1/2"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT UTIC #BUD-UTIC $GS-02232 | ASN8670 |",
+    "circuits": [
+      {
+        "id": 739336,
+        "name": "BUD-UTIC",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 945,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "UTIC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UTIC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-lhc-bw-fra.de.geant.org pS BWCTL (LHCONE)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 553,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/1/7.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #par-lon2-SUPERPOP-QFX-GEANT $GS-00080 |",
+    "circuits": [
+      {
+        "id": 729412,
+        "name": "PAR-LON2-SUPERPOP-QFX-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1120,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3151",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET SINGAREN #LON-LON-GEANTOPEN-NORDUNET-SINGAREN-CAE1-19074-VL3151 $GS-00976 |",
+    "circuits": [
+      {
+        "id": 705892,
+        "name": "LON-LON-GEANTOPEN-NORDUNET-SINGAREN-CAE1-19074-VL3151",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 758,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.35",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #NORDUNET-FUNET-ExpressRoute-VLAN3917 $GS-02327 | ",
+    "circuits": [
+      {
+        "id": 727782,
+        "name": "NORDUNET-FUNET-EXPRESSROUTE-VLAN3917",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1416,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1059,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/2.201",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE REDIRIS #fra-mad-RARE-REDIRIS-23017-VL201 $GS-02274",
+    "circuits": [
+      {
+        "id": 732759,
+        "name": "FRA-MAD-RARE-REDIRIS-23017-VL201",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1447,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-4/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 997,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-9.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-HAM-IPTRUNK $GS-00010 | AMS-HAM | ",
+    "circuits": [
+      {
+        "id": 739970,
+        "name": "AMS-HAM-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-HAM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-HAM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.3151",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER SINET #ams-gen-Grid5000-Renater-SINET-07201 $GS-00636 |",
+    "circuits": [
+      {
+        "id": 705429,
+        "name": "AMS-GEN-GRID5000-RENATER-SINET-07201",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 893,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "irb.521",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-LON2-UK-VRF-VLAN521 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 831,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.209",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ddos-mit2-fra-de-idrac | NEMO DDOS Mitigation 2 iDRAC | ",
+    "circuits": [
+      {
+        "id": 732633,
+        "name": "DDOS-MIT2-FRA-DE-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1411,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 524,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER REDIRIS P_AE15 SRF21114",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 670,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae12.1200",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/5",
+      "et-8/0/5",
+      "et-11/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CERN GARR #gen-gen-GARR-CERNlight-CERN-GARR-16034 $GS-00709 |",
+    "circuits": [
+      {
+        "id": 706977,
+        "name": "GEN-GEN-GARR-CERNLIGHT-CERN-GARR-16034",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 805,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/5.3174",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINGAREN NETHERLIGHT #SINGAREN-02647 $GS-02647 |",
+    "circuits": [
+      {
+        "id": 746484,
+        "name": "SINGAREN-02647",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 929,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ASNET-AM P_AE17 Interxion CID: DE238515 | Telekom Armenia CID: GEANT-22-254-EPL1 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 898,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ASNET-AM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASNET-AM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER BELNET | $GA-01913",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.903",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 GEANT #par-par-MISC-GEANT-INTERNET2-9940539 $GS-00747 |",
+    "circuits": [
+      {
+        "id": 705916,
+        "name": "PAR-PAR-MISC-GEANT-INTERNET2-9940539",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1210,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/0/1:2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 533,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "2/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "''",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161730,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 621,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1028,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-4/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae4 | GEN-MAR | to rt0.gen  2/1/c8/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 580,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae1.28",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/4",
+      "xe-3/0/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT EUMETSAT #PRA-EUMETSAT-SERVER-DATA-TRAFFIC $GS-02361 | PRA-EUMETSAT-1G",
+    "circuits": [
+      {
+        "id": 729004,
+        "name": "PRA-EUMETSAT-SERVER-DATA-TRAFFIC",
+        "type": "IP PEERING - R&E",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 966,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "EUMETSAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EUMETSAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae10.4088",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-2/1/5",
+      "et-11/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER GARR MICROSOFT #GARR-ROMA_ExpressRoute_VLAN4088 $GS-01147 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707295,
+        "name": "GARR-ROMA_EXPRESSROUTE_VLAN4088",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 796,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/2/7.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-fra-de-management UAT |perfSONAR MGMT",
+    "circuits": [
+      {
+        "id": 733940,
+        "name": "PS-FRA-DE-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1354,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5",
+      "et-1/1/2",
+      "et-2/0/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BIL-PAR-IPTRUNK $GS-00016| BIL-PAR | BIL-PAR",
+    "circuits": [
+      {
+        "id": 739468,
+        "name": "BIL-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 525,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae1.250",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/0",
+      "xe-1/2/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #vm-lon2-uk-idracs-250| NEW VM iDRACs",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 884,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/5",
+      "et-0/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BIL-POR-IPTRUNK $GS-00017 | BIL-POR IP TRUNK",
+    "circuits": [
+      {
+        "id": 709122,
+        "name": "BIL-POR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 524,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-POR IP TRUNK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-POR IP TRUNK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae31.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/3/5",
+      "xe-8/0/0"
+    ],
+    "description": "SRV_INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 MGMT | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 741,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 564,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/0.1200",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER CERN GARR #gen-gen-GARR-CERNlight-CERN-GARR-16034 $GS-00709 |",
+    "circuits": [
+      {
+        "id": 706977,
+        "name": "GEN-GEN-GARR-CERNLIGHT-CERN-GARR-16034",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 859,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "1/1/c11/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-9 | BUD-VIE | to MX1.BUD et-8/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900162,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae18",
+    "bundle": [
+      "et-1/1/0"
+    ],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "LAG PUBLIC BIX SRF9946209 $GA-01900 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 655,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae33",
+    "bundle": [
+      "et-1/1/2"
+    ],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "LAG CUSTOMER NORDUNET $GA-02480 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1682,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "2/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | RIG-TAR | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178497,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "RIG-TAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RIG-TAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER REDIRIS P_AE15 SRF21114",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 676,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.19",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-UWSSEC $GS-01090",
+    "circuits": [
+      {
+        "id": 732660,
+        "name": "GRE-MULTICAST-TUNNEL-UWSSEC",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1222,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-101.103",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/2",
+      "1/x1/1/c2/3"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-ATH-GR-VRF-VLAN103 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "10",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1195,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae14.160",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5",
+      "et-8/0/2",
+      "et-8/1/2",
+      "et-8/1/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER RENATER #RENATER-AP2 $GS-00506 | ASN2200 |",
+    "circuits": [
+      {
+        "id": 663060,
+        "name": "RENATER-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 828,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae11.420",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER DFN NKN SRF22079 #FRA-GEN-DFN-NKN-22079 $GS-02210 |",
+    "circuits": [
+      {
+        "id": 724886,
+        "name": "FRA-GEN-DFN-NKN-22079",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 915,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NKN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bud.hu.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c9/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUD-BUD-IPTRUNK $GS-02596 | BUD-BUD | BUD-BUD-MGMT",
+    "circuits": [
+      {
+        "id": 742924,
+        "name": "BUD-BUD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-BUD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-BUD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "1/1/c9/2",
+      "1/1/c12/2",
+      "2/1/c9/2"
+    ],
+    "bundle-parents": [
+      "1/1/c9/2",
+      "1/1/c12/2",
+      "2/1/c9/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02544 | PRA-PRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-PRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-PRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-21.111",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1",
+      "1/x1/1/c26/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER ULAKBIM #ULAKBIM-AP1-LHCONE $GS-00868 | ASN8517 | ",
+    "circuits": [
+      {
+        "id": 745294,
+        "name": "ULAKBIM-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "12",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #GEN-MIL2-IPTRUNK $GS-00039 | GEN-MIL2 | ",
+    "circuits": [
+      {
+        "id": 740949,
+        "name": "GEN-MIL2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MIL2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MIL2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/x1/1/c9/1",
+      "1/x1/1/c9/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c9/1",
+      "1/x1/1/c9/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02369 | SOF-ZAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-ZAG",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-ZAG",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 559,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE DTN-Project 10G $GA-01377 | Under testing ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1199,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-1/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENATER P_AE12 | RENATER-AP1-1 | DR Circuit ID: FR112753",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1152,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae12.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/1/2"
+    ],
+    "description": "SRV_IAS CUSTOMER CARNET #CARNET-AP2-IAS IASPS $GS-00560 | ASN2108",
+    "circuits": [
+      {
+        "id": 730098,
+        "name": "CARNET-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 843,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-7/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | WAS FB-ID: 8644659",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 824,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/1/5.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #DTN-LON-100G-JBO-DATA $GS-00144 | DTN-PROJECT | 100G Testing CONTACT: Richard.Hughes-Jones@geant.org",
+    "circuits": [
+      {
+        "id": 708302,
+        "name": "DTN-LON-100G-JBO-DATA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 632,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae11.938",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-2/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CESNET #pra-ams-CESNET-SURF-FABRIC $GS-02649 |",
+    "circuits": [
+      {
+        "id": 747231,
+        "name": "PRA-AMS-CESNET-SURF-FABRIC",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1029,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE2     | LON2-PRD-ESX02 NIC1 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 518,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1058,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/8.10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #GEANT-CORPORATE-ViaVodafone | GEANT Corporate to mx1.lon - Via Vodafone",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 543,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE1     | LON2-PRD-ESX01 NIC1 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 517,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae11.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-2/1/5"
+    ],
+    "description": "SRV_L3VPN CUSTOMER CESNET #CESNET-AP1-LHCONE $GS-00813 | ASN2852",
+    "circuits": [
+      {
+        "id": 725154,
+        "name": "CESNET-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 934,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 516,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/2/6.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-fra-de-owamp UAT | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 733912,
+        "name": "PS-FRA-DE-OWAMP",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1353,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE FW1-SNM",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 663,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-bw- bud.hu geant.org pS BWCTL",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 943,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-5/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | FRA-PAR-QFX | to QFX xe-1/0/17",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 821,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4085",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-IMEC-ExpressRoute-VLAN4085 $GS-02091 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739663,
+        "name": "BELNET-IMEC-EXPRESSROUTE-VLAN4085",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1670,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae18.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/1/1",
+      "xe-2/2/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | SPLUNK LON2 PEER01 MGMT | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 798,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-22:1006",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET GRNET #FED4FIRE-00669 $GS-00669",
+    "circuits": [
+      {
+        "id": 747356,
+        "name": "FED4FIRE-00669",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-3/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 769,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 846,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/3.501",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #CAM-CH-WAN-GATEWAY-2 | 2nd internet link at City House",
+    "circuits": [
+      {
+        "id": 663110,
+        "name": "CAM-CH-WAN-GATEWAY-2",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 549,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER NETHERLIGHT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 647,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/4.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER RENATER $GS-00784  #ams-par-LOFAR-RENATER-NetherLight-10001 |",
+    "circuits": [
+      {
+        "id": 734546,
+        "name": "AMS-PAR-LOFAR-RENATER-NETHERLIGHT-10001",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1057,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 791,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.25",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #DRAC-SuperPoP-PAR-FR | SuperPOP DRAC",
+    "circuits": [
+      {
+        "id": 733978,
+        "name": "DRAC-SUPERPOP-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 715,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "1/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | AMS-LON | to LON01.GRV1 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900097,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae27.1",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-10/2/0"
+    ],
+    "description": "PHY CUSTOMER_GEO MAEEN #MAEEN-GEO-UK-1 |  SRF21017|",
+    "circuits": [
+      {
+        "id": 719829,
+        "name": "MAEEN-GEO-UK-1",
+        "type": "GEANT OPEN PORT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1171,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "MAEEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAEEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.401",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS SINGAREN #OOB-SINGAREN-LON2-UK | LON2-SingAREN-1G OOB",
+    "circuits": [
+      {
+        "id": 740504,
+        "name": "OOB-SINGAREN-LON2-UK",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 900,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae17",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01705 | LON2-PRD-ESX11 VM TRAFFIC LAG",
+    "circuits": [
+      {
+        "id": 658659,
+        "name": "LON2-PRD-ESX11-VM-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 605,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-1/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae4 | BIL-PAR | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 679,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 569,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae33.200",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 - CLEAN-IAS | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 817,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-5/1/1",
+      "xe-5/1/2"
+    ],
+    "bundle-parents": [
+      "xe-5/1/1",
+      "xe-5/1/2"
+    ],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN | bud hu POP LAN",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 615,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "2/1/c9/2",
+      "2/1/c11/1",
+      "2/1/c11/2"
+    ],
+    "bundle-parents": [
+      "2/1/c9/2",
+      "2/1/c11/1",
+      "2/1/c11/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02527 | POZ-POZ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-POZ",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-POZ",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "xe-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENAM",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 567,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-2/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | 100GB LR4 CFP2 INSTALLED",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 649,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE16 | QFX.LON2.UK xe-0/0/47",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1571,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "et-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER SANET P_AE13 SRF24007|",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 592,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SANET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SANET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.1629",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 SCION #gen-par-SCION-SCION-INTERNET2-2 $GS-02311 |",
+    "circuits": [
+      {
+        "id": 736653,
+        "name": "GEN-PAR-SCION-SCION-INTERNET2-2",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1155,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.412",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_GCS CUSTOMER REDIRIS MICROSOFT #REDIRIS-UCLM-ExpressRoute-VLAN412 $GS-01164 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707138,
+        "name": "REDIRIS-UCLM-EXPRESSROUTE-VLAN412",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1085,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-21.200",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c26/1"
+    ],
+    "description": "SRV_IAS CUSTOMER EENET #EENET-AP2-IAS IASPS $GS-00569 | ASN3221 | ",
+    "circuits": [
+      {
+        "id": 745985,
+        "name": "EENET-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "9",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "EENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "xe-0/1/7"
+    ],
+    "bundle-parents": [
+      "xe-0/1/7"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN |rt1-sw1(ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 596,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-ZAG-HR-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "4",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "et-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae8 | BRA-VIE | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 629,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/42",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE29    | 10_GBS to MX1.LON2.UK xe-2/2/7",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 683,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01690 | LON2-PRD-ESX01 ESXI Traffic LAG - No LACP",
+    "circuits": [
+      {
+        "id": 658656,
+        "name": "LON2-PRD-ESX01-ESXI-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 591,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/3.1338",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION SURF #ams-par-SCION-SURF-SCION-23013 $GS-02264 |",
+    "circuits": [
+      {
+        "id": 726377,
+        "name": "AMS-PAR-SCION-SURF-SCION-23013",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 961,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.19",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #DASHBOARD-TEST-SERVICE-LON2-VIRGIN(DO-NOT-OPEN-TICKET)|",
+    "circuits": [
+      {
+        "id": 707142,
+        "name": "DASHBOARD-TEST-SERVICE-LON2-VIRGIN(DO-NOT-OPEN-TICKET)",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 610,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.4005",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN CUSTOMER NORDUNET #NORDUNET-LON-IPv6-LHCONE $GS-00842 | ASN2603",
+    "circuits": [
+      {
+        "id": 661712,
+        "name": "NORDUNET-LON-IPV6-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1282,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 564,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4065",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEONDD-02389 $GS-02389",
+    "circuits": [
+      {
+        "id": 744236,
+        "name": "MSEONDD-02389",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-23:550",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET RENATER #GRID5K-02234",
+    "circuits": [
+      {
+        "id": 744235,
+        "name": "GRID5K-02234",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | mx1-sw2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1268,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 592,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER AMS",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 532,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "AMS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.buc.ro.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "2/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c26/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-50062 | BUC-BUC",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUC",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUC",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.2000",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT CSTNET #CSTNET-AMS-LHCONE  $GS-02537 | ASN7497 ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1745,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CSTNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CSTNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.3502",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER RARE #RARE-02640 $GS-02640 |",
+    "circuits": [
+      {
+        "id": 745532,
+        "name": "RARE-02640",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 899,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae1.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/1/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-vie-at | SW1-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 737826,
+        "name": "EX3400-MANAGEMENT-VIE-AT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 655,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-2/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 636,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae1.402",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/0",
+      "xe-1/2/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS WP6 Netronome server # Netronome-IDRAC-LON2-UK | IDRAC CONTACT: pavle.vuletic@amres.ac.rs IMPLEMENTED: 20180502",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 902,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae29",
+    "bundle": [
+      "xe-4/1/5",
+      "xe-8/0/1"
+    ],
+    "bundle-parents": [
+      "xe-4/1/5",
+      "xe-8/0/1"
+    ],
+    "description": "LAG UPSTREAM COGENT SRF9945471 $GA-01849 | Cogent ID: 3-001176142",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 709,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21",
+    "bundle": [
+      "2/x1/1/c2/2"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c2/2"
+    ],
+    "description": "LAG CUSTOMER BELNET | $GA-02314 | IMINDS-IC-GEANT-10G",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1342177301,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-8/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER REDIRIS P_AE16 SRF21114 |Equinix CID: M21-11I-02-65/66 |  P6 in odf3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1143,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae20.2260",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-5/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINGAREN #AMS-LON-GEANTOPEN-SINET-SINGAREN-CAE1-19103-VL2260 $GS-00957 |",
+    "circuits": [
+      {
+        "id": 706922,
+        "name": "AMS-LON-GEANTOPEN-SINET-SINGAREN-CAE1-19103-VL2260",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1286,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #COR-LON2-IPTRUNK $GS-02386 | COR-LON2 | ",
+    "circuits": [
+      {
+        "id": 738860,
+        "name": "COR-LON2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-LON2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-LON2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae11.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/2"
+    ],
+    "description": "SRV_IAS PRIVATE GOOGLE #NL-GOOGLE-2-15169 $GS-00938 | ASN15169 |",
+    "circuits": [
+      {
+        "id": 734909,
+        "name": "NL-GOOGLE-2-15169",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1328,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "GOOGLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GOOGLE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae18.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/1/0"
+    ],
+    "description": "SRV_IAS CUSTOMER KIFU #KIFU-AP2-IAS IASPS $GS-00576 | ASN1955 |",
+    "circuits": [
+      {
+        "id": 734862,
+        "name": "KIFU-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 586,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "xe-3/0/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P10",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 539,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #HAM-POZ-IPTRUNK $GS-02339 | HAM-POZ | ",
+    "circuits": [
+      {
+        "id": 740148,
+        "name": "HAM-POZ-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-POZ",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-POZ",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 831,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae28.1",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/0/5"
+    ],
+    "description": "PHY CUSTOMER_GEO TENET #TENET-GEO-UK | P_AE28 SRF21083 |",
+    "circuits": [
+      {
+        "id": 719827,
+        "name": "TENET-GEO-UK",
+        "type": "GEANT OPEN PORT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1173,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "TENET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4074",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSECREDENDO-02655 $GS-02655 | ",
+    "circuits": [
+      {
+        "id": 747921,
+        "name": "MSECREDENDO-02655",
+        "type": "EXPRESS ROUTE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1721,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae20.333",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/2/3"
+    ],
+    "description": "SRV_IAS CUSTOMER GRENA #GRENA-AP1-IAS IASPS $GS-02653 | ASN20545 |",
+    "circuits": [
+      {
+        "id": 747643,
+        "name": "GRENA-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 816,
+    "dashboards": [
+      "EAP",
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "GRENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 835,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae22",
+    "bundle": [
+      "et-10/0/2",
+      "et-11/0/5"
+    ],
+    "bundle-parents": [
+      "et-10/0/2",
+      "et-11/0/5"
+    ],
+    "description": "LAG CUSTOMER CERN #1  $GA-02089 |EXT-2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 712,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-LON-IPTRUNK $GS-02269 | AMS-LON | ",
+    "circuits": [
+      {
+        "id": 738598,
+        "name": "AMS-LON-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "et-3/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | ROEDUNET 100G AP upgrade - CFP2 present | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 629,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "et-4/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | BUC-BUC | Connected to rt0.buc 2/x1/1/c26/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 636,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/11",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 525,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae25.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/0"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT NIKS #NL-NIKS $GS-01183 | ASN3267 |",
+    "circuits": [
+      {
+        "id": 734932,
+        "name": "NL-NIKS",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1330,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "NIKS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NIKS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c8/1",
+      "2/x1/1/c8/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUC-SOF-IPTRUNK $GS-00024 | BUC-SOF | ",
+    "circuits": [
+      {
+        "id": 744991,
+        "name": "BUC-SOF-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 17,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-SOF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-SOF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-101.200",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER BREN #BREN-AP2 $GS-00439 | ASN6802 |",
+    "circuits": [
+      {
+        "id": 744952,
+        "name": "BREN-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "12",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae32.533",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/0",
+      "et-5/0/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE Access #TOOLS-ACCESS-LON2-UK  | TOOLS ACCESS",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 925,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-lhc-owd-gen.ch.geant.org pS OWAMP (OWAMP)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1295,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-20.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c18/2",
+      "1/x1/1/c24/1",
+      "1/x1/1/c24/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER ARNES #ARNES-AP2 $GS-00427 | ASN2107 | ",
+    "circuits": [
+      {
+        "id": 747839,
+        "name": "ARNES-AP2",
+        "type": "GEANT IP",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "9",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1038,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "1/x1/1/c6/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | ATH2-MIL2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916225,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-uat-bw-fra.de.geant.org  pS BWCTL",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1299,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae4",
+    "bundle": [
+      "et-8/0/2",
+      "et-8/0/5"
+    ],
+    "bundle-parents": [
+      "et-8/0/2",
+      "et-8/0/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE #LAG-LIS-MAD $GA-02001 | LIS-MAD | 200G",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 618,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-MAD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-MAD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "1/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | KAU-KAU | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-KAU",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-KAU",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | 10G-SR",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1027,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-22",
+    "bundle": [
+      "1/x1/1/c2/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/2"
+    ],
+    "description": "LAG CUSTOMER MARNET | $GA-01732 | #MARNET-AP1-LAG | MARNET-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177302,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MARNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MARNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "et-0/0/0"
+    ],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02036 | AMS2-LON-AMT-LAG |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 580,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS2-LON-AMT-LAG",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS2-LON-AMT-LAG",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RARE EDGECORE WEDGE100BF-32X xe-1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1261,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "et-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | BUC-CHI | connected to GRV4 port 1/1/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 660,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 565,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "xe-0/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 561,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-8/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CARNET P_AE12 | CARnet AP2 #1 part of ae12",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1148,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CARNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CARNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae23.25",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET SCION #FED4FIRE-00671 $GS-00671",
+    "circuits": [
+      {
+        "id": 745340,
+        "name": "FED4FIRE-00671",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 693,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-bw-poz-pl.geant.org pS BWCTL",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 755,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #HAM-TAR-IPTRUNK $GS-02348 | HAM-TAR | ",
+    "circuits": [
+      {
+        "id": 746460,
+        "name": "HAM-TAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-TAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-TAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 745,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.23",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-lon-uk-psmp-bwctl-vlan23 |psmp-lhc-drac-lon-uk.geant.org pS iDRAC",
+    "circuits": [
+      {
+        "id": 740709,
+        "name": "PS-LON-UK-PSMP-BWCTL-VLAN23",
+        "type": "SERVER LINK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 776,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | mx1-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1261,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.2110",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 HBKU #lon-par-GEANTOPEN-INTERNET2-HBKU-190092 $GS-00985 |",
+    "circuits": [
+      {
+        "id": 709340,
+        "name": "LON-PAR-GEANTOPEN-INTERNET2-HBKU-190092",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 827,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "HBKU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.2126",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CERN CANARIE #lon-par-Canarie-CERN-15014 $GS-00720 |",
+    "circuits": [
+      {
+        "id": 736734,
+        "name": "LON-PAR-CANARIE-CERN-15014",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1161,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/8.11",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #GEANT-CORPORATE-ViaVodafone-VRF | GEANT Corporate to mx1.lon - Via Vodafone - for VRF",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 545,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.3174",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINGAREN NETHERLIGHT #SINGAREN-02647 $GS-02647 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1751,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01694 | LON2-PRD-ESX11 ESXI Traffic LAG - LACP passive",
+    "circuits": [
+      {
+        "id": 658524,
+        "name": "LON2-PRD-ESX11-ESXI-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 597,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 594,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae17.333",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/6"
+    ],
+    "description": "SRV_IAS CUSTOMER ASREN #UK-ASREN-IAS IASGWS $GS-00547 | ASN199354 |",
+    "circuits": [
+      {
+        "id": 661220,
+        "name": "UK-ASREN-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 607,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ASREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "1/x1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02347 | RIG-TAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "RIG-TAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "RIG-TAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/5.1000",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT SINGAREN #UK-SINGAREN $GS-00923 | ASN136968 | UK-SINGAREN",
+    "circuits": [
+      {
+        "id": 661473,
+        "name": "UK-SINGAREN",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 751,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4091",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-ICT-ExpressRoute-Vlan4091 $GS-01125 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739679,
+        "name": "BELNET-ICT-EXPRESSROUTE-VLAN4091",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1675,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.2701",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER BELNET #SLCIMEC-02486 $GS-02486",
+    "circuits": [
+      {
+        "id": 745342,
+        "name": "SLCIMEC-02486",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 736,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 658,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-8/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | QSFP56-DD-400GBASE-DR4 installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1013,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae24.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/1/7"
+    ],
+    "description": "SRV_IAS PRIVATE ORACLE #UK-ORACLE-31898 $GS-00624 | ASN31898 |",
+    "circuits": [
+      {
+        "id": 719260,
+        "name": "UK-ORACLE-31898",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 976,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "ORACLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae6",
+    "bundle": [
+      "et-5/1/2",
+      "et-5/1/5",
+      "et-10/0/2",
+      "et-10/0/5"
+    ],
+    "bundle-parents": [
+      "et-5/1/2",
+      "et-5/1/5",
+      "et-10/0/2",
+      "et-10/0/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02204 | BIL-MAD | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 620,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-MAD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-MAD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-1/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 675,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC P_AE10 SRF24022 | JISC-AP1-LL4 | JISC ID: 22820799",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1557,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "et-3/3/0"
+    ],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "LAG CUSTOMER KIFU AP1 SRF19047 $GA-01905 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 642,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.205",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #FLOWMON-DDOS-FRA-DE-MANAGEMENT | FlowMon Management CONTACT: evangelos.spatharas@geant.org IMPLEMENTED: 20170910",
+    "circuits": [
+      {
+        "id": 732620,
+        "name": "FLOWMON-DDOS-FRA-DE-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1408,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae33.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/2/6",
+      "xe-4/3/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | NEMO DDOS Detection 1",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1049,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae10.114",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ORACLE CERN #fra-gen-ORACLE-CERN-20094 $GS-00698 |",
+    "circuits": [
+      {
+        "id": 705442,
+        "name": "FRA-GEN-ORACLE-CERN-20094",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 907,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ORACLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Was DE-CIX",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 653,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.2698",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA | deltaId+1e2911d9-39e2-4d23-a914-cc10de75732c:uuid+3059a3f6-605d-49a2-8630-d3c42195cb88 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1540,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c9/2",
+      "1/1/c12/1",
+      "1/1/c12/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #VIE-VIE-IPTRUNK $GS-02563 | VIE-VIE | VIE-VIE-MGMT",
+    "circuits": [
+      {
+        "id": 740752,
+        "name": "VIE-VIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "VIE-VIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "VIE-VIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE EXOSCALE-2 P_AE24 | Interxion CID: DE107460 | ASN61098",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 882,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae30.106",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ESNET #NL-ESNET-IPV6 $GS-00890 | ASN293 | AMS-ESNET-400G",
+    "circuits": [
+      {
+        "id": 734114,
+        "name": "NL-ESNET-IPV6",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1032,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae30.3007",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/0/5",
+      "xe-4/1/2",
+      "xe-4/2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #INFOBLOX-VPAR-PAR-FR $GS-00205 | Infoblox vPAR",
+    "circuits": [
+      {
+        "id": 712154,
+        "name": "INFOBLOX-VPAR-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1014,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae1.50",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/0",
+      "xe-1/2/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #Dashboard-server-lon2-vlan50_ | DBOARD",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 885,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c11/1",
+      "1/1/c11/2",
+      "1/1/c12/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MAR-MIL2-IPTRUNK $GS-01185 | MAR-MIL2 | MAR-MIL2",
+    "circuits": [
+      {
+        "id": 746147,
+        "name": "MAR-MIL2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MIL2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MIL2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae30.2001",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS SUPERPOP #ESXI-Management-Fra $GS-00073 | ESXI MANAGEMENT",
+    "circuits": [
+      {
+        "id": 733918,
+        "name": "ESXI-MANAGEMENT-FRA",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1127,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | DDOS Mitigation Server link 1 Node 2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1295,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-2/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 633,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-3/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE GOOGLE P_AE15",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 837,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/4.18",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #VIRGIN_MEDIA_EX1_LON2_TO_CAM_SRX_VLAN18-CH | ",
+    "circuits": [
+      {
+        "id": 662977,
+        "name": "VIRGIN_MEDIA_EX1_LON2_TO_CAM_SRX_VLAN18-CH",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 550,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-5/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE GOOGLE P_AE13  | Interxion CID DE236100-1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 829,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.2210",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 HBKU #lon-par-GEANTOPEN-HBKU-INTERNET2-190091 $GS-00967 |",
+    "circuits": [
+      {
+        "id": 736739,
+        "name": "LON-PAR-GEANTOPEN-HBKU-INTERNET2-190091",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1162,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "HBKU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.120",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL CUSTOMER EUMETSAT-SVALBARD #EUMET-SVALBARD-LON-MONITORINGVLAN $GS-02156 | NU-S800115 | - Monitoring Link 2",
+    "circuits": [
+      {
+        "id": 729170,
+        "name": "EUMET-SVALBARD-LON-MONITORINGVLAN",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 591,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "EUMETSAT-SVALBARD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EUMETSAT-SVALBARD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 518,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "irb.3004",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-CONTROL-RANCID-LOGICAL-INTERFACE-PAR-FR $GS-00865 | RANCID gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 712152,
+        "name": "TAAS-CONTROL-RANCID-LOGICAL-INTERFACE-PAR-FR",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 574,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1465,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "lag-5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #PRA-VIE-IPTRUNK $GS-00059 | PRA-VIE | ",
+    "circuits": [
+      {
+        "id": 740751,
+        "name": "PRA-VIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-VIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-VIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae5",
+    "bundle": [
+      "xe-3/2/8",
+      "xe-3/2/9"
+    ],
+    "bundle-parents": [
+      "xe-3/2/8",
+      "xe-3/2/9"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02588 | MAR-MAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 861,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-mgmt-bud.hu.geant.org pS MGMT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 941,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/24",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX01 NIC2 PORT3 - VSAN PORT",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 672,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE GOOGLE P_AE13 |Interxion CID - NL244649",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 678,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae19.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/2/4",
+      "xe-2/3/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | SPLUNK LON2 PEER02 MGMT | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 799,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "1/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | VIE-VIE | to MX1.VIE et-1/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900034,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "VIE-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "VIE-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae21",
+    "bundle": [
+      "et-7/1/0"
+    ],
+    "bundle-parents": [
+      "et-7/1/0"
+    ],
+    "description": "LAG PRIVATE T-SYSTEMS SRF22104 $GA-02272 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 714,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 609,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "1/x1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02425 | SOF-THE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-THE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-THE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.3914",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER NORDUNet MICROSOFT $GS-01160 | #NORDUNet-SUNET-ExpressRoute-VLAN3914 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 713462,
+        "name": "NORDUNET-SUNET-EXPRESSROUTE-VLAN3914",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 785,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.41",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEAZDELTA-02564 $GS-02564",
+    "circuits": [
+      {
+        "id": 744149,
+        "name": "MSEAZDELTA-02564",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1688,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1469,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 915,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-22.2603",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER RESTENA #RESTENA-AP2 $GS-00508 | ASN2602 | ",
+    "circuits": [
+      {
+        "id": 744073,
+        "name": "RESTENA-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "3",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RESTENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1047,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae1.991",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/1/1",
+      "xe-5/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-BUD-HU | ",
+    "circuits": [
+      {
+        "id": 739309,
+        "name": "DCN-MANAGEMENT-BUD-HU",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 897,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "et-3/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT BELLA P_AE11 SRF21059| #FOR-LIS-BELLA-100G | Circuit ID: BRFT1 PTLX1 100GE00001",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 704,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "BELLA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELLA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "1/x1/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER AMRES P_lag-21",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916418,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "AMRES",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMRES",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-5/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae6 | BIL-MAD |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 931,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "2/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | POZ-PRA | to RT1.PRA.CZ et-2/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162113,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0",
+      "xe-0/1/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BRA-BRA-MGMT-IPTRUNK $GS-02602| BRA-BRA | BRA-BRA-MGMT",
+    "circuits": [
+      {
+        "id": 743065,
+        "name": "BRA-BRA-MGMT-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 533,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae31",
+    "bundle": [
+      "xe-4/1/5"
+    ],
+    "bundle-parents": [
+      "xe-4/1/5"
+    ],
+    "description": "LAG PRIVATE ORANGE SRF21047 #FR-ORANGE-LAG-4 $GA-02145",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 993,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae27",
+    "bundle": [
+      "et-1/1/5",
+      "et-8/3/0"
+    ],
+    "bundle-parents": [
+      "et-1/1/5",
+      "et-8/3/0"
+    ],
+    "description": "LAG PRIVATE AKAMAI SRF9941087 $GA-01872 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 707,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-1/3/0",
+      "xe-1/3/1"
+    ],
+    "bundle-parents": [
+      "xe-1/3/0",
+      "xe-1/3/1"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 |mx1-sw2(ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 599,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.131",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ocvm-lon-uk | OC VM User Traffic",
+    "circuits": [
+      {
+        "id": 740698,
+        "name": "OCVM-LON-UK",
+        "type": "SERVER LINK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 693,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02340 | HAM-POZ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-POZ",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-POZ",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/0/2:2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 537,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.18",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet_Premier_ExpressRoute_VLAN4093 $GS-01127 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739681,
+        "name": "BELNET-PREMIER-EXPRESSROUTE-VLAN4093",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 600,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-20:2282",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER HEANET INTERNET2 #HEANET-00630 $GS-00630",
+    "circuits": [
+      {
+        "id": 747351,
+        "name": "HEANET-00630",
+        "type": "GEANT PLUS",
+        "status": "planned"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-4/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 924,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae7 | MIL2-MIL2 | RT0.MIL2.IT 1/1/c9/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 653,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.1500",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER UBUNTUNET NETHERLIGHT #AMS-LON-JIVE-NETHERLIGHT-UBUNTUNET-12008 $GS-00645 |",
+    "circuits": [
+      {
+        "id": 734613,
+        "name": "AMS-LON-JIVE-NETHERLIGHT-UBUNTUNET-12008",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1122,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-20:2112",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER LAT EENet #GENOMICS-00752 $GS-00752",
+    "circuits": [
+      {
+        "id": 745982,
+        "name": "GENOMICS-00752",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "EENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 577,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Was PSMP Server",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 594,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mad.es.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MAD-MAD-IPTRUNK $GS-02593 | MAD-MAD | MAD-MAD",
+    "circuits": [
+      {
+        "id": 742615,
+        "name": "MAD-MAD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/28",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX11 NIC1 PORT3 - VSAN PORT",
+    "circuits": [
+      {
+        "id": 658458,
+        "name": "LON2-PRD-ESX11-NIC1-PORT3",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 642,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 525,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.472",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER CERN RARE SRF223010 #AMS-GEN-CERN-RARE-123010 $GS-02262 |",
+    "circuits": [
+      {
+        "id": 736071,
+        "name": "AMS-GEN-CERN-RARE-123010",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1531,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE T-SYSTEMS P_AE25 Interxion CID: DE087499| AS6878",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 884,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-8/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COGENT SRF9943643 P_AE29 | Cogent ID: 3-001176142",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 988,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COGENT - VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT - VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/15",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY Surfnet Primary - Service ID: 3287IP1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 531,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae8",
+    "bundle": [
+      "et-0/0/1"
+    ],
+    "bundle-parents": [
+      "et-0/0/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01755 | BRA-VIE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 597,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-VIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-VIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.203",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ESNET #UK-ESNET-NEA3R-203 $GS-00918 | ASN293 | NEA3R-ESnet",
+    "circuits": [
+      {
+        "id": 661433,
+        "name": "UK-ESNET-NEA3R-203",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 854,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO NORDUnet #NORDUnet-GEO-UK-1 $GA-01447 |  SRF9928249 | NORDUNET 100G access to GeO",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1204,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE FW1-SNM",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1595,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 | mx1-sw1  (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1335,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-5/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | NEMO DDOS 100G #2 | Needs SR optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 836,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.32",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSETHOMASMORE-02475 $GS-02475",
+    "circuits": [
+      {
+        "id": 744238,
+        "name": "MSETHOMASMORE-02475",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1643,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 606,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "ae6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BRA-BUD-IPTRUNK $GS-00018| BRA-BUD",
+    "circuits": [
+      {
+        "id": 730086,
+        "name": "BRA-BUD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 603,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BUD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BUD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-21.1",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c18/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER AMRES #AMRES-AP1 $GS-00425 | ASN13092 | ",
+    "circuits": [
+      {
+        "id": 747837,
+        "name": "AMRES-AP1",
+        "type": "GEANT IP",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "12",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "AMRES",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMRES",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 932,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 578,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/4.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX1-AMS-TO-SWITCH-CLUSTER-VME0 |",
+    "circuits": [
+      {
+        "id": 708168,
+        "name": "SRX1-AMS-TO-SWITCH-CLUSTER-VME0",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 532,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae8.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BRA-VIE-IPTRUNK $GS-00019| BRA-VIE | ",
+    "circuits": [
+      {
+        "id": 740792,
+        "name": "BRA-VIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 614,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-VIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-VIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.11",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #GEANT-CORPORATE-ViaVodafone-VRF | GEANT Corporate to SRX2.CH - Via Vodafone - for VRF",
+    "circuits": [
+      {
+        "id": 740705,
+        "name": "GEANT-CORPORATE-VIAVODAFONE-VRF",
+        "type": "CORPORATE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 857,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae2.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/2/2",
+      "xe-3/2/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-LIS-PT $GS-00118 |",
+    "circuits": [
+      {
+        "id": 679548,
+        "name": "DCN-MANAGEMENT-LIS-PT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 735,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "2/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-9 | AMS-HAM | to AMS01-GRV5 1/1/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162113,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-HAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-HAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/7.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #par-lon2-SUPERPOP-QFX-2-GEANT $GS-00081 |",
+    "circuits": [
+      {
+        "id": 729417,
+        "name": "PAR-LON2-SUPERPOP-QFX-2-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 613,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "1/x1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | KAU-KAU | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915970,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-KAU",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-KAU",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae21",
+    "bundle": [
+      "et-5/0/4"
+    ],
+    "bundle-parents": [
+      "et-5/0/4"
+    ],
+    "description": "LAG CUSTOMER CERN #1 SRF20066 $GA-01876 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 711,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "xe-0/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | BUC-CHI | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 559,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01886 | GEN-MIL2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MIL2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MIL2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.802",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT RE_INTERCONNECT INTERNET2 UBUNTUNET #AMS-LON-MISC-UBUNTUNET-INTERNET2-170342 $GS-00647 |",
+    "circuits": [
+      {
+        "id": 735619,
+        "name": "AMS-LON-MISC-UBUNTUNET-INTERNET2-170342",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 823,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/0.472",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER CERN RARE SRF223010 #AMS-GEN-CERN-RARE-P4-123010 $GS-02262 |",
+    "circuits": [
+      {
+        "id": 736071,
+        "name": "AMS-GEN-CERN-RARE-123010",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 839,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | LJU-ZAG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916353,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "1/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | AMS-FRA | To  FRA01-GRV2- 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899777,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 605,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.10",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER FCCN MICROSOFT #FCCN-IPP-ExpressRoute-VLAN1946 $GS-01143 | MANUALLY MIGRATED FROM MX1.LIS TO RT1.POR 25/08/21",
+    "circuits": [
+      {
+        "id": 706996,
+        "name": "FCCN-IPP-EXPRESSROUTE-VLAN1946",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1394,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/6.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #fra-lon2-SUPERPOP-QFX-2-GEANT $GS00077 |",
+    "circuits": [
+      {
+        "id": 729418,
+        "name": "FRA-LON2-SUPERPOP-QFX-2-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1029,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "et-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 664,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | SOF-ZAG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916418,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.420",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NEA3R TENET #lon-lon-GEANTOPEN-NEA3R-TENET-18097 $GS-00971 |",
+    "circuits": [
+      {
+        "id": 718087,
+        "name": "LON-LON-GEANTOPEN-NEA3R-TENET-18097",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 789,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "TENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "1/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | LON-LON | to RT1.LON et-7/0/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900673,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "2/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | AMS-LON | to AMS01-GRV3 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161665,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RARE EDGECORE WEDGE100BF-32X xe-2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1262,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02194 |SCION server 2 external port",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1288,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01696 | LON2-PRD-ESX02 ESXI Traffic LAG - No LACP",
+    "circuits": [
+      {
+        "id": 658664,
+        "name": "LON2-PRD-ESX02-ESXI-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 592,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-101.991",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c2/1",
+      "1/1/c2/2"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-HAM-DE-VRF-VLAN991 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "17",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4084",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSESTADKORTRIJK-01138 $GS-01138",
+    "circuits": [
+      {
+        "id": 744150,
+        "name": "MSESTADKORTRIJK-01138",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.2016",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT REDCLARA #REDCLARA-PAR-LHCONE-2 $GS-00846 | ASN27750",
+    "circuits": [
+      {
+        "id": 736738,
+        "name": "REDCLARA-PAR-LHCONE-2",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1157,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 585,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "ae6",
+    "bundle": [
+      "et-0/0/1"
+    ],
+    "bundle-parents": [
+      "et-0/0/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01756 | BRA-BUD",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 601,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BUD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BUD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "2/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | LJU-MIL2 | to RT1.LJU.SI et-2/1/5 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162177,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae30.3004",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/0/5",
+      "xe-4/1/2",
+      "xe-4/2/2"
+    ],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-CONTROL-RANCID-PAR-FR $GS-00865 | RANCID gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 712152,
+        "name": "TAAS-CONTROL-RANCID-LOGICAL-INTERFACE-PAR-FR",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1474,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 596,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae30.1220",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ESNET RENATER #AMS-PAR-INFINICORTEX-ESNET-RENATER-15030 $GS-00653 |",
+    "circuits": [
+      {
+        "id": 734115,
+        "name": "AMS-PAR-INFINICORTEX-ESNET-RENATER-15030",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1034,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE IT_INFRA | to QFX xe-0/0/18",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1314,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.7",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #NTP6.GEANT.NET |",
+    "circuits": [
+      {
+        "id": 736081,
+        "name": "NTP6.GEANT.NET",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1513,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae20.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_IAS PUBLIC MIX #IX-Peerings-in-MIX $GS-00952 |",
+    "circuits": [
+      {
+        "id": 708323,
+        "name": "IX-PEERINGS-IN-MIX",
+        "type": "IP PEERING - NON R&E (PUBLIC)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 695,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PUBLIC"
+    ],
+    "dashboard_info": {
+      "name": "MIX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Reserved for GTS Expansion",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 603,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/3.100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX1-AMS-VLAN100-TO-SURFNET-VIA-MX1 | Surfnet Service ID: 5836",
+    "circuits": [
+      {
+        "id": 662997,
+        "name": "SRX1-AMS-VLAN100-TO-SURFNET-VIA-MX1",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 522,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "et-0/0/3"
+    ],
+    "bundle-parents": [
+      "et-0/0/3"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02045 | KIE-KIE|",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 585,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-KIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-KIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/3/2.100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT UBUNTUNET #UK-UBUNTUNET $GS-00909 | ASN36944 |",
+    "circuits": [
+      {
+        "id": 661682,
+        "name": "UK-UBUNTUNET",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1564,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-7/0/4",
+      "et-7/1/4"
+    ],
+    "bundle-parents": [
+      "et-7/0/4",
+      "et-7/1/4"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02462 | GEN-GEN",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 652,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-GEN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-GEN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER NETHERLIGHT #ams-lon-LOFAR-NETHERLIGHT-JISC-10007 $GS-00783",
+    "circuits": [
+      {
+        "id": 711990,
+        "name": "AMS-LON-LOFAR-NETHERLIGHT-JISC-10007",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1058,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/6.2702",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION EENET #fra-tar-SCION-EENET $GS-02357 | ",
+    "circuits": [
+      {
+        "id": 746442,
+        "name": "FRA-TAR-SCION-EENET",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1337,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.2710",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER ESnet #lon-poz-PIONIER-ESnet-Quantum-Demo-VL2710 $GS-02557 |",
+    "circuits": [
+      {
+        "id": 739897,
+        "name": "LON-POZ-PIONIER-ESNET-QUANTUM-DEMO-VL2710",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 856,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.206",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #SCION-fra-de  | SCION SERVERS",
+    "circuits": [
+      {
+        "id": 732657,
+        "name": "SCION-FRA-DE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1409,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 688,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.por.pt.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "1/x1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02586 | POR-POR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POR-POR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "POR-POR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1  | mx1-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 921,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-2/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | BUC-CHI | ROEDUNET CID: BUC-CHI-040-2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 552,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "1/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | FRA-GEN | to GEN01-GRV2 port 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899521,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/6.107",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF SRF21106 #PRA-POZ-RARE-BMS9 $GS-00751",
+    "circuits": [
+      {
+        "id": 737234,
+        "name": "PRA-POZ-RARE-BMS9",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 974,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT ASNET-TW $GA-01635 | Digital Reality CID: NL265320",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 648,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ASNET-TW",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASNET-TW",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae42",
+    "bundle": [
+      "xe-0/2/3",
+      "xe-0/2/4"
+    ],
+    "bundle-parents": [
+      "xe-0/2/3",
+      "xe-0/2/4"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 2 | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1325,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.1626",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 SCION #fra-par-SCION-SCION-INTERNET2-2 $GS-02310 |",
+    "circuits": [
+      {
+        "id": 736666,
+        "name": "FRA-PAR-SCION-SCION-INTERNET2-2",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1146,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/4.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #PSMP-LHC-MANAGEMENT-LON-UK-VLAN0 | psmp-lhc-mgmt-lon-uk.geant.org pS MGMT (LHCONE)",
+    "circuits": [
+      {
+        "id": 708184,
+        "name": "PSMP-LHC-MANAGEMENT-LON-UK-VLAN0",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1001,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.3917",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #NORDUNET-FUNET-ExpressRoute-VLAN3917 $GS-02327 | ",
+    "circuits": [
+      {
+        "id": 727782,
+        "name": "NORDUNET-FUNET-EXPRESSROUTE-VLAN3917",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1253,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae10.4006",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-5/0/2",
+      "et-9/0/5",
+      "et-11/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC NKN #AMS-LON-5GUK-JISC-NKN-22048 $GS-02162 | ",
+    "circuits": [
+      {
+        "id": 719849,
+        "name": "AMS-LON-5GUK-JISC-NKN-22048",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1186,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NKN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-1/0/2",
+      "et-1/0/5",
+      "et-1/1/2"
+    ],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-1/0/5",
+      "et-1/1/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02561 | VIE-VIE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 752,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "VIE-VIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "VIE-VIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 617,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4086",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS Customer BELNET MICROSOFT #BELNET-THOMASMORE-ExpressRoute-VLAN4086 $GS-02476  | ",
+    "circuits": [
+      {
+        "id": 739668,
+        "name": "BELNET-THOMASMORE-EXPRESSROUTE-VLAN4086",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1671,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae10.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/1"
+    ],
+    "description": "SRV_IAS CUSTOMER RENAM #RENAM-AP1-IAS IASGWS $GS-00541 | ASN9199",
+    "circuits": [
+      {
+        "id": 714070,
+        "name": "RENAM-AP1-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 566,
+    "dashboards": [
+      "EAP",
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "2/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | FRA-GEN | TO FRA01-GRV1  port 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162241,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c8/1",
+      "1/x1/1/c8/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #SOF-ZAG-IPTRUNK $GS-02367 | SOF-ZAG | ",
+    "circuits": [
+      {
+        "id": 747867,
+        "name": "SOF-ZAG-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-ZAG",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-ZAG",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE7     | LON2-PRD-ESX11 NIC1 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 521,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.208",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ddos-mit1-fra-de-idrac | NEMO DDOS Mitigation 1 iDRAC | ",
+    "circuits": [
+      {
+        "id": 732632,
+        "name": "DDOS-MIT1-FRA-DE-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1410,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 752,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae41",
+    "bundle": [
+      "xe-0/2/1",
+      "xe-0/2/2"
+    ],
+    "bundle-parents": [
+      "xe-0/2/1",
+      "xe-0/2/2"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1324,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.2013",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT ESNET #ESNET-NEA3R-LON-LHCONE $GS-00822 | ASN293",
+    "circuits": [
+      {
+        "id": 709643,
+        "name": "ESNET-NEA3R-LON-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 877,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae5",
+    "bundle": [
+      "et-5/0/2",
+      "et-9/0/2",
+      "et-9/0/5",
+      "et-9/1/2"
+    ],
+    "bundle-parents": [
+      "et-5/0/2",
+      "et-9/0/2",
+      "et-9/0/5",
+      "et-9/1/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02010 | MAD-MAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 619,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/0/1:3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 531,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.12",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-KNMI $GS-01083",
+    "circuits": [
+      {
+        "id": 732663,
+        "name": "GRE-MULTICAST-TUNNEL-KNMI",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1215,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1043,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/17",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE18    | LON2-PRD-ESX12 NIC1 PORT2",
+    "circuits": [
+      {
+        "id": 658495,
+        "name": "LON2-PRD-ESX12-NIC1-PORT2",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 532,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-lhc-mgmt-par-fr.geant.org  pS MGMT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1200,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae17",
+    "bundle": [
+      "et-10/0/5"
+    ],
+    "bundle-parents": [
+      "et-10/0/5"
+    ],
+    "description": "LAG CUSTOMER SURF GEO SRF18071 $GA-01819 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 689,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "lag-5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-AMS-IPTRUNK $GS-02458 | AMS-AMS | AMS-AMS-NOKIA",
+    "circuits": [
+      {
+        "id": 735616,
+        "name": "AMS-AMS-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae17.3901",
+    "bundle": [],
+    "bundle-parents": [
+      "et-10/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #par-par-GEANTOpen-SINET-SINET-19033 $GS-00987 |",
+    "circuits": [
+      {
+        "id": 706599,
+        "name": "PAR-PAR-GEANTOPEN-SINET-SINET-19033",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1485,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "2/x1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02426 | SOF-THE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-THE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-THE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1272,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.2031",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET ESNET #lon-lon-GEANTOpen-ESnet-NORDUNET-15039-3 $GS-00965 |",
+    "circuits": [
+      {
+        "id": 738641,
+        "name": "LON-LON-GEANTOPEN-ESNET-NORDUNET-15039-3",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1276,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-21.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER LITNET #LITNET-AP1 $GS-00486 | ASN2847 | ",
+    "circuits": [
+      {
+        "id": 746528,
+        "name": "LITNET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LITNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LITNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | GEN-MIL2 | to RT0.GEN.CH 1/1/c8/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899970,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 640,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/2/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-fra-de-management LHC new |perfSONAR MGMT",
+    "circuits": [
+      {
+        "id": 729060,
+        "name": "PS-FRA-DE-MANAGEMENT-BWCTL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 546,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/3/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 610,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-DUB-IE-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "9",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "ae13.421",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "SRV_IAS CUSTOMER SANET #SANET-AP2-IAS IASPS $GS-02439 | ASN2607 |",
+    "circuits": [
+      {
+        "id": 733192,
+        "name": "SANET-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 618,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae15",
+    "bundle": [
+      "et-9/1/5"
+    ],
+    "bundle-parents": [
+      "et-9/1/5"
+    ],
+    "description": "LAG RE_INTERCONNECT COPERNICUS SRF21068 $GA-02004 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 653,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "COPERNICUS",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "COPERNICUS",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.2126",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER CERN CANARIE #lon-par-Canarie-CERN-15014 $GS-00720 |",
+    "circuits": [
+      {
+        "id": 736734,
+        "name": "LON-PAR-CANARIE-CERN-15014",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1589,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "ae2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUC-BUC-IPTRUNK $GS-50060| BUC-BUC | BUC-BUC",
+    "circuits": [
+      {
+        "id": 745576,
+        "name": "BUC-BUC-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 631,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-9/0/4",
+      "et-9/1/4"
+    ],
+    "bundle-parents": [
+      "et-9/0/4",
+      "et-9/1/4"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02471 | PAR-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1179,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PAR-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "PAR-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "xe-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 560,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 618,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 549,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:3503",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER BELNET #SLCIMEC-02486 $GS-02486",
+    "circuits": [
+      {
+        "id": 745342,
+        "name": "SLCIMEC-02486",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | mx1-sw2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1267,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-21.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_IAS CUSTOMER LITNET #LITNET-AP1-IAS IASGWS $GS-00534 | ASN2847 | ",
+    "circuits": [
+      {
+        "id": 746533,
+        "name": "LITNET-AP1-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "7",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "LITNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LITNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae13.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/2/2"
+    ],
+    "description": "SRV_IAS PRIVATE GOOGLE #GOOGLE-15169-NL $GS-02451 | ASN15169",
+    "circuits": [
+      {
+        "id": 733783,
+        "name": "GOOGLE-15169-NL",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 996,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "GOOGLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GOOGLE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-23.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c2/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #HAM-DTN-10G-DATA $GS-02433",
+    "circuits": [
+      {
+        "id": 747638,
+        "name": "HAM-DTN-10G-DATA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "15",
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/8.12",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRV_CORPORATE CUSTOMER GEANT_INTERNAL #DASHBOARD-TEST-SERVICE-LON-VODAFONE(DO-NOT-OPEN-TICKET)|",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 522,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae6",
+    "bundle": [
+      "et-7/1/5"
+    ],
+    "bundle-parents": [
+      "et-7/1/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01910 | BRA-BUD",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 828,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BUD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BUD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae19.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2"
+    ],
+    "description": "SRV_IAS CUSTOMER UOM #UOM-AP2-100G-IAS IASGWS $GS-02165 | ASN12046 | ",
+    "circuits": [
+      {
+        "id": 720397,
+        "name": "UOM-AP2-100G-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 627,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "UOM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UOM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae12.4087",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/5",
+      "et-8/0/5",
+      "et-11/0/2"
+    ],
+    "description": "SRV_GCS CUSTOMER GARR MICROSOFT #GARR-UDMilano-ExpressRoute-Vlan4087 $GS-01146 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707644,
+        "name": "GARR-UDMILANO-EXPRESSROUTE-VLAN4087",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 639,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "ae10.360",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/1",
+      "xe-0/1/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER URAN #URAN-AP1-LHCONE $GS-00870 | ASN12687 |",
+    "circuits": [
+      {
+        "id": 714002,
+        "name": "URAN-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 590,
+    "dashboards": [
+      "EAP",
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bud.hu.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "2/x1/1/c9/2"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c9/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02595 | BUD-BUD",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-BUD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-BUD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/24",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX01 NIC1 PORT3 - VSAN PORT",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 640,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "2/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | LON-LON | to RT1.LON et-7/1/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162817,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 584,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-22.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_IAS CUSTOMER CARNET #CARNET-AP1-IAS IASPS $GS-00559 | ASN2108 | ",
+    "circuits": [
+      {
+        "id": 747859,
+        "name": "CARNET-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "16",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/2/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 601,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #PAR-PAR-IPTRUNK $GS-02473 | PAR-PAR | RT0.PAR-MX1.PAR IPTRUNK",
+    "circuits": [
+      {
+        "id": 739437,
+        "name": "PAR-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PAR-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PAR-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.2702",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER BELNET #SLCIMEC-02487 $GS-02487",
+    "circuits": [
+      {
+        "id": 745329,
+        "name": "SLCIMEC-02487",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 762,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae11",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01683 | FRA-PRD-ESX03 VM Traffic LAG",
+    "circuits": [
+      {
+        "id": 658655,
+        "name": "FRANKFURT 15-FRANKFURT 15-LAG-052(GEANT)",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 580,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4060",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS Customer BELNET MICROSOFT #BELNET-STAD-EXPRESSROUTE-VLAN4060 $GS-02246  | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739667,
+        "name": "BELNET-STAD-EXPRESSROUTE-VLAN4060",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1656,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "2/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | AMS-LON | to AMS01-GRV3 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161921,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 824,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae3.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-BRA1-SK $GS-00114 | DCN MANAGEMENT ",
+    "circuits": [
+      {
+        "id": 731614,
+        "name": "DCN-MANAGEMENT-BRA1-SK",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 621,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-2/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT SINET P_AE20 | Digital Realty CID: NL116823-4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 955,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "1/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915969,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-3/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENATER P_AE12 | RENATER-AP1-4 | DR Circuit ID: FR247487",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 854,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 550,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/2.559",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SWITCH GEANT #fra-gen-SWITCH-RARE-21035 $GS-00700 |",
+    "circuits": [
+      {
+        "id": 709921,
+        "name": "FRA-GEN-SWITCH-RARE-21035",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1448,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae28",
+    "bundle": [
+      "et-11/0/5"
+    ],
+    "bundle-parents": [
+      "et-11/0/5"
+    ],
+    "description": "LAG RE_INTERCONNECT TENET SRF21083 $GA-02014 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 724,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "TENET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.1916",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE INTERNET2-RNP #AMS-PAR-RARE-INTERNET2-RNP-20061 $GS-00655 |",
+    "circuits": [
+      {
+        "id": 736072,
+        "name": "AMS-PAR-RARE-INTERNET2-RNP-20061",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1087,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-10/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | SUSPECTED FAULTY SLOT",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 911,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae1.521",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/0",
+      "xe-1/2/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #snm-switch-mgmt $GS-00151 | IT Refresh QFX MGMT",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 844,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-5",
+    "bundle": [
+      "1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02479 | COR-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177285,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae19",
+    "bundle": [
+      "xe-11/1/3",
+      "xe-11/1/4"
+    ],
+    "bundle-parents": [
+      "xe-11/1/3",
+      "xe-11/1/4"
+    ],
+    "description": "LAG PRIVATE ORACLE SRF19090 #1 $GA-01941 | FastConnect CERN ONLY",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1052,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "xe-3/0/8",
+      "xe-3/2/0"
+    ],
+    "bundle-parents": [
+      "xe-3/0/8",
+      "xe-3/2/0"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 |rt1-sw2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 601,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-par-fr.geant.org pS OWAMP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1283,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "1/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915972,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae13.40",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-10/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SWITCH NETHERLIGHT #AMS-PAR-SCION-SWITCH-NETHERLIGHT-20019 $GS-00658 |",
+    "circuits": [
+      {
+        "id": 714175,
+        "name": "AMS-PAR-SCION-SWITCH-NETHERLIGHT-20019",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 729,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "et-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE1 | KIE-KIE | KIE-KIE-IP1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 610,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-KIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-KIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.18",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEPREMIER-01137 $GS-01137",
+    "circuits": [
+      {
+        "id": 744264,
+        "name": "MSEPREMIER-01137",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1401,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "2/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | LON2-PAR | TO GRV2.LON2 - 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161921,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01672 | MX AE30",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 573,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS | QFX1 C0 MGMT",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 521,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae27",
+    "bundle": [
+      "xe-10/2/0"
+    ],
+    "bundle-parents": [
+      "xe-10/2/0"
+    ],
+    "description": "LAG RE_INTERCONNECT MAEEN SRF21017 $GA-02005 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 723,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "MAEEN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAEEN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/6.1626",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION INTERNET2 #fra-par-SCION-SCION-INTERNET2-2 $GS-02310 |",
+    "circuits": [
+      {
+        "id": 736666,
+        "name": "FRA-PAR-SCION-SCION-INTERNET2-2",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1331,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-10/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER SWITCH P_AE13 SRF19148 | Circuit ID : CE4 Hu0/0/0/7 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 997,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae49",
+    "bundle": [
+      "et-2/1/1"
+    ],
+    "bundle-parents": [
+      "et-2/1/1"
+    ],
+    "description": "LAG PRIVATE GOOGLE $GA-01943 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1440,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/27",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX10 NIC2 PORT3 - VSAN PORT",
+    "circuits": [
+      {
+        "id": 658552,
+        "name": "LON2-PRD-ESX10-NIC2-PORT3",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 675,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae17.200",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-1/1/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER CERN #CERN-AP1 $GS-00442 | ASN513 |",
+    "circuits": [
+      {
+        "id": 662952,
+        "name": "CERN-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 920,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-1/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae7 | MIL2-MIL2 | RT0.MIL2.IT 2/1/c9/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 660,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "xe-0/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENAM | Prime Telecom CID: 1022641",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 569,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-20.1",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c11/1",
+      "1/1/c11/2",
+      "1/1/c12/1",
+      "1/1/c12/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER JISC #JISC-AP2 $GS-00480 | ASN786 | ",
+    "circuits": [
+      {
+        "id": 743310,
+        "name": "JISC-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-3/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER SWITCH P_AE23  |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1184,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae10.4086",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-2/1/5",
+      "et-11/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER GARR MICROSOFT #GARR-UDMilano_ExpressRoute_Vlan4086 $GS-01148 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707643,
+        "name": "GARR-UDMILANO_EXPRESSROUTE_VLAN4086",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 795,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-8/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 993,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | SOF-ZAG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916417,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c2/1",
+      "1/1/c2/2"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-HAM-DE-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "18",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae15.52",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/0"
+    ],
+    "description": "SRV_IAS CUSTOMER ACONET #ACONET-AP1-IAS IASPS $GS-00550 | ASN1853",
+    "circuits": [
+      {
+        "id": 661622,
+        "name": "ACONET-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 830,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ACONET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ACONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/25",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX02 NIC1 PORT3 - VSAN PORT",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 644,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/3.2704",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION EENET #lon-par-SCION-WACREN $GS-02495 | ",
+    "circuits": [
+      {
+        "id": 737889,
+        "name": "LON-PAR-SCION-WACREN",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1213,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/1/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-ams-nl-owamp new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 736110,
+        "name": "PS-AMS-NL-OWAMP",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1525,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/0/2.500",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF #BUD-POZ-RARE-BMS8 $GS-02629",
+    "circuits": [
+      {
+        "id": 744388,
+        "name": "BUD-POZ-RARE-BMS8",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 954,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae12.4089",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/5",
+      "et-8/0/5",
+      "et-11/0/2"
+    ],
+    "description": "SRV_GCS CUSTOMER GARR MICROSOFT #GARR-ROMA-ExpressRoute-Vlan4089 $GS-01145 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707342,
+        "name": "GARR-ROMA-EXPRESSROUTE-VLAN4089",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 630,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-20.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c18/2",
+      "1/x1/1/c24/1",
+      "1/x1/1/c24/2"
+    ],
+    "description": "SRV_IAS CUSTOMER ARNES #ARNES-AP2-IAS IASPS $GS-00553 | ASN2107 | ",
+    "circuits": [
+      {
+        "id": 747852,
+        "name": "ARNES-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "10",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-8",
+    "bundle": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01824 | LON2-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177288,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1276,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-3/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 698,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE5     | LON2-PRD-ESX21 NIC2 PORT3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 662,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.1304",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KREONET SWITCH #ams-fra-SCION-KREONET-SWITCH $GS-02292 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1742,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 594,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "2/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | BIL-PAR | to RT1.BIL.ES - et-1/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162113,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "2/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | MIL2-MIL2 | to RT1.MIL2.IT et-1/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162178,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4090",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEARTEV-01131 $GS-01131",
+    "circuits": [
+      {
+        "id": 744265,
+        "name": "MSEARTEV-01131",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae13.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT ESNET #ESNET-GEN-LHCONE $GS-00820 | ASN293",
+    "circuits": [
+      {
+        "id": 730103,
+        "name": "ESNET-GEN-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1286,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "et-4/1/2"
+    ],
+    "bundle-parents": [
+      "et-4/1/2"
+    ],
+    "description": "LAG CUSTOMER FCCN SRF9928599 $GA-01786 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 570,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "2/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | GEN-MAR | to to RT1.MAR et-2/1/5 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162178,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.401",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT RE_INTERCONNECT CANARIE UBUNTUNET #lon-lon-MISC-UBUNTUNET-CANARIE-170351 $GS-00727 |",
+    "circuits": [
+      {
+        "id": 709304,
+        "name": "LON-LON-MISC-UBUNTUNET-CANARIE-170351",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 797,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "irb.521",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-AMS-NL-VRF-VLAN521 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1588,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1470,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4064",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSENCCN-02370 $GS-02370",
+    "circuits": [
+      {
+        "id": 744141,
+        "name": "MSENCCN-02370",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.620",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET RNP #IMINDS-00680 $GS-00680",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1096,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "xe-0/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 559,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915969,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-20.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4",
+      "1/x1/1/c4/1",
+      "1/x1/1/c4/2",
+      "1/x1/1/c4/3",
+      "1/x1/1/c4/4"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER GRNET #GRNET-AP2 $GS-00472 | ASN5408 | ",
+    "circuits": [
+      {
+        "id": 745279,
+        "name": "GRNET-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/1/2",
+      "et-5/1/5",
+      "et-10/0/2",
+      "et-10/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BIL-MAD-IPTRUNK $GS-02203 | BIL-MAD |",
+    "circuits": [
+      {
+        "id": 719646,
+        "name": "BIL-MAD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1134,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-MAD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-MAD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-10/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO WACREN #WACREN-GEO-UK-1 P_AE22 | SRF43753 ID: SN-20858588 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 904,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "WACREN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE - Unused - Was cbg-lon Virgin-Media ID CAL0151087 - Removed 07/08/19",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 606,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 520,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 583,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "2/x1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | ZAG-ZAG | TO MX2.ZAG.HR-et-4/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178561,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ZAG-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ZAG-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | PRA BMS Server 8",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 544,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-5/0/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #fra-par-SUPERPOP-QFX-2-GEANT $GS-00079 |",
+    "circuits": [
+      {
+        "id": 729480,
+        "name": "FRA-PAR-SUPERPOP-QFX-2-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 978,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "1/x1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915970,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 935,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 888,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae40.416",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ORACLE PIONIER SRF23002 #fra-poz-ORACLE-PIONIER-23002-VL416 $GS-02243",
+    "circuits": [
+      {
+        "id": 726355,
+        "name": "FRA-POZ-ORACLE-PIONIER-23002-VL416",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1060,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ORACLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-8/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | BUD-VIE | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1145,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae12",
+    "bundle": [
+      "et-2/0/2"
+    ],
+    "bundle-parents": [
+      "et-2/0/2"
+    ],
+    "description": "LAG PUBLIC AMS-IX $GA-01920 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1336,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae11",
+    "bundle": [
+      "et-4/0/4"
+    ],
+    "bundle-parents": [
+      "et-4/0/4"
+    ],
+    "description": "LAG CUSTOMER DFN $GA-01957 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 780,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4069",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEHOGENT-02573 $GS-02573",
+    "circuits": [
+      {
+        "id": 744239,
+        "name": "MSEHOGENT-02573",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.14",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-JPL $GS-01081",
+    "circuits": [
+      {
+        "id": 732677,
+        "name": "GRE-MULTICAST-TUNNEL-JPL",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1217,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/3.996",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #City-House-Lab-Infinera-MGMT-Network |",
+    "circuits": [
+      {
+        "id": 663240,
+        "name": "CITY-HOUSE-LAB-INFINERA-MGMT-NETWORK",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 553,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.340",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_IAS CUSTOMER REDIRIS #REDIRIS-AP2-IAS IASPS $GS-00582 | ASN766",
+    "circuits": [
+      {
+        "id": 718228,
+        "name": "REDIRIS-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 812,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 604,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/6.106",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF SRF21106 $GS-00687 | #BUD-PRA-RARE-BMS5",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 969,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-10/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | QSFP-100GBASE  optic installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1562,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:3502",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER PRO-M/NIIF BELNET #SLCIMEC-02511 $GS-02511",
+    "circuits": [
+      {
+        "id": 744362,
+        "name": "SLCIMEC-02511",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PRO-M/NIIF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRO-M/NIIF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 562,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 518,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | RARE EDGECORE WEDGE100BF-32X xe-1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 684,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae13.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-10/0/2"
+    ],
+    "description": "SRV_IAS CUSTOMER SWITCH #SWITCH-AP2-IAS IASPS $GS-00590 | ASN559",
+    "circuits": [
+      {
+        "id": 661345,
+        "name": "SWITCH-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 612,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1305,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CARNET P_lag-22",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917505,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CARNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CARNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "1/x1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | COR-PAR | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916417,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae10.2300",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CSTNET CERN #ams-gen-IHEP-CERN-CSTNET $GS-02415 |",
+    "circuits": [
+      {
+        "id": 740995,
+        "name": "AMS-GEN-IHEP-CERN-CSTNET",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1494,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CSTNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CSTNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "ae1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #KIE-KIE-IPTRUNK $GS-00045 | KIE-KIE |",
+    "circuits": [
+      {
+        "id": 713325,
+        "name": "KIE-KIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 583,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-KIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-KIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/2/3.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-fra-de-bwctl LHC new | BWCTL CONTACT: ivan.garnizov@fau.de IMPLEMENTED: 20160524",
+    "circuits": [
+      {
+        "id": 729062,
+        "name": "PS-FRA-DE-BWCTL-LHCONE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 551,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae17.333",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/3/4"
+    ],
+    "description": "SRV_IAS CUSTOMER ASNET-AM #ASNET-AM-AP1-IAS IASPS $GS-00555 | ASN47623 |",
+    "circuits": [
+      {
+        "id": 732137,
+        "name": "ASNET-AM-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1171,
+    "dashboards": [
+      "EAP",
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ASNET-AM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASNET-AM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae14.600",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SWITCH AMS-IX #AMS-GEN-NREN-IX-AMSIX-SWITCH-18008 $GS-00638 |",
+    "circuits": [
+      {
+        "id": 734173,
+        "name": "AMS-GEN-NREN-IX-AMSIX-SWITCH-18008",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1041,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-IX",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.11",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #Nordunet_LTU_ExpressRoute_Vlan3909 $GS-01153 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707121,
+        "name": "NORDUNET-LTU-EXPRESSROUTE-VLAN3909",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 594,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ge-1/0/36",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX10 IDRAC",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 689,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/2/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 586,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-8/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS IT REFRESH P_AE32 | qfx1.ams.nl et-1/0/52",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1274,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "2/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | LJU-ZAG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178497,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 899,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae1.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/3/0",
+      "xe-1/3/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-poz1-pl| SW1-EX3400-POZ1 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 724825,
+        "name": "EX3400-MANAGEMENT-POZ1-PL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 822,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/1/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BRA-BUD-IPTRUNK $GS-00018| BRA-BUD",
+    "circuits": [
+      {
+        "id": 730086,
+        "name": "BRA-BUD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 829,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BUD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BUD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915971,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae7.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-1/0/5",
+      "et-1/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MIL2-MIL2-IPTRUNK $GS-02548| MIL2-MIL2 | MIL2-MIL2-MGMT",
+    "circuits": [
+      {
+        "id": 740951,
+        "name": "MIL2-MIL2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 754,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-MIL2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-MIL2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-5/0/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": " SRV_10GGBS CUSTOMER GEANT-IT #fra-par-SUPERPOP-QFX-GEANT $GS-00078 |",
+    "circuits": [
+      {
+        "id": 729477,
+        "name": "FRA-PAR-SUPERPOP-QFX-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 977,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | RARE EDGECORE WEDGE100BF-32X xe-0",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1442,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/0/2.107",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF SRF21106 #PRA-POZ-RARE-BMS9 $GS-00751",
+    "circuits": [
+      {
+        "id": 737234,
+        "name": "PRA-POZ-RARE-BMS9",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 804,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-3/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 767,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "1/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | GEN-PAR | Connected to PAR01.GRV2 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900097,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae30.3003",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-throughput-network-fra-de $GS-00299| Throughput network",
+    "circuits": [
+      {
+        "id": 733021,
+        "name": "PS-THROUGHPUT-NETWORK-FRA-DE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1131,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-50065 | KAU-KAU",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-KAU",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-KAU",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ge-0/0/37",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX02 IDRAC",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 554,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | LON2-PAR-QFX | to QFX xe-1/0/42",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1587,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "lag-8",
+    "bundle": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01915 | AMS-FRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177288,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae14",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01686 | QFX.LON2.UK AE30",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 583,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-20.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1",
+      "1/x1/1/c26/2"
+    ],
+    "description": "SRV_IAS CUSTOMER ARNES #ARNES-AP1-IAS IASPS $GS-00552 | ASN2107 | ",
+    "circuits": [
+      {
+        "id": 745717,
+        "name": "ARNES-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "7",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/0/2.1955",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER KIFU GEANT #bud-bud-KIFU-RARE-200100 $GS-00683 |",
+    "circuits": [
+      {
+        "id": 705914,
+        "name": "BUD-BUD-KIFU-RARE-200100",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 816,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae13.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-10/0/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER SWITCH #SWITCH-AP2 $GS-00515 | ASN559 |",
+    "circuits": [
+      {
+        "id": 661602,
+        "name": "SWITCH-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 811,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-9 | AMS-HAM | to RT0.AMS 2/1/C8/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899970,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-HAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-HAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #KIE-POZ-IPTRUNK $GS-00046| KIE-POZ | ",
+    "circuits": [
+      {
+        "id": 740201,
+        "name": "KIE-POZ-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 587,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-POZ",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-POZ",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-10/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER REDIRIS P_AE16 SRF23022 | CXC ID M21-12I-03-59 & 60  --P12 in ODF3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1048,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.2033",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET #lon-lon-GEANTOPEN-NORDUNET-WACREN-20041 $GS-00979 |",
+    "circuits": [
+      {
+        "id": 705942,
+        "name": "LON-LON-GEANTOPEN-NORDUNET-WACREN-20041",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 982,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "WACREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:3507",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDIRIS BELNET #SLCIMEC-02515 $GS-02515",
+    "circuits": [
+      {
+        "id": 745337,
+        "name": "SLCIMEC-02515",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | LON2-LON2 | to xe-1/2/9 MX1.LON2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899585,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "1/1/c12/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | VIE-VIE | to MX1.VIE et-1/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900225,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "VIE-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "VIE-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-2/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE CLOUDFERRO P_AE35 | Interxion CID: DE132127 | ASN200999",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 684,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae1.31",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/1/7",
+      "xe-2/2/7"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ESNET #Gen513-EEX-ESNET-1G $GA-01543",
+    "circuits": [
+      {
+        "id": 708305,
+        "name": "GEN513-EEX-ESNET-1G",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1487,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE FW1-SNM",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 664,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 810,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae41.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/2/1",
+      "xe-0/2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 MGMT | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1355,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.41",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-AZDELTA-ExpressRoute-VLAN4068 GS-02565 | ",
+    "circuits": [
+      {
+        "id": 740640,
+        "name": "BELNET-AZDELTA-EXPRESSROUTE-VLAN4068",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 684,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 608,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-1/0/45",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PSY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 658,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 691,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 524,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "gr-10/1/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN INFRASTRUCTURE ACCESS #FORTIGATE-TUNNEL-TO-CH-LON2-UK $GS-02124 | Tunnel to Fortigate CH",
+    "circuits": [
+      {
+        "id": 737548,
+        "name": "FORTIGATE-TUNNEL-TO-CH-LON2-UK",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 872,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "2/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER EENET P_lag-21",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611179649,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "EENET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EENET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 635,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae29",
+    "bundle": [
+      "xe-11/0/7",
+      "xe-11/1/2"
+    ],
+    "bundle-parents": [
+      "xe-11/0/7",
+      "xe-11/1/2"
+    ],
+    "description": "LAG UPSTREAM COLT $GA-02113 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1153,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "1/x1/1/c27/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ULAKBIM P_lag-23",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917569,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 647,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1476,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_IAS CUSTOMER PIONIER #PIONIER-AP1-IAS IASGWS $GS-00539 | ASN8501",
+    "circuits": [
+      {
+        "id": 660626,
+        "name": "PIONIER-AP1-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 789,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-20.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/4",
+      "1/x1/1/c4/1",
+      "1/x1/1/c4/2",
+      "1/x1/1/c4/3",
+      "1/x1/1/c4/4"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER GRNET #GRNET-AP1 $GS-00471 | ASN5408 | ",
+    "circuits": [
+      {
+        "id": 745493,
+        "name": "GRNET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "4",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 590,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 616,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-3/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER KIFU P_AE10 SRF19047 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 698,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-0/0/43",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae14    | 10_GBS to RT1 xe-7/0/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 692,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae11",
+    "bundle": [
+      "et-9/0/2",
+      "et-10/3/0"
+    ],
+    "bundle-parents": [
+      "et-9/0/2",
+      "et-10/3/0"
+    ],
+    "description": "LAG CUSTOMER SURF $GA-01844 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 707,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "irb.370",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN CUSTOMER SCION SRF22092 #SCION-SCION-FRA-INTERNAL-VPN-VL370 $GS-02216 |",
+    "circuits": [
+      {
+        "id": 732533,
+        "name": "SCION-SCION-FRA-INTERNAL-VPN-VL370",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1368,
+    "dashboards": [
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-5/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic present",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 677,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "2/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CYNET P_lag-23 | CYNET-GRIX",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178115,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CYNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CYNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS CORSA SRF0000001 | JRA MX to CORSA P4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1580,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "1/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | KAU-RIG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916353,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-RIG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-RIG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "et-10/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1159,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.936",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDIRIS GEANT #AMS-BIL-REDIRIS-RARE $GS-02287 |",
+    "circuits": [
+      {
+        "id": 736075,
+        "name": "AMS-BIL-REDIRIS-RARE",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 850,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "1/1/c12/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | MIL2-MIL2 | to RT1.MIL2.IT et-1/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900226,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS | mx1-sw2-1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1019,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 665,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1060,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-20:1213",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER HEANET RARE #RARE-00689 $GS-00689",
+    "circuits": [
+      {
+        "id": 747350,
+        "name": "RARE-00689",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/7.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-lon-uk-psmp-bwctl-lhcone | psmp-lhc-bw-lon-uk.geant.org pS BWCTL (LHCONE)",
+    "circuits": [
+      {
+        "id": 708314,
+        "name": "PS-LON-UK-PSMP-BWCTL-LHCONE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1478,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/2/3.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRENA COGENT #vie-vie-EAP-GRENA-COGENT-22035 $GS-00695",
+    "circuits": [
+      {
+        "id": 719668,
+        "name": "VIE-VIE-EAP-GRENA-COGENT-22035",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1089,
+    "dashboards": [
+      "EAP",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "GRENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1280,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 522,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.111",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN CUSTOMER NORDUNET #NORDUNET-AP1-IPv4-LHCONE $GS-00841 | ASN2603",
+    "circuits": [
+      {
+        "id": 661194,
+        "name": "NORDUNET-AP1-IPV4-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1268,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-7/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | BUD-BUD | to RT0.BUD 2/x1/1/c9/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1138,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae13",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01701 | LON2-PRD-ESX03 VM Traffic LAG",
+    "circuits": [
+      {
+        "id": 658695,
+        "name": "LON2-PRD-ESX03-VM-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 601,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c8/1",
+      "1/x1/1/c8/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LJU-ZAG-IPTRUNK $GS-02372 | LJU-ZAG | ",
+    "circuits": [
+      {
+        "id": 747865,
+        "name": "LJU-ZAG-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 14,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-ZAG",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-ZAG",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/1/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-ams-nl-management |perfSONAR MGMT",
+    "circuits": [
+      {
+        "id": 736082,
+        "name": "PS-AMS-NL-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1523,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.15",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet_NCCN_ExpressRoute_Vlan4092 $GS-01126 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739680,
+        "name": "BELNET-NCCN-EXPRESSROUTE-VLAN4092",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 598,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 594,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "et-4/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC NIX P_AE12",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 996,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-0/0/16",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 533,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "xe-3/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE1 | RT1-SW1 | Patched to EX3400 xe-0/2/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 531,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "RT1-SW1",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RT1-SW1",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4062",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEJUST-02318 $GS-02318",
+    "circuits": [
+      {
+        "id": 745303,
+        "name": "SLCIMEC-02518",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/2/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #ams-fra-IT_INFRA-QFX-GEANT $GS-02555 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1685,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "2/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ULAKBIM P_lag-23",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611179649,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 549,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.116",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER RENATER #RENATER-AP1-IPv6-LHCONE $GS-00854 | ASN2200",
+    "circuits": [
+      {
+        "id": 661664,
+        "name": "RENATER-AP1-IPV6-LHCONE",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 586,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "1/x1/1/c4/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20 | GRNET-AP1-IP3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916098,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.3504",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER RARE #RARE-02642 $GS-02642 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 872,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "lag-7",
+    "bundle": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01887 | GEN-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177287,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "2/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | FRA-GEN | TO FRA01-GRV1  port 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162049,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "et-0/0/3"
+    ],
+    "bundle-parents": [
+      "et-0/0/3"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02015 | CHI-CHI|",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 585,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-CHI",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-CHI",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "2/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | AMS-LON | to AMS01-GRV3 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162241,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.23",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT CAAREN #GRE-MULTICAST-TUNNEL-CAAREN $GS-02376 | ASN4901",
+    "circuits": [
+      {
+        "id": 732664,
+        "name": "GRE-MULTICAST-TUNNEL-CAAREN",
+        "type": "IP PEERING - R&E",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1226,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CAAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CAAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.8",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01149 $GS-01149",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 591,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS CORSA SRF0000001 | JRA MX to CORSA P6",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1575,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-6 | FRA-PRA | TO RT1.PRA.CZ-et-0/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899970,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae8.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS2-LON-AMT-IPTRUNK $GS-00012 | ",
+    "circuits": [
+      {
+        "id": 736813,
+        "name": "AMS2-LON-AMT-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1428,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-101.103",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-RIG-SI-VRF-VLAN103 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "3",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER NKN SRF19102 P_AE20 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 559,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NKN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NKN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.550",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET RENATER #GRID5K-02234",
+    "circuits": [
+      {
+        "id": 744235,
+        "name": "GRID5K-02234",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 934,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.3925",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT SINGAREN #NL-SINGAREN $GS-02202 | ASN23855 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1758,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-3/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 770,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO Netherlight #Netherlight-GEO-UK-1 |  SRF9928315 | GeO NETHERLIGHT 100G | NETHERLIGHT ID: Asd001A-8700-08:8/1",
+    "circuits": [
+      {
+        "id": 719825,
+        "name": "NETHERLIGHT-GEO-UK-1",
+        "type": "GEANT OPEN PORT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1168,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/1/4.102",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER MAEEN ESNET #LON-LON-GEANTOpen-MAEEN-ESNET-22004 $GS-00464 | ",
+    "circuits": [
+      {
+        "id": 738639,
+        "name": "LON-LON-GEANTOPEN-MAEEN-ESNET-22004",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1512,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MAEEN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MAEEN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 559,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #RIG-TAR-IPTRUNK $GS-02345 | RIG-TAR | ",
+    "circuits": [
+      {
+        "id": 746458,
+        "name": "RIG-TAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 7,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "RIG-TAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RIG-TAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "2/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | LON-LON2 | to LON01.GRV2 - 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162241,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 869,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:1501",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET NORDUNET #HAM-LON-00719 $GS-00719",
+    "circuits": [
+      {
+        "id": 747551,
+        "name": "HAM-LON-00719",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-fra-de $GS-00151 | SW3-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 729100,
+        "name": "EX3400-MANAGEMENT-FRA-DE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 973,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae34.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/2/5",
+      "xe-4/3/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | NEMO DDOS Detection 2",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1048,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae5",
+    "bundle": [
+      "et-7/0/2",
+      "et-7/0/5"
+    ],
+    "bundle-parents": [
+      "et-7/0/2",
+      "et-7/0/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01738 | BUD-ZAG | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 619,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-ZAG",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-ZAG",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | SPLUNK LON2 PEER01 link Slot7 P1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1574,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.130",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ocvm-lon-uk-ilo | OC VM iDRAC",
+    "circuits": [
+      {
+        "id": 740699,
+        "name": "OCVM-LON-UK-ILO",
+        "type": "SERVER LINK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 676,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 551,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/2/8",
+      "xe-3/2/9"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MAR-MAR-IPTRUNK $GS-02590| MAR-MAR | MAR-MAR",
+    "circuits": [
+      {
+        "id": 742606,
+        "name": "MAR-MAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 862,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae30",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01709 | QFX.FRA.DE AE14",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 608,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/26",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX03 NIC1 PORT3 - VSAN PORT",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 638,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae10.2030",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-5/0/2",
+      "et-9/0/5",
+      "et-11/1/5"
+    ],
+    "description": "SRV_L3VPN CUSTOMER JISC #JISC-AP1-LHCONE $GS-00832 | ASN786",
+    "circuits": [
+      {
+        "id": 661732,
+        "name": "JISC-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 967,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "1/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | LJU-MIL2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916353,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/1/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 536,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/1/4.2010",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET ESNET #lon-lon-GEANTOpen-Esnet-NORDUNET-15039-2 $GS-00964 |",
+    "circuits": [
+      {
+        "id": 738645,
+        "name": "LON-LON-GEANTOPEN-ESNET-NORDUNET-15039-2",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1518,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY To SRX2 to SRX1 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 514,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-21",
+    "bundle": [
+      "1/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER LITNET | $GA-02042  | LITNET-AP1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177301,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LITNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LITNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE ORACLE P_AE11 SRF21099 | GEANT-Interxion-AMS8 2-1 | Digital Realty CID: NL159412",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 565,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae1.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/0",
+      "xe-3/0/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-POR-PT $GS-00125 | ",
+    "circuits": [
+      {
+        "id": 712189,
+        "name": "DCN-MANAGEMENT-POR-PT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 589,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.801",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT RE_INTERCONNECT INTERNET2 UBUNTUNET #lon-lon-MISC-UBUNTUNET-INTERNET2-170341 $GS-00729 |",
+    "circuits": [
+      {
+        "id": 709301,
+        "name": "LON-LON-MISC-UBUNTUNET-INTERNET2-170341",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 804,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/1/3.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER URAN #chi-kie-EAP-RENAM-URAN-22087 $GS-02212 |",
+    "circuits": [
+      {
+        "id": 723461,
+        "name": "CHI-KIE-EAP-RENAM-URAN-22087",
+        "type": "GEANT - GBS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 600,
+    "dashboards": [
+      "EAP",
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-2/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE GOOGLE P_AE49 | Interxion CID DE272882",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 682,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4082",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEKULEUVEN-01134 $GS-01134",
+    "circuits": [
+      {
+        "id": 744267,
+        "name": "MSEKULEUVEN-01134",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1462,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/0/1:3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 534,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-11/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC LINX P_AE20 | LINX port: core4-tch-re1 - et-2/2/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1652,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/1/4.201",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER ESNET #lon-lon-GEANTOpen-Esnet-TENET-180871 $GS-00966 |",
+    "circuits": [
+      {
+        "id": 738644,
+        "name": "LON-LON-GEANTOPEN-ESNET-TENET-180871",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1514,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "TENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "1/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | AMS-FRA | to AMS01-GRV1 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899777,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "1/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | GEN-PAR | Connected to PAR01.GRV2 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899521,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "et-1/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS IT REFRESH P_AE30 | qfx1.lon2.uk et-0/0/52",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 748,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.3019",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #AMS-LON-SINET-SD-WAN-SINET-SINET-17088 $GS-00649 |",
+    "circuits": [
+      {
+        "id": 740719,
+        "name": "AMS-LON-SINET-SD-WAN-SINET-SINET-17088",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 667,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "1/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER HEANET P_lag-20 | HEANET-AP2-IP1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917505,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "et-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE1 | AMS-AMS | AMS-AMS-IP1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 633,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC DE-CIX P_AE20 | DE-CIX Migration 1_2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1562,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "1/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER BELNET P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917505,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4",
+      "1/x1/1/c4/1",
+      "1/x1/1/c4/2",
+      "1/x1/1/c4/3",
+      "1/x1/1/c4/4"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4",
+      "1/x1/1/c4/1",
+      "1/x1/1/c4/2",
+      "1/x1/1/c4/3",
+      "1/x1/1/c4/4"
+    ],
+    "description": "LAG CUSTOMER GRNET | $GA-01929 | #GRNET-AP2-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "irb.3006",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-GTS-IMS-MEDIATION-FRANKFURT-LOGiCAL-INTERFACE $GS-00866| IMS Mediation Gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 733017,
+        "name": "TAAS-GTS-IMS-MEDIATION-FRANKFURT",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1234,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 606,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c9/1",
+      "2/1/c11/1",
+      "2/1/c11/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LJU-MIL2-IPTRUNK $GS-00051 | LJU-MIL2 | ",
+    "circuits": [
+      {
+        "id": 746146,
+        "name": "LJU-MIL2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 6,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-MIL2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-MIL2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.300",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #dtn-project-par-fr $GS-00145 | DTN-Project CONTACT: anura.hettiarachchi@geant.org IMPLEMENTED: 20171205",
+    "circuits": [
+      {
+        "id": 739093,
+        "name": "DTN-PROJECT-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1225,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-10/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | WAS BIL-MAD",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1045,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 560,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "et-3/0/4",
+      "et-3/1/4"
+    ],
+    "bundle-parents": [
+      "et-3/0/4",
+      "et-3/1/4"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02459 | FRA-FRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1376,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-FRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-FRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-5/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | LR4 Optic Installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 848,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-11/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE FACEBOOK P_AE16 | Digital Reality CID: AT227180 | FB ID: FC-203126783",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 869,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/6.500",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF #PRA-POZ-RARE-BMS9 $GS-02628",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1025,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-23.111",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c27/1",
+      "2/x1/1/c26/1"
+    ],
+    "description": "SRV_L3VPN CUSTOMER ULAKBIM #ULAKBIM-AP2-LHCONE $GS-00869 | ASN8517 | ",
+    "circuits": [
+      {
+        "id": 744997,
+        "name": "ULAKBIM-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "20",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:3913",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01154 $GS-01154",
+    "circuits": [
+      {
+        "id": 747629,
+        "name": "AMS-HAM-MSE-01154",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MICROSOFT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT MANLAN P_AE15 SRF21042 | Paris-NewYork ANA Link - GTT/002228864",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1150,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "MANLAN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MANLAN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1064,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.5",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #NORDUNET-JYV-ExpressRoute-VLAN3902 $GS-01157 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707076,
+        "name": "NORDUNET-JYV-EXPRESSROUTE-VLAN3902",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1389,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "et-7/1/2"
+    ],
+    "bundle-parents": [
+      "et-7/1/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02594 | BUD-BUD",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 616,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-BUD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-BUD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE GTS SRF0000001 | MAD GTS Server #1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 578,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1265,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae30",
+    "bundle": [
+      "xe-4/0/4",
+      "xe-4/0/5",
+      "xe-4/1/2",
+      "xe-4/2/2"
+    ],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/0/5",
+      "xe-4/1/2",
+      "xe-4/2/2"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS SUPERPOP SRF0000001 $GA-01815 | QFX1.PAR.FR SRX BYPASS",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 702,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "2/1/c5/1"
+    ],
+    "bundle-parents": [
+      "2/1/c5/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01769 | MIL2-VIE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-VIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-VIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1062,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/44",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE30 | to QFX1.LON2.UK xe-1/0/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 684,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE3     | LON2-PRD-ESX03 NIC1 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 519,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_AE2 | rt1-sw3 xe-2/0/1  (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1441,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae31",
+    "bundle": [
+      "xe-11/0/1"
+    ],
+    "bundle-parents": [
+      "xe-11/0/1"
+    ],
+    "description": "LAG CUSTOMER MICROSOFT SRF19104 EXPRESSROUTE #2 $GA-01963 | GEANT-FRA32-09XGMR-CIS-2-SEC-11012019",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1207,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae40.415",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ORACLE REDIRIS SRF22010 #fra-mad-ORACLE-REDIRIS-22010-VL415 $GS-02096",
+    "circuits": [
+      {
+        "id": 719496,
+        "name": "FRA-MAD-ORACLE-REDIRIS-22010-VL415",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1059,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ORACLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae17.433",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/3/4"
+    ],
+    "description": "SRV_IAS CUSTOMER ASNET-AM #ASNET-AM-AP2-IAS IASPS $GS-02651 | ASN47623 |",
+    "circuits": [
+      {
+        "id": 747039,
+        "name": "ASNET-AM-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1710,
+    "dashboards": [
+      "EAP",
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ASNET-AM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASNET-AM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COLT | COLT ID: 444162876",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1065,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COLT - VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COLT - VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:2104",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET REDIRIS #HAM-MAD-02516 $GS-02516",
+    "circuits": [
+      {
+        "id": 747543,
+        "name": "HAM-MAD-02516",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-9/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC P_AE10 SRF22051 | JISC-AP1-LL3 | JISC ID: 22352619",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1403,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 557,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1298,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c6/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | ATH2-THE | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916225,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-THE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-THE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | HAM-POZ | to RT0.HAM.DE 2/1/c8/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899970,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae1.991",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/1/7",
+      "xe-2/2/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-GEN-CH | DCN MANAGEMENT",
+    "circuits": [
+      {
+        "id": 740080,
+        "name": "DCN-MANAGEMENT-GEN-CH",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1484,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae10.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER KIFU #KIFU-AP1 $GS-00481 | ASN1955 | aka KIFU",
+    "circuits": [
+      {
+        "id": 663051,
+        "name": "KIFU-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 730,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.4050",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT CANARIE #FR-CANARIE-2 $GS-00913 | ASN6509 | MANLAN Vlan:4050 ",
+    "circuits": [
+      {
+        "id": 736733,
+        "name": "FR-CANARIE-2",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1173,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CANARIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "1/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20 | GRNET-AP1-IP1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915972,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/47",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE31    | MX1.LON2.UK xe-3/2/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 549,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/2",
+      "et-8/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUD-VIE-IPTRUNK $GS-00026| BUD-VIE | ",
+    "circuits": [
+      {
+        "id": 740790,
+        "name": "BUD-VIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 714,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-VIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-VIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae13.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/0",
+      "xe-11/0/3",
+      "xe-11/0/5"
+    ],
+    "description": "SRV_IAS PRIVATE GOOGLE #GOOGLE-FRA15-15169-DE-to-be-deleted $TS-00934 | ASN15169",
+    "circuits": [
+      {
+        "id": 731196,
+        "name": "GOOGLE-FRA15-15169-DE-TO-BE-DELETED",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 999,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "GOOGLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GOOGLE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae16",
+    "bundle": [
+      "et-4/1/5"
+    ],
+    "bundle-parents": [
+      "et-4/1/5"
+    ],
+    "description": "LAG CUSTOMER RASH SRF23039 $GA-02324 | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 940,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RASH",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "RASH",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 644,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-20:2281",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER HEANET #LOFAR-00632 $GS-00632",
+    "circuits": [
+      {
+        "id": 747349,
+        "name": "LOFAR-00632",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 520,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/32",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik C Data Port 2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 680,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/2/0.702",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT GEANT #par-fra-DTN-generator $GS-00745 | RARE P4 TESTBED ",
+    "circuits": [
+      {
+        "id": 733002,
+        "name": "PAR-FRA-DTN-GENERATOR",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 984,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "xe-3/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE1 | RT1-SW1 | Patched to EX3400 xe-0/2/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 540,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "RT1-SW1",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RT1-SW1",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-5/0/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_ae1 SRF0000001 | rt1-sw2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 683,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae11",
+    "bundle": [
+      "xe-0/1/1"
+    ],
+    "bundle-parents": [
+      "xe-0/1/1"
+    ],
+    "description": "LAG PRIVATE ORACLE SRF21099 #2 | #NL-ORACLEFC-LAG-2 $GA-02035| FastConnect NREN Access",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 582,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.692",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER REDIRIS MICROSOFT #REDIRIS-ICN2-ExpressRoute-VLAN692 $GS-02560 | ",
+    "circuits": [
+      {
+        "id": 740768,
+        "name": "REDIRIS-ICN2-EXPRESSROUTE-VLAN692",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1040,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #FRA-FRA-IPTRUNK $GS-02461 | FRA-FRA | RT0.FRA-RT1.FRA",
+    "circuits": [
+      {
+        "id": 739046,
+        "name": "FRA-FRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-FRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-FRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #HAM-POZ-IPTRUNK $GS-02339 | HAM-POZ | ",
+    "circuits": [
+      {
+        "id": 740148,
+        "name": "HAM-POZ-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-POZ",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-POZ",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-8/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1273,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4081",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet-ARTEV-ExpressRoute-VLAN4081 $GS-01123 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739675,
+        "name": "BELNET-ARTEV-EXPRESSROUTE-VLAN4081",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1666,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE FW1-SNM",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1594,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-21",
+    "bundle": [
+      "1/x1/1/c25/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c25/1"
+    ],
+    "description": "LAG CUSTOMER ARNES | $GA-02632 | ARNES-AP1B-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177301,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/12",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 527,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 525,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae30.3004",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-CONTROL-FRANKFURT-VRF-VLAN3004 $GS-00862 | RANCID gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 733012,
+        "name": "TAAS-CONTROL-FRANKFURT-VRF-VLAN3004",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1132,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.2707",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA AUTOGOLE DUB-SAO.T4 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 816,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.3928",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT CANARIE #NL-CANARIE-vlan3928 $GS-02646 | ASN6509",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1759,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CANARIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER UOM P_AE19 SRF21103 | #UOM-AP2-100G-LL1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 673,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "UOM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UOM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-7/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | AMS-AMS | to RT0.AMS 1/1/c19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 543,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/8.996",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #GEANT-OPERATIONS-LabConnectivity | GEANT MX1.LON Infinera VRF to Operations Lab",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 554,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae21.4001",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/1/0"
+    ],
+    "description": "SRV_IAS PRIVATE T-SYSTEMS #DE-T-SYSTEMS-IAS $GS-02273 | ASN6878 |",
+    "circuits": [
+      {
+        "id": 727982,
+        "name": "DE-T-SYSTEMS-IAS",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 722,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "T-SYSTEMS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "T-SYSTEMS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1467,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.204",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #FLOWMON-DDOS-FRA-DE-IDRAC | FlowMon iDRAC CONTACT: evangelos.spatharas@geant.org IMPLEMENTED: 20170910",
+    "circuits": [
+      {
+        "id": 732625,
+        "name": "FLOWMON-DDOS-FRA-DE-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1407,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.26",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-JUST-ExpressRoute-VLAN4063 $GS-02319 | ",
+    "circuits": [
+      {
+        "id": 739662,
+        "name": "BELNET-JUST-EXPRESSROUTE-VLAN4063",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 607,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.21",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet_ZWEV_ExpressRoute_VLAN4082 $GS-01129 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739676,
+        "name": "BELNET-ZWEV-EXPRESSROUTE-VLAN4082",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 602,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "2/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "''",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161729,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "1/x1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER MARNET P_lag-22",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915970,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MARNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MARNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-22.320",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c27/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER PIONIER #PIONIER-AP2 $GS-00496 | ASN8501 | ",
+    "circuits": [
+      {
+        "id": 747601,
+        "name": "PIONIER-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "9",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae10.2802",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET KIFU #SLCUTH-02497 $GS-02497|",
+    "circuits": [
+      {
+        "id": 745594,
+        "name": "SLCUTH-02497",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 860,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 598,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 602,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae16.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/5"
+    ],
+    "description": "SRV_IAS CUSTOMER RASH #RASH-AP1-100G-IAS IASGWS $GS-02326 | ASN57961 | ",
+    "circuits": [
+      {
+        "id": 727802,
+        "name": "RASH-AP1-100G-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 944,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RASH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RASH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-8/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 994,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-5/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS SUPERPOP P_AE30 | QFX xe-0/0/29",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 818,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SRX-2 To Switch Cluster ge-1/0/2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 513,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae21.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/1/0"
+    ],
+    "description": "SRV_IAS CUSTOMER ROEDUNET #ROEDUNET-AP2-IAS IASGWS $GS-00545 | ASN2614 |",
+    "circuits": [
+      {
+        "id": 679570,
+        "name": "ROEDUNET-AP2-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 918,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ROEDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ROEDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3240",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET HARNET #lon-lon-GEANTOpen-HARNET-NORDUNET $GS-02606 | ",
+    "circuits": [
+      {
+        "id": 742671,
+        "name": "LON-LON-GEANTOPEN-HARNET-NORDUNET",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 620,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "HARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.3068",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE CANARIE #AMS-AMS-RARE-CANARIE-21013 $GS-00627 |",
+    "circuits": [
+      {
+        "id": 736077,
+        "name": "AMS-AMS-RARE-CANARIE-21013",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1541,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.3",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER RedIRIS Microsoft #RedIRIS-UCLM-ExpressRoute-Vlan411 $GS-01166 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 706055,
+        "name": "REDIRIS-UCLM-EXPRESSROUTE-VLAN411",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1387,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1301,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE |DDOS SERVER 2 10Gb_2 | P_ae22",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1056,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "1/x1/1/c25/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ARNES P_lag-21 | ARNES-AP1B-IP1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917441,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-1/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae6 | BIL-MAD |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 680,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "lag-7.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #GEN-PAR-IPTRUNK $GS-00040 | GEN-PAR | ",
+    "circuits": [
+      {
+        "id": 739696,
+        "name": "GEN-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae32.991",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/0",
+      "et-5/0/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE Access #CORIANT-LIBRENMS-ACCESS-LON2-UK | OPTICAL LIBRENMS ACCESS",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 926,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.buc.ro.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER ROEDUNET | $GA-018934 | # | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ROEDUNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ROEDUNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-25.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c4/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER KREN #KREN-AP1 $GS-02153 | ASN211080 | ",
+    "circuits": [
+      {
+        "id": 747899,
+        "name": "KREN-AP1",
+        "type": "GEANT IP",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "19",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER MARNET P_lag-23",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915971,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MARNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MARNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae1.21",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/1/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #hades-vie-at-DRAC | Hades DRAC",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 657,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.1002",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET TEIN #lon-lon-GEANTOpen-NORDUNET-TEIN-17026 $GS-00977 |",
+    "circuits": [
+      {
+        "id": 705906,
+        "name": "LON-LON-GEANTOPEN-NORDUNET-TEIN-17026",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 579,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TEIN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/1/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER ASNET-AM ASNET-AM #fra-fra-EAP-ASNET-AM-CL-190891 $GS-00696 |",
+    "circuits": [
+      {
+        "id": 732138,
+        "name": "FRA-FRA-EAP-ASNET-AM-CL-190891",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1070,
+    "dashboards": [
+      "EAP",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ASNET-AM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASNET-AM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/1/4.1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO ESnet #ESnet-GEO-UK-1 |  Lon-ESnet-OPEN-400G",
+    "circuits": [
+      {
+        "id": 738646,
+        "name": "ESNET-GEO-UK-1",
+        "type": "GEANT OPEN PORT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1511,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | RARE EDGECORE WEDGE100BF-32X xe-2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 687,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae10.1990",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER FCCN #FCCN-AP1-LIS-LHCONE $GS-02401 | ASN1930",
+    "circuits": [
+      {
+        "id": 730596,
+        "name": "FCCN-AP1-LIS-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 673,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "2/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | BUC-SOF | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178497,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-SOF",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-SOF",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-3/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-mgmt-loc-lis-pt.geant.org  pS MGMT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 695,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT HBKU SRF18083 $GA-01398 | Colt ID: XBG/XBG/LE-241593",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1289,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "HBKU",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HBKU",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae18",
+    "bundle": [
+      "et-2/0/2"
+    ],
+    "bundle-parents": [
+      "et-2/0/2"
+    ],
+    "description": "LAG CUSTOMER ACONET AP_B SRF9943109 $GA-01770 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 803,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ACONET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ACONET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-RIG-SI-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "4",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae30.3015",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #INFOBLOX-FRA-DE | Infoblox vFRA MGMT",
+    "circuits": [
+      {
+        "id": 733919,
+        "name": "INFOBLOX-FRA-DE-MGMT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1137,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | was ANKABUT",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1458,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26",
+    "bundle": [
+      "et-1/1/0"
+    ],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "LAG RE_INTERCONNECT NEA3R SRF20098 $GA-01970 | ANA-100G-NEA3R",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 722,
+    "dashboards": [
+      "ANA",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "NEA3R",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "NEA3R",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.500",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NEA3R SURF #LON-LON-NEA3R-SURF-22015 $GS-00707 | ",
+    "circuits": [
+      {
+        "id": 718304,
+        "name": "LON-LON-NEA3R-SURF-22015",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1012,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NEA3R",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NEA3R",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SURFNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "2/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | FRA-GEN | TO FRA01-GRV1  port 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161921,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.702",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE RARE #LON-AMS-DTN-GENERATOR $GS-00722 | RARE P4 TESTBED",
+    "circuits": [
+      {
+        "id": 736105,
+        "name": "LON-AMS-DTN-GENERATOR",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1533,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae20",
+    "bundle": [
+      "xe-2/2/0"
+    ],
+    "bundle-parents": [
+      "xe-2/2/0"
+    ],
+    "description": "LAG CUSTOMER MICROSOFT EXPRESSROUTE #2 $GA-02523 | GEANT-EXRJ02-MAD31-SEC-07192024",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 658,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER MICROSOFT  EXPRESSROUTE #1 P_AE10 | Interrxion CID: DE131269-1 | GEANT-FRA32-09XGMR-CIS-1-PRI-11012019",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 854,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.3918",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS Customer Nordunet MICROSOFT #Nordunet-MSER-ExpressRoute-Vlan3918 $GS-02411  | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 732192,
+        "name": "NORDUNET-MSER-EXPRESSROUTE-VLAN3918",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1344,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "et-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CESNET P_AE11 SRF9922157 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 885,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-bw-ams.nl.geant.org pS BWCTL",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1452,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/0/1:0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 531,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-9/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT COPERNICUS P_AE15 SRF21068| #FOR-MAD-COPERNICUS-100G | Circuit ID: BRFT1 MEQX1 100GB00001 | p22 in odf3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1145,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "COPERNICUS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COPERNICUS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-2/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 634,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae18",
+    "bundle": [
+      "et-8/1/0"
+    ],
+    "bundle-parents": [
+      "et-8/1/0"
+    ],
+    "description": "LAG CUSTOMER KIFU  $GA-01861 | KIFU-AP2-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 578,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/2.2210",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER HBKU INTERNET2 #lon-par-GEANTOPEN-HBKU-INTERNET2-190091 $GS-00967 |",
+    "circuits": [
+      {
+        "id": 736739,
+        "name": "LON-PAR-GEANTOPEN-HBKU-INTERNET2-190091",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1434,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "HBKU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae1.301",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/3/0",
+      "xe-1/3/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #POZ Groove 1 | ",
+    "circuits": [
+      {
+        "id": 727448,
+        "name": "POZ",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 780,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.352",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #FLOWMON-PAR-FR-NETFLOW | FlowMon1 Management + FanOut CONTACT: evangelos.spatharas@geant.org",
+    "circuits": [
+      {
+        "id": 739101,
+        "name": "FLOWMON-PAR-FR-NETFLOW",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1368,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.50",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT IRANET #DE-IRANET $GS-01169 | ASN6736",
+    "circuits": [
+      {
+        "id": 732661,
+        "name": "DE-IRANET",
+        "type": "IP PEERING - R&E",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1228,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "IRANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "IRANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae46",
+    "bundle": [
+      "et-2/0/1"
+    ],
+    "bundle-parents": [
+      "et-2/0/1"
+    ],
+    "description": "LAG PRIVATE FACEBOOK $GA-02481 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1606,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae21.110",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/4"
+    ],
+    "description": "SRV_L3VPN CUSTOMER CERN #CERN-GEN-LHCONE-2 $GS-00812 | ASN513 | CERNLIGHT",
+    "circuits": [
+      {
+        "id": 701612,
+        "name": "CERN-GEN-LHCONE-2",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1243,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/2.1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO HBKU #HBKU-GEO-UK-1 | SRF18085 | EQUINIX ID: 20873393 |",
+    "circuits": [
+      {
+        "id": 719826,
+        "name": "HBKU-GEO-UK-1",
+        "type": "GEANT OPEN PORT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1178,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "HBKU",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HBKU",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae32",
+    "bundle": [
+      "xe-4/0/0"
+    ],
+    "bundle-parents": [
+      "xe-4/0/0"
+    ],
+    "description": "LAG PRIVATE ORANGE SRF21047 #FR-ORANGE-LAG-3 $GA-02179",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 779,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 607,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "xe-0/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 562,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.904",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 GEANT #lon-lon2-MISC-GEANT-INTERNET2-9940525 $GS-00732 |",
+    "circuits": [
+      {
+        "id": 709300,
+        "name": "LON-LON2-MISC-GEANT-INTERNET2-9940525",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 832,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-10/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CESNET P_AE23 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 569,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.2001",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT INTERNET2 #INTERNET2-PAR-LHCONE $GS-00831 | ASN11537",
+    "circuits": [
+      {
+        "id": 660639,
+        "name": "INTERNET2-PAR-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 613,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "1/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | PAR-PAR | TO MX1.PAR.FR et-9/0/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900673,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PAR-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PAR-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/2.101",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE GEANT #fra-ham-WP7T2SF-RARE-20104-FRA",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1444,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "1/x1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01792 | AMS-BRU",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-BRU",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-BRU",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-1/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 527,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-4/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 998,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae31.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/1/5"
+    ],
+    "description": "SRV_IAS PRIVATE ORANGE #FR-ORANGE-2280-2 $GS-01179 | ASN2280 |",
+    "circuits": [
+      {
+        "id": 718722,
+        "name": "FR-ORANGE-2280-2",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 994,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "ORANGE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORANGE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-5/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic present",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 678,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "2/x1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-50047 | ZAG-ZAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ZAG-ZAG",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ZAG-ZAG",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/42",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE29    | 10_GBS to MX1.LON2.UK xe-2/0/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 543,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/6.1728",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION KAUST #ams-fra-KAUST-SCION $GS-02417|",
+    "circuits": [
+      {
+        "id": 744389,
+        "name": "AMS-FRA-KAUST-SCION",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1705,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae11.1700",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-2/1/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER CESNET P_AE11 SRF0000001 #CESnet-NSI-GCS $GS-00446 | GCS Port",
+    "circuits": [
+      {
+        "id": 725157,
+        "name": "CESNET-NSI-GCS",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 937,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP P_AE30 | QFX xe-1/0/19",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1270,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae13",
+    "bundle": [
+      "xe-0/2/2"
+    ],
+    "bundle-parents": [
+      "xe-0/2/2"
+    ],
+    "description": "LAG PRIVATE GOOGLE $GA-02450 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 995,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae15.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/5"
+    ],
+    "description": "SRV_IAS PRIVATE GOOGLE #GOOGLE-2-15169-IT $GS-02248 | ASN15169",
+    "circuits": [
+      {
+        "id": 733062,
+        "name": "GOOGLE-2-15169-IT",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 951,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "GOOGLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GOOGLE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "et-7/0/2"
+    ],
+    "bundle-parents": [
+      "et-7/0/2"
+    ],
+    "description": "LAG CUSTOMER LITNET AP2 #LITNET-AP2-LAG $GA-02071 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 615,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LITNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LITNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae5",
+    "bundle": [
+      "xe-0/3/0",
+      "xe-0/3/1"
+    ],
+    "bundle-parents": [
+      "xe-0/3/0",
+      "xe-0/3/1"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 |rt1-sw2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 671,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae15.422",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ACONET SANET #BRA-VIE-ACONET-SANET $GS-02379 |",
+    "circuits": [
+      {
+        "id": 729694,
+        "name": "BRA-VIE-ACONET-SANET",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1025,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae1.200",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/0",
+      "xe-1/2/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #LON2-SEC-ESX-DEVICES-IDRAC |lon2-sec-esx20/21-devices-iDRAC CONTACT: anura.hettiarachchi@geant.org IMPLEMENTED: 20181031",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 881,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-23",
+    "bundle": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "LAG CUSTOMER BELNET | $GA-01791 | #BELNET-GRID5K-LAG",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1342177303,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | GEN-MIL2 | to RT1.MIL2 et-9/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900033,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | was LON TAAS 01",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 597,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "lag-8.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-FRA-IPTRUNK $GS-00009 | AMS-FRA | ",
+    "circuits": [
+      {
+        "id": 739045,
+        "name": "AMS-FRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-8/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GARR P_AE12 SRF21107 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1529,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c4/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916097,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-21.100",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c2/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER CYNET #CYNET-AP2 $GS-00450 | ASN3268 | ",
+    "circuits": [
+      {
+        "id": 745492,
+        "name": "CYNET-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CYNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CYNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-8/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENATER P_AE14 | RENATER-100GB-LL4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1528,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-0/0/18",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae0      | MX xe-4/2/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 535,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1063,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "1/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915971,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-2/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 637,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-5/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | RENAM 10G GBS",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 681,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-mgmt-ams-nl.geant.org  pS MGMT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1450,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "1/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | HAM-TAR | to RT2.TAR et-0/0/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900034,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-TAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-TAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae11.931",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER DFN REDIRIS SRF21028 #fra-mad-DFN-REDIRIS-21028 $GS-00692",
+    "circuits": [
+      {
+        "id": 719501,
+        "name": "FRA-MAD-DFN-REDIRIS-21028",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 916,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | FRA-LON2-QFX | to QFX xe-0/0/43",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 545,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 524,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/0/1:1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 532,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "et-0/0/5",
+      "et-0/1/2"
+    ],
+    "bundle-parents": [
+      "et-0/0/5",
+      "et-0/1/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02077 | BIL-POR |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 519,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-POR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-POR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.2023",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET INTERNET2 #AMS-PAR-GEANTOPEN-NORDUNET-INTERNET2-17008 $GS-00959 |",
+    "circuits": [
+      {
+        "id": 705899,
+        "name": "AMS-PAR-GEANTOPEN-NORDUNET-INTERNET2-17008",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 962,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/2/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 641,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae18.333",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-7/0/6"
+    ],
+    "description": "SRV_IAS Customer ARN #ES-ARN-AP1-IAS IASGWS $GS-00529 | ASN3208 |",
+    "circuits": [
+      {
+        "id": 724754,
+        "name": "ES-ARN-AP1-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1167,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SRX-1 To TS eth1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 519,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1312,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-11/1/2.100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS DTN-PROJECT #DTN-LON-100G-DATA $GS-00143 | 100G Testing CONTACT: Richard.Hughes-Jones@geant.org",
+    "circuits": [
+      {
+        "id": 736817,
+        "name": "DTN-LON-100G-DATA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1424,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-1/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 530,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "xe-0/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENAM P_AE10 SRF21066 | RENAM ID: MX240 xe-2/0/1-AP2-L1 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 561,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "ae2.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-kie-ua $GS-00152 | SW1-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 713313,
+        "name": "EX3400-MANAGEMENT-KIE-UA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 585,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-20:713",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET REDIRIS #SLCUTH-02498 $GS-02498|",
+    "circuits": [
+      {
+        "id": 745414,
+        "name": "SLCUTH-02498",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/5",
+      "et-0/1/2",
+      "et-0/1/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #PRA-PRA-IPTRUNK $GS-02545| PRA-PRA | PRA-PRA-MGMT",
+    "circuits": [
+      {
+        "id": 739239,
+        "name": "PRA-PRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1022,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-PRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-PRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.2023",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL CUSTOMER NORDUNET #NORDUNET-AP1 $GS-00492 | ASN2603 |",
+    "circuits": [
+      {
+        "id": 661366,
+        "name": "NORDUNET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1275,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae30",
+    "bundle": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "bundle-parents": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS SUPERPOP $GA-01938| QFX1.FRA.DE SRX BYPASS",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1125,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae30.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT ESNET #NL-ESNET-LHCONE $GS-00835 | ASN293 |",
+    "circuits": [
+      {
+        "id": 734117,
+        "name": "NL-ESNET-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1036,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "1/x1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02478 | COR-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae13",
+    "bundle": [
+      "et-0/0/0"
+    ],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "LAG CUSTOMER SANET SRF9938829 $GA-02157 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 599,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SANET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SANET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "et-7/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | POZ-POZ | to RT0.POZ.PL 2/1/c11/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1060,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae12.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/5"
+    ],
+    "description": "SRV_IAS PRIVATE GOOGLE #GOOGLE-15169-IT $GS-00935 | ASN15169",
+    "circuits": [
+      {
+        "id": 708198,
+        "name": "GOOGLE-15169-IT",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 765,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "GOOGLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GOOGLE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "xe-3/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P7",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 536,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/0/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT GEANT #bud-fra-RARE-P4-9951387 $GS-00684 | RARE P4 TESTBED",
+    "circuits": [
+      {
+        "id": 708177,
+        "name": "BUD-FRA-RARE-P4-9951387",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 787,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/27",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX10 NIC1 PORT3 - VSAN PORT",
+    "circuits": [
+      {
+        "id": 658425,
+        "name": "LON2-PRD-ESX10-NIC1-PORT3",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 646,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c6/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #ATH2-THE-IPTRUNK $GS-02421 | ATH2-THE | ",
+    "circuits": [
+      {
+        "id": 745464,
+        "name": "ATH2-THE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-THE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-THE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.3906",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #Nordunet-Aalto-ExpressRoute-Vlan3906 $GS-01155 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 706994,
+        "name": "NORDUNET-AALTO-EXPRESSROUTE-VLAN3906",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1197,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BRU-PAR-IPTRUNK $GS-02280 | BRU-PAR | ",
+    "circuits": [
+      {
+        "id": 744055,
+        "name": "BRU-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 8,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRU-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRU-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3101",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT AARNET #UK-AARNET $GS-00904 | ASN7575 | CAE1-WL065785-VL3101",
+    "circuits": [
+      {
+        "id": 661460,
+        "name": "UK-AARNET",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 666,
+    "dashboards": [
+      "CAE1",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "AARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae7.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/0/2",
+      "et-9/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUC-BUD-IPTRUNK $GS-00021 | BUC-BUD | ",
+    "circuits": [
+      {
+        "id": 730444,
+        "name": "BUC-BUD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 848,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.14",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01154 $GS-01154",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 597,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c4/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER KREN P_lag-25",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916097,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KREN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KREN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.2200",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT CANARIE #CANARIE-PAR-LHCONE $GS-00809 | ASN6509",
+    "circuits": [
+      {
+        "id": 661404,
+        "name": "CANARIE-PAR-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 625,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CANARIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/2.904",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 GEANT #lon-lon2-MISC-GEANT-INTERNET2-9940525 $GS-00732 |",
+    "circuits": [
+      {
+        "id": 709300,
+        "name": "LON-LON2-MISC-GEANT-INTERNET2-9940525",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 785,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 594,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae23.559",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SWITCH GEANT #fra-gen-SWITCH-RARE-21035 $GS-00700 |",
+    "circuits": [
+      {
+        "id": 709921,
+        "name": "FRA-GEN-SWITCH-RARE-21035",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 641,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:3907",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01149 $GS-01149",
+    "circuits": [
+      {
+        "id": 747630,
+        "name": "AMS-HAM-MSE-01149",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MICROSOFT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.55",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS GEANT IT #DataDomain-01-DATA  PORT |",
+    "circuits": [
+      {
+        "id": 745869,
+        "name": "DATADOMAIN-01-DATA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 711,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.1627",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 SCION #gen-par-SCION-SCION-INTERNET2-1 $GS-02297 |",
+    "circuits": [
+      {
+        "id": 736637,
+        "name": "GEN-PAR-SCION-SCION-INTERNET2-1",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1153,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae20.200",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-5/1/2"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT SINET #NL-SINET-LHCONE $GS-00840 | ASN2907 |",
+    "circuits": [
+      {
+        "id": 734869,
+        "name": "NL-SINET-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1284,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "1/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | AMS-FRA | To  FRA01-GRV2- 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900097,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "1/x1/1/c8/1",
+      "1/x1/1/c8/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c8/1",
+      "1/x1/1/c8/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02374 | LJU-ZAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-ZAG",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-ZAG",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.29",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-UCLOUVAIN-ExpressRoute-VLAN4088 $GS-02161 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739665,
+        "name": "BELNET-UCLOUVAIN-EXPRESSROUTE-VLAN4088",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 609,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ge-1/0/33",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik B IPMI",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 688,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 576,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-11/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-owd-vie.at.geant.org pS OWAMP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 862,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-1/0/19",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae0      | MX xe-4/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 651,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/0/2:3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 535,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae10.1990",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER FCCN #FCCN-AP2-POR-LHCONE $GS-02402 | ASN1930",
+    "circuits": [
+      {
+        "id": 730599,
+        "name": "FCCN-AP2-POR-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 582,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-1/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 609,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/0/2.105",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF SRF21105 $GS-00686 | #BUD-PRA-RARE-BMS8",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1154,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.12",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRV_CORPORATE CUSTOMER GEANT_INTERNAL #DASHBOARD-TEST-SERVICE-LON-VODAFONE(DO-NOT-OPEN-TICKET)|",
+    "circuits": [
+      {
+        "id": 740706,
+        "name": "SRV_CORPORATE",
+        "type": "CORPORATE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 890,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | GEN-MIL2 | to RT0.GEN.CH 1/1/c8/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-3/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ESNET P_AE13 SRF9928169 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 868,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.30",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-MOBILIT-ExpressRoute-VLAN4089 $GS-02170 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739664,
+        "name": "BELNET-MOBILIT-EXPRESSROUTE-VLAN4089",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 610,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bud.hu.geant.net",
+    "name": "2/x1/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | BUD-BUD | to MX1.BUD et-7/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178562,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae3.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/8",
+      "xe-3/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-mar-fr| SW2-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 719630,
+        "name": "EX3400-MANAGEMENT-MAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 606,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/5.25",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GARR UBUNTUNET #lon-mil2-ASI-BSC-to-Fucino-Ubuntunet-GARR-20007 $GS-00735",
+    "circuits": [
+      {
+        "id": 705891,
+        "name": "LON-MIL2-ASI-BSC-TO-FUCINO-UBUNTUNET-GARR-20007",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 766,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-mgmt-poz-pl.geant.org  pS MGMT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 754,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae43.200",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 - CLEAN-IAS | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1362,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE2     | LON2-PRD-ESX02 NIC2 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 656,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-3/2/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-lis-pt-owamp new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 722352,
+        "name": "PS-LIS-PT-OWAMP",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 798,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/2/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 614,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "1/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | COR-DUB | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916353,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-DUB",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-DUB",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae19.114",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/1/3",
+      "xe-11/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ORACLE CERN #fra-gen-ORACLE-CERN-20094 $GS-00698 |",
+    "circuits": [
+      {
+        "id": 705442,
+        "name": "FRA-GEN-ORACLE-CERN-20094",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1054,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ORACLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 611,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC DE-CIX P_AE20 | DE-CIX Migration 2_2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1565,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.2501",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA | deltaId+f5c0e052-7c69-4363-9368-8c56d5cfd01c:uuid+ab7479ec-1408-4c49-b3d1-a7d9f580635f | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 706,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COGENT SRF22035 $GA-02147 | EAP GRENA GWS |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1057,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COGENT - VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT - VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "2/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178113,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-25",
+    "bundle": [
+      "1/x1/1/c4/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c4/1"
+    ],
+    "description": "LAG CUSTOMER KREN | $GA-02154 | #KREN-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177305,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KREN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KREN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 552,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae10.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-5/0/2",
+      "et-9/0/5",
+      "et-11/1/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER JISC #JISC-AP1 $GS-00479 | ASN786 |",
+    "circuits": [
+      {
+        "id": 661264,
+        "name": "JISC-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 770,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/11",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 527,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae12.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/5"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT CSTNET #CSTNET-MAR-LHCONE-PRIMARY $GS-00814 | ASN7497 ",
+    "circuits": [
+      {
+        "id": 729627,
+        "name": "CSTNET-MAR-LHCONE-PRIMARY",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 637,
+    "dashboards": [
+      "IC1",
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CSTNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CSTNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Was PSMP Server",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 581,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 638,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "1/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ARNES P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917505,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE ORACLE P_AE19 | Interxion CID: DE134518 | Oracle CID: GEANT-Interxion-1-2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 866,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "et-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE2 | BIL-POR | Infinera POR01-GRV2 1/1/3 facing Bilbao",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 557,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-POR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-POR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 553,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.2160",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT SINGAREN #UK-SINGAREN-AER-vlan2160 $GS-00908 | ASN23855 |",
+    "circuits": [
+      {
+        "id": 708101,
+        "name": "UK-SINGAREN-AER-VLAN2160",
+        "type": "IP PEERING - R&E",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 747,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L3VPN CUSTOMER PIONIER #PIONIER-AP1-LHCONE $GS-00844 | ASN8501",
+    "circuits": [
+      {
+        "id": 661518,
+        "name": "PIONIER-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 785,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.992",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-HEL-FI | DCN MANAGEMENT",
+    "circuits": [
+      {
+        "id": 714244,
+        "name": "DCN-MANAGEMENT-HEL-FI",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 946,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c13/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | LON2-PAR | connected to LON2.GRV4 port 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900289,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ESNET P_AE13 SRF9928017 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 778,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/1/6.1220",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER ESNET RENATER #AMS-PAR-INFINICORTEX-ESNET-RENATER-15030 $GS-00653 |",
+    "circuits": [
+      {
+        "id": 734115,
+        "name": "AMS-PAR-INFINICORTEX-ESNET-RENATER-15030",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1349,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae28",
+    "bundle": [
+      "xe-4/0/4",
+      "xe-4/3/0"
+    ],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/3/0"
+    ],
+    "description": "LAG UPSTREAM COLT SRF0000001 $GA-02114 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 708,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 574,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 528,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "1/x1/1/c4/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20 | GRNET-AP1-IP2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916097,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae46.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/1"
+    ],
+    "description": "SRV_IAS PRIVATE FACEBOOK #FACEBOOK-32934-FRA-PCDE-90606624 $GS-02483 | ASN32934",
+    "circuits": [
+      {
+        "id": 737794,
+        "name": "FACEBOOK-32934-FRA-PCDE-90606624",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1608,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "FACEBOOK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FACEBOOK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.40",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS Customer BELNET MICROSOFT #BELNET-FEDPOL-ExpressRoute-VLAN4071 $GS-02525 | ",
+    "circuits": [
+      {
+        "id": 739671,
+        "name": "BELNET-FEDPOL-EXPRESSROUTE-VLAN4071",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 672,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.975",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDIRIS BELNET #SLCIMEC-02514 $GS-02514",
+    "circuits": [
+      {
+        "id": 745330,
+        "name": "SLCIMEC-02514",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 818,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/3.2701",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION EENET #par-tar-SCION-EENET $GS-02356 | ",
+    "circuits": [
+      {
+        "id": 746441,
+        "name": "PAR-TAR-SCION-EENET",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1326,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae14",
+    "bundle": [
+      "et-9/1/2"
+    ],
+    "bundle-parents": [
+      "et-9/1/2"
+    ],
+    "description": "LAG PRIVATE FACEBOOK  $GA-01852 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 694,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.53",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS FLOWMON #FLOWMON-LON-IDRAC $GS-01193 | DRAC LOM",
+    "circuits": [
+      {
+        "id": 745870,
+        "name": "FLOWMON-LON-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 699,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | DDOS Mitigation Server link 1 Node 1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1293,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.2242",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT HARNET #NL-HARNET $GS-02539 | ASN137207 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1747,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "HARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae12.1000",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/5",
+      "et-8/0/5",
+      "et-11/0/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER GARR #GARR-AP2 $GS-00463 | ASN137 |",
+    "circuits": [
+      {
+        "id": 663180,
+        "name": "GARR-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 696,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-2/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE FACEBOOK P_AE46| META ID:  PCDE-90606624",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 673,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS JBO (via JISC) DTN $GA-01448 | 100G testing from Jodrell Bank DTN servers",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1266,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae29",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN P_--      | QFX.PAR.FR AE14",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 607,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-4/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | Reserved for SINET 400G upgrade",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 562,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-8/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER KIFU AP2  P_AE18 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 991,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 523,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.20",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-KMA2 $GS-00790",
+    "circuits": [
+      {
+        "id": 732662,
+        "name": "GRE-MULTICAST-TUNNEL-KMA2",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1223,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/0/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #fra-lon2-SUPERPOP-QFX-GEANT $GS00076 |",
+    "circuits": [
+      {
+        "id": 729416,
+        "name": "FRA-LON2-SUPERPOP-QFX-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1018,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | LON-LON2 | TO LON02 GRV1 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899905,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/3/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 625,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #PSMP-GN-MANAGEMENT-LON-UK-VLAN0 | psmp-gn-mgmt-lon-uk.geant.org pS MGMT",
+    "circuits": [
+      {
+        "id": 708299,
+        "name": "PSMP-GN-MANAGEMENT-LON-UK-VLAN0",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1011,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.32",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT MANLAN #FR-MANLAN $GS-00461 | Notification VLAN Only",
+    "circuits": [
+      {
+        "id": 714830,
+        "name": "FR-MANLAN",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1246,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "MANLAN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MANLAN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/2",
+      "et-9/0/2",
+      "et-9/0/5",
+      "et-9/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MAD-MAR-IPTRUNK $GS-00054| MAD-MAR | ",
+    "circuits": [
+      {
+        "id": 717047,
+        "name": "MAD-MAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 855,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "et-4/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE3 | LIS-POR | Infinera GRV1 1/1/3 Facing PORto",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 654,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-POR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-POR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4081",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-ARPGAN-01130 $GS-01130",
+    "circuits": [
+      {
+        "id": 744143,
+        "name": "BELNET-ARPGAN-01130",
+        "type": "EXPRESS ROUTE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/3.500",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #City-House-Network-Infrastructure | Network Infrastructure City House",
+    "circuits": [
+      {
+        "id": 662925,
+        "name": "CITY-HOUSE-NETWORK-INFRASTRUCTURE",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 548,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae27.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-10/2/0"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT MAEEN #UK-MAEEN $GS-00921 | ASN8895|",
+    "circuits": [
+      {
+        "id": 713957,
+        "name": "UK-MAEEN",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 935,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "MAEEN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAEEN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE8     | LON2-PRD-ESX12 NIC2 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 660,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-7/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae6 | BRA-BUD",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1139,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "1/x1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02044 | KAU-POZ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-POZ",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-POZ",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COLT P_ae21 | COLT ID: 444031977 # DX9403226 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 917,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COLT - BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COLT - BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae14",
+    "bundle": [
+      "xe-3/0/2"
+    ],
+    "bundle-parents": [
+      "xe-3/0/2"
+    ],
+    "description": "LAG CUSTOMER CYNET AP1 SRF23077 $GA-02440 | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 719,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CYNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CYNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "irb.520",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #IDRAC-MGMT-AMS-NL-VRF-VLAN520 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1586,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/32",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik C Data Port 1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 539,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "1/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER LAT P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917505,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LAT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/19",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE15    | LON2-PRD-ESX21 NIC2 PORT4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 670,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae3.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/0/1",
+      "xe-2/0/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-mad-es| SW1-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 702125,
+        "name": "EX3400-MANAGEMENT-MAD-ES",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 748,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GEANT CORPORATE SRF000001 | GEANT Corporate to MX1.LON - Via Vodafone",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 523,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SRX-1 To Switch Cluster ge-0/0/0 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 513,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "ae0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01714  | MX AE30",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 583,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS | mx1-sw2-2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1023,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | LON-LON2 | TO LON02 GRV1 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900097,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 523,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | BRA-BRA-MGMT | to RT0.BRA.SK 1/X1/1/C2/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 565,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA-MGMT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA-MGMT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "2/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | PRA-VIE | to RT0.PRA 2/1/c8/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162113,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 606,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae20",
+    "bundle": [
+      "xe-11/2/3"
+    ],
+    "bundle-parents": [
+      "xe-11/2/3"
+    ],
+    "description": "LAG CUSTOMER GRENA SRF21081 $GA-01860 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 700,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRENA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRENA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 575,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae14.518",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5",
+      "et-8/0/2",
+      "et-8/1/2",
+      "et-8/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER NISN #LON-GEN-CNES-NISN-RENATER-09201 $GS-00723 |",
+    "circuits": [
+      {
+        "id": 709299,
+        "name": "LON-GEN-CNES-NISN-RENATER-09201",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 827,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NISN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-1/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CERN P_AE17 SRF0000001 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1346,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-4/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT IC-1 P_AE12 SRF22102 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 584,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "IC-1",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "IC-1",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-7/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | AMS-AMS | to RT0.AMS 2/1/c19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 551,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae28.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/0/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT TENET #UK-TENET $GS-01192 | ASN2018",
+    "circuits": [
+      {
+        "id": 717803,
+        "name": "UK-TENET",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1007,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "TENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.11",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #FLOWMON-LON2-UK-MANAGEMENT | FlowMon1 Management + FanOut CONTACT: evangelos.spatharas@geant.org",
+    "circuits": [
+      {
+        "id": 661935,
+        "name": "FLOWMON-LON2-UK-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 979,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15",
+    "bundle": [
+      "et-3/1/4"
+    ],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "LAG CUSTOMER SURF $GA-01919 | SURF AE4 (0c94e02e)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1059,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-8/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_AE7 | AMT RELAY LINK #1 | TO AMT1.FRA.DE et-0/0/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1589,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-20.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1",
+      "1/x1/1/c26/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER ARNES #ARNES-AP1 $GS-00426 | ASN2107 | ",
+    "circuits": [
+      {
+        "id": 745714,
+        "name": "ARNES-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "2/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | GEN-MAR | to to RT1.MAR et-4/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162177,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 548,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-9/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | MAD-MAR | connected to MAD01-GRV2 1/1/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1138,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01674 | FRA-PRD-ESX03 ESXI Traffic LAG",
+    "circuits": [
+      {
+        "id": 658678,
+        "name": "FRANKFURT 15-FRANKFURT 15-LAG-056(GEANT)",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 576,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | PRA BMS Server 9",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 542,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/0/0.103",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE RARE #FRA-PAR-RARE-RARE-21101 $GS-00705 |",
+    "circuits": [
+      {
+        "id": 716207,
+        "name": "FRA-PAR-RARE-RARE-21101",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 959,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/2/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 554,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 832,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1049,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "2/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | POZ-PRA | to RT1.PRA.CZ et-2/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162114,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.3909",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #Nordunet-LTU-ExpressRoute-Vlan3909 $GS-01153 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707121,
+        "name": "NORDUNET-LTU-EXPRESSROUTE-VLAN3909",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1200,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-11/3/0.111",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #DTN-PAR-100G-DATA-LHCONE $GS-99999 | 100G Testing LHCONE CONTACT: Richard.Hughes-Jones@geant.org;",
+    "circuits": [
+      {
+        "id": 724437,
+        "name": "DTN-PAR-100G-DATA-LHCONE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 751,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae30.3002",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-latency-network-fra-de $GS-00312 | Latency network",
+    "circuits": [
+      {
+        "id": 733022,
+        "name": "PS-LATENCY-NETWORK-FRA-DE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1130,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 901,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | DDOS Mitigation Server link 2 Node 1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1294,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 521,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.10",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #NE-ESXI-FRA-DE-TNMS-VLAN10 | ne-esxi-prod-fra-1 VMnetwork",
+    "circuits": [
+      {
+        "id": 732679,
+        "name": "NE-ESXI-FRA-DE-TNMS-VLAN10",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1403,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | LON2-LON2 | TO MX1.LON2.UK-et-3/0/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900673,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 634,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "2/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | DUB-LON | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178497,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "DUB-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DUB-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae30.3008",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/0/5",
+      "xe-4/1/2",
+      "xe-4/2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE Access link DNS #INFOBLOX-TEST-PAR-FR $GS-00203 | TEST - Infoblox GRID /// NMAAS IS-IS Listener",
+    "circuits": [
+      {
+        "id": 712155,
+        "name": "INFOBLOX-TEST-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1060,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.3501",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER RARE #RARE-02639 $GS-02639 |",
+    "circuits": [
+      {
+        "id": 745531,
+        "name": "RARE-02639",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 898,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #CHI-KIE-IPTRUNK $GS-00029 | CHI-KIE IP TRUNK",
+    "circuits": [
+      {
+        "id": 713101,
+        "name": "CHI-KIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 607,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-KIE IP TRUNK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-KIE IP TRUNK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.3611",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT MAEEN #NL-MAEEN $GS-00898 | ASN8895 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1756,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "MAEEN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAEEN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "Reserved for GEANT OC to test Virgin Media link",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 513,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.3140",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET SINGAREN #LON-LON-GEANTOPEN-NORDUNET-SINGAREN-CAE1-19074-VL3140 $GS-00975 |",
+    "circuits": [
+      {
+        "id": 705918,
+        "name": "LON-LON-GEANTOPEN-NORDUNET-SINGAREN-CAE1-19074-VL3140",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 763,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 920,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae21.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/1/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER ROEDUNET #ROEDUNET-AP2 $GS-00510 | ASN2614 |",
+    "circuits": [
+      {
+        "id": 679571,
+        "name": "ROEDUNET-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 919,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ROEDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ROEDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:3918",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-02328 $GS-02328",
+    "circuits": [
+      {
+        "id": 747549,
+        "name": "AMS-HAM-MSE-02328",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MICROSOFT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-10/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO MAEEN #MAEEN-GEO-UK-1 P_AE27 | SRF21017 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 913,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "MAEEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAEEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.3005",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER RARE #RARE-02639 $GS-02639 |",
+    "circuits": [
+      {
+        "id": 736109,
+        "name": "RARE-P4-MANAGEMENT-VLAN26",
+        "type": "L2SERVICES",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1518,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ge-1/0/34",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik D IPMI",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 731,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.25",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #FRANKFURT-DRAC | SuperPOP DRAC",
+    "circuits": [
+      {
+        "id": 729098,
+        "name": "FRANKFURT-DRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 969,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.701",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE RARE NETHERLIGHT #AMS-AMS-NETHERLIGHT-RARE-9952733 $GS-00626 |",
+    "circuits": [
+      {
+        "id": 736101,
+        "name": "AMS-AMS-NETHERLIGHT-RARE-9952733",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1117,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 516,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae1.3005",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/1/1",
+      "xe-5/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER RARE #RARE-02641 $GS-02641 | ",
+    "circuits": [
+      {
+        "id": 739308,
+        "name": "RARE-P4-MANAGEMENT-VLAN3005",
+        "type": "L2SERVICES",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 944,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.1338",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SURF SCION #ams-par-SCION-SURF-SCION-23013 $GS-02264 |",
+    "circuits": [
+      {
+        "id": 726377,
+        "name": "AMS-PAR-SCION-SURF-SCION-23013",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1121,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 903,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "1/x1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER LAT P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916417,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LAT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/45",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 546,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | LON2-FRA-QFX | to QFX xe-0/0/41",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1566,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.39",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-RVA-ONEM-ExpressRoute-VLAN4067 $GS-02432 | ",
+    "circuits": [
+      {
+        "id": 739670,
+        "name": "BELNET-RVA-ONEM-EXPRESSROUTE-VLAN4067",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 683,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae10.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_IAS CUSTOMER KIFU #KIFU-AP1-IAS IASPS $GS-00575 | ASN1955 | aka KIFU",
+    "circuits": [
+      {
+        "id": 663070,
+        "name": "KIFU-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 705,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 852,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-9/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 571,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c17/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "''",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900545,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-9/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | NEEDS OPTIC",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1136,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "xe-0/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 561,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUC-CHI-IPTRUNK $GS-00022| BUC-CHI | BUC-CHI-IPTRUNK",
+    "circuits": [
+      {
+        "id": 745144,
+        "name": "BUC-CHI-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 614,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "xe-0/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE4 | rt2-sw2(ex3400) ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 562,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | LR optic connected",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1310,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT GEANT #AMS-FRA-RARE-P4-9951375 $GS-00635 | RARE P4 TESTBED",
+    "circuits": [
+      {
+        "id": 736076,
+        "name": "AMS-FRA-RARE-P4-9951375",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1442,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | RARE EDGECORE WEDGE100BF-32X xe-2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 751,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 887,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "xe-0/1/2",
+      "xe-0/1/3",
+      "xe-0/1/4",
+      "xe-0/1/5"
+    ],
+    "bundle-parents": [
+      "xe-0/1/2",
+      "xe-0/1/3",
+      "xe-0/1/4",
+      "xe-0/1/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-92018 | BUC-CHI",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 587,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | LON2-PAR-QFX | to QFX xe-1/0/42",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1201,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 548,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE  | WAS RASH",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 554,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.3009",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #INFOBLOX-GRID-PAR-FR | Infoblox Grid-PAR",
+    "circuits": [
+      {
+        "id": 733983,
+        "name": "INFOBLOX-GRID-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1304,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/3/2.602",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER UBUNTUNET WACREN #lon-lon-UBUNTUNET-WACREN-20103 $GS-00731 |",
+    "circuits": [
+      {
+        "id": 705895,
+        "name": "LON-LON-UBUNTUNET-WACREN-20103",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1236,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-LON-IPTRUNK $GS-02269 | AMS-LON | ",
+    "circuits": [
+      {
+        "id": 738598,
+        "name": "AMS-LON-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-4/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER DFN P_AE11  |Digital Realty CID: DE225750-3  DFN AP1 400G ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 914,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/14",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 529,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "2/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | GEN-MAR | to RT1.MAR et-4/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162113,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | LR optic connected",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1308,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-2/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | 100GB LR4 CFP2 INSTALLED",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 647,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-5/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic present",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 676,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.28",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #LON2-SPLUNK-SERVER1-iDRAC",
+    "circuits": [
+      {
+        "id": 732437,
+        "name": "LON2-SPLUNK-SERVER1-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 788,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENATER",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1263,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "lag-9.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-HAM-IPTRUNK $GS-00010 | AMS-HAM | ",
+    "circuits": [
+      {
+        "id": 739970,
+        "name": "AMS-HAM-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-HAM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-HAM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.24",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSESTADKORTRIJK-01138 $GS-01138",
+    "circuits": [
+      {
+        "id": 744150,
+        "name": "MSESTADKORTRIJK-01138",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1407,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-7/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | WAS FB-ID: 8644660",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 827,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/0/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #fra-lon2-SUPERPOP-QFX-GEANT $GS-00076 |",
+    "circuits": [
+      {
+        "id": 729416,
+        "name": "FRA-LON2-SUPERPOP-QFX-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1071,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae27.102",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-10/2/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER MAEEN ESNET #LON-LON-GEANTOpen-MAEEN-ESNET-22004 $GS-00464 |",
+    "circuits": [
+      {
+        "id": 738639,
+        "name": "LON-LON-GEANTOPEN-MAEEN-ESNET-22004",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 588,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MAEEN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MAEEN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 567,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "lag-7.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c11/1",
+      "1/1/c11/2",
+      "1/1/c12/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #POZ-PRA-IPTRUNK $GS-02407 | POZ-PRA | ",
+    "circuits": [
+      {
+        "id": 740495,
+        "name": "POZ-PRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-PRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-PRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "et-2/0/2",
+      "et-5/0/2",
+      "et-9/0/5",
+      "et-11/1/5"
+    ],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-5/0/2",
+      "et-9/0/5",
+      "et-11/1/5"
+    ],
+    "description": "LAG CUSTOMER JISC SRF9923031 $GA-01845 | JISC-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 706,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.22",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER GARR MICROSOFT #GARR-ROMA_ExpressRoute_VLAN4088 $GS-01147 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707295,
+        "name": "GARR-ROMA_EXPRESSROUTE_VLAN4088",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1405,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-20.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_IAS CUSTOMER HEANET #HEANET-AP2-IAS IASPS $GS-00573 | ASN1213 | ",
+    "circuits": [
+      {
+        "id": 747415,
+        "name": "HEANET-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:2102",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER KIFU NORDUNET #BUD-HAM-02513 $GS-02513",
+    "circuits": [
+      {
+        "id": 747547,
+        "name": "BUD-HAM-02513",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c24/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ARNES P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917377,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/29",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX12 NIC2 PORT3 - VSAN PORT",
+    "circuits": [
+      {
+        "id": 658585,
+        "name": "LON2-PRD-ESX12-NIC2-PORT3",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 677,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.9",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet_fgov_ExpressRoute_Vlan4090 $GS-01124 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739678,
+        "name": "BELNET-FGOV-EXPRESSROUTE-VLAN4090",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 592,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-20:2701",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION EENET #SCION-02356 $GS-02356",
+    "circuits": [
+      {
+        "id": 746463,
+        "name": "SCION-02356",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "EENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | COLT GWS Upstream 1_2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 937,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "xe-0/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 559,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/1.10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX2-SRX1-CH-OFFICE |",
+    "circuits": [
+      {
+        "id": 662939,
+        "name": "SRX2-SRX1-CH-OFFICE",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 509,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "irb.50",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS SRF22066 #SCION-SCION-FRA-INTERNAL-BRIDGE",
+    "circuits": [
+      {
+        "id": 732534,
+        "name": "SCION-SCION-FRA-INTERNAL-BRIDGE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1330,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.1306",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KREONET SWITCH #fra-lon-SCION-SWITCH-KREONET $GS-02294 |",
+    "circuits": [
+      {
+        "id": 727332,
+        "name": "FRA-LON-SCION-SWITCH-KREONET",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1247,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KREONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-1/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE AKAMAI  P_AE27 | Interxion ID: DP28378",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 923,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | SPLUNK LON2 PEER02 link Slot7 P1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1592,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-3/0/4",
+      "et-3/1/4"
+    ],
+    "bundle-parents": [
+      "et-3/0/4",
+      "et-3/1/4"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02468 | LON2-LON2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 620,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-LON2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-LON2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE5     | LON2-PRD-ESX21 NIC2 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 525,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS PERFSONAR  SRF0000001 | uat-psmp.lon2.uk.geant.net OWAMP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1591,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-10/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1565,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "xe-3/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P6",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 535,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/12",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE11    | LON2-PRD-ESX01 NIC2 PORT2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 663,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | PREVIOUSLY ORANGE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 649,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "et-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | QSFP LR4 optic installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 556,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 788,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.4006",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC NKN #AMS-LON-5GUK-JISC-NKN-22048 $GS-02162 | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1760,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae16.2001",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/1",
+      "xe-1/2/3",
+      "xe-2/0/7",
+      "xe-2/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS SUPERPOP #ESXI-Management-Lon2 $GS-00074 | ESXI MANAGEMENT",
+    "circuits": [
+      {
+        "id": 661564,
+        "name": "ESXI-MANAGEMENT-LON2",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1773,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae30.3006",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/0/5",
+      "xe-4/1/2",
+      "xe-4/2/2"
+    ],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-CONTROL-IMS-MEDIATION-PAR-FR $GS-00863 | IMS Mediation Gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 712153,
+        "name": "TAAS-CONTROL-IMS-MEDIATION-LOGICAL-INTERFACE-PAR-FR",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 812,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT UBUNTUNET P_AE17 | Digital Realty CID: NL247648",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 673,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "ae10.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/1",
+      "xe-0/1/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER URAN #URAN-AP1 $GS-00520 | ASN12687 |",
+    "circuits": [
+      {
+        "id": 714001,
+        "name": "URAN-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 588,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 598,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "1/1/c25/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER DFN P_lag-20 | Circuit ID: 2007330347 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610901057,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae13.50",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-10/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER SWITCH #PAR-PAR-GRID5000-RENATER-SWITCH-20026 $GS-00750 |",
+    "circuits": [
+      {
+        "id": 714182,
+        "name": "PAR-PAR-GRID5000-RENATER-SWITCH-20026",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 732,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.191",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET REDIRIS #HAM-MAD-02343 $GS-02343",
+    "circuits": [
+      {
+        "id": 747542,
+        "name": "HAM-MAD-02343",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 721,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1040,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae7.20",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #LON2-LON2-AMT-RELAYLINK-IAS $GS-02638 | ",
+    "circuits": [
+      {
+        "id": 747034,
+        "name": "LON2-LON2-AMT-RELAYLINK-IAS",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 931,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae16.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER RASH #RASH-AP1-100G $GS-02325 | ASN57961 |",
+    "circuits": [
+      {
+        "id": 727800,
+        "name": "RASH-AP1-100G",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 943,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RASH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RASH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE4     | LON2-PRD-ESX20 NIC2 PORT3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 661,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.101",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE GEANT #AMS-AMS-WP7TSF-RARE-200105-AMS",
+    "circuits": [
+      {
+        "id": 736083,
+        "name": "AMS-AMS-WP7TSF-RARE-200105-AMS",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1528,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "1/1/c12/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | POZ-PRA | to RT0.POZ 2/1/c9/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900225,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #EXFO-MANAGEMENT-VLAN11 | EXFO Management VLAN 11",
+    "circuits": [
+      {
+        "id": 740506,
+        "name": "EXFO-MANAGEMENT-VLAN11",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 878,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae21",
+    "bundle": [
+      "xe-5/0/5",
+      "xe-5/0/6"
+    ],
+    "bundle-parents": [
+      "xe-5/0/5",
+      "xe-5/0/6"
+    ],
+    "description": "LAG UPSTREAM COLT $GA-02112 | COLT ID: 342349627",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 662,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 524,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-2/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE APPLE-1 P_AE45 | ASN714",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 696,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 916,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae12",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01684 | FRA-PRD-ESX04 VM Traffic LAG",
+    "circuits": [
+      {
+        "id": 658677,
+        "name": "FRANKFURT 15-FRANKFURT 15-LAG-061(GEANT)",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 581,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/12",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE11    | LON2-PRD-ESX01 NIC1 PORT2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 526,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-5/0/8",
+      "xe-5/0/9"
+    ],
+    "bundle-parents": [
+      "xe-5/0/8",
+      "xe-5/0/9"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001| rt1-sw2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 887,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c8/1",
+      "2/x1/1/c8/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUD-ZAG-IPTRUNK $GS-00027 | BUD-ZAG | ",
+    "circuits": [
+      {
+        "id": 747898,
+        "name": "BUD-ZAG-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 8,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-ZAG",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-ZAG",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:1008",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET RNP #IMINDS-00680 $GS-00680",
+    "circuits": [
+      {
+        "id": 745349,
+        "name": "IMINDS-00680",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RNP",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/13",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 529,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/0/4",
+      "et-7/1/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LON-LON-IPTRUNK $GS-02467| LON-LON | RT0.LON-MX1.LON",
+    "circuits": [
+      {
+        "id": 738586,
+        "name": "LON-LON-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1163,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 692,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae24.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT TENET #NL-TENET $GS-01182 | ASN2018",
+    "circuits": [
+      {
+        "id": 732999,
+        "name": "NL-TENET",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 972,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "TENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/0.937",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDIRIS GEANT #BIL-GEN-REDIRIS-RARE $GS-02288 |",
+    "circuits": [
+      {
+        "id": 726620,
+        "name": "BIL-GEN-REDIRIS-RARE",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 855,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/3/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 610,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "xe-0/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 559,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae10.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-2/1/5",
+      "et-11/1/0"
+    ],
+    "description": "SRV_L3VPN CUSTOMER GARR #GARR-AP1-LHCONE $GS-00825 | ASN137",
+    "circuits": [
+      {
+        "id": 661882,
+        "name": "GARR-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 791,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS PERFSONAR SRF9925113 | psmp-lhc-bw-lon-uk.geant.org pS BWCTL (LHCONE)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1451,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae1.3005",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/3/0",
+      "xe-1/3/1"
+    ],
+    "description": "SRV_VPLS INFRASTRUCTURE VLAN3005 #RARE-P4-B1-POZ | RARE P4 b1.poz MGMT CONTACT: mian.usman@geant.org IMPLEMENTED: 20200116",
+    "circuits": [
+      {
+        "id": 727552,
+        "name": "RARE-P4-B1-POZ",
+        "type": "L2SERVICES",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 840,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "et-3/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | LON2-LON2 | TO RT0.LON2.UK-1/1/C19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 616,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae11.400",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-2/1/5"
+    ],
+    "description": "SRV_GCS Customer CESNET MICROSOFT #CESNET-NACIT-ExpressRoute-VLAN400 $GS-02174  | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 725107,
+        "name": "CESNET-NACIT-EXPRESSROUTE-VLAN400",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 939,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae13.203",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-10/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION SWITCH #par-par-SCION-SWITCH $GS-02209 |",
+    "circuits": [
+      {
+        "id": 721429,
+        "name": "PAR-PAR-SCION-SWITCH",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 969,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-0/0/42",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE14    | 10_GBS to MX1.PAR.FR xe-4/1/7",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 544,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER MICROSOFT EXPRESSROUTE #1 |GEANT-EXR01-AMS21-PRI-06162020 | Digital Realty CID: NL144337-1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 646,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "LAG INFRASTRUCTURE LAN $GA- | Uplink LAG to sw5.lon.uk.geant.net",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 614,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02267 | AMS-LON",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.954",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER REDIRIS #PSNC-RedIRIS-SLICES-UPV/EHU $GS-02493|",
+    "circuits": [
+      {
+        "id": 739389,
+        "name": "PSNC-REDIRIS-SLICES-UPV/EHU",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 915,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "lag-9",
+    "bundle": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01923 | AMS-HAM",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177289,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-HAM",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-HAM",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c9/2",
+      "2/1/c11/1",
+      "2/1/c11/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #POZ-POZ-IPTRUNK $GS-02528 | POZ-POZ | POZ-POZ-MGMT",
+    "circuits": [
+      {
+        "id": 740149,
+        "name": "POZ-POZ-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-POZ",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-POZ",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.409",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_GCS CUSTOMER REDIRIS MICROSOFT #RedIRIS-USC-ExpressRoute-Vlan409 $GS-01167 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 708369,
+        "name": "REDIRIS-USC-EXPRESSROUTE-VLAN409",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1091,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-4/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RASH P_AE16 100G | to MIX MMR ODF MOD5 P01 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 938,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RASH",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RASH",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "1/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | FRA-GEN | to GEN01-GRV2 port 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899777,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:3921",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET RARE #AMS-HAM-02430 $GS-02430",
+    "circuits": [
+      {
+        "id": 747548,
+        "name": "AMS-HAM-02430",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae32.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/0"
+    ],
+    "description": "SRV_IAS PRIVATE ORANGE #FR-ORANGE-2280 $GS-02180 | ASN2280 |",
+    "circuits": [
+      {
+        "id": 720102,
+        "name": "FR-ORANGE-2280",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 809,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "ORANGE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORANGE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/6.1624",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION INTERNET2 #fra-par-SCION-SCION-INTERNET2-1 $GS-02296 |",
+    "circuits": [
+      {
+        "id": 736667,
+        "name": "FRA-PAR-SCION-SCION-INTERNET2-1",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1336,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/1/4.2710",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER ESnet #lon-poz-PIONIER-ESnet-Quantum-Demo-VL2710 $GS-02557 |",
+    "circuits": [
+      {
+        "id": 739897,
+        "name": "LON-POZ-PIONIER-ESNET-QUANTUM-DEMO-VL2710",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1529,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae23.611",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L3VPN CUSTOMER SWITCH #SWITCH-UNIBE-LHCONE $GS-02378 | AS216467",
+    "circuits": [
+      {
+        "id": 729642,
+        "name": "SWITCH-UNIBE-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 722,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae7.20",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #AMS-AMS-AMT-RELAYLINK-IAS $GS-02636 | ",
+    "circuits": [
+      {
+        "id": 744351,
+        "name": "AMS-AMS-AMT-RELAYLINK-IAS",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1711,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/0/2.500",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF #PRA-POZ-RARE-BMS9 $GS-02628",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 870,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19",
+    "bundle": [
+      "et-3/0/4"
+    ],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "LAG RE_INTERCONNECT INTERNET2  $GA-01477  | INTERNET2-ANA-400G to BOSTON",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 691,
+    "dashboards": [
+      "ANA",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-22",
+    "bundle": [
+      "1/x1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "LAG CUSTOMER RESTENA | $GA-01818 | #RESTENA-AP2-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177302,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "RESTENA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #COR-DUB-IPTRUNK $GS-02383 | COR-DUB | ",
+    "circuits": [
+      {
+        "id": 747279,
+        "name": "COR-DUB-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 6,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-DUB",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-DUB",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae33.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER NORDUNET #NORDUNET-AP3 $GS-02552 | ASN2603 |",
+    "circuits": [
+      {
+        "id": 739582,
+        "name": "NORDUNET-AP3",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1683,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 521,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae28.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/3/0"
+    ],
+    "description": "SRV_IAS UPSTREAM COLT #COLT-GWS-VIE $GS-00070 | ASN3356",
+    "circuits": [
+      {
+        "id": 720369,
+        "name": "COLT-GWS-VIE",
+        "type": "GWS - UPSTREAM",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1006,
+    "dashboards": [
+      "IAS_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COLT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COLT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "1/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915972,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #DUB-LON-IPTRUNK $GS-00031 | DUB-LON | ",
+    "circuits": [
+      {
+        "id": 747278,
+        "name": "DUB-LON-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "DUB-LON",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DUB-LON",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER HEANET | $GA-01925 | #HEANET-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "et-2/1/2",
+      "et-2/1/5",
+      "et-11/1/0"
+    ],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-2/1/5",
+      "et-11/1/0"
+    ],
+    "description": "LAG CUSTOMER GARR SRF9923977 $GA-01773 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 789,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4065",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-MSER-NCCN-ExpressRoute-VLAN4065 $GS-02371  | ",
+    "circuits": [
+      {
+        "id": 739672,
+        "name": "BELNET-MSER-NCCN-EXPRESSROUTE-VLAN4065",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1659,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.123",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET ESNET #lon-lon-GEANTOpen-ESnet-NORDUNET-15039-1 $GS-00963 |",
+    "circuits": [
+      {
+        "id": 738642,
+        "name": "LON-LON-GEANTOPEN-ESNET-NORDUNET-15039-1",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1269,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae23.600",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SWITCH AMS-IX #AMS-GEN-NREN-IX-AMSIX-SWITCH-18008 $GS-00638 |",
+    "circuits": [
+      {
+        "id": 734173,
+        "name": "AMS-GEN-NREN-IX-AMSIX-SWITCH-18008",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1275,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-IX",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/44",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE30 | to QFX1.LON2.UK xe-0/0/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 544,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae17.802",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/6"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER UBUNTUNET INTERNET2 #AMS-LON-MISC-UBUNTUNET-INTERNET2-170342 $GS-00647 |",
+    "circuits": [
+      {
+        "id": 735619,
+        "name": "AMS-LON-MISC-UBUNTUNET-INTERNET2-170342",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1346,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-8/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENATER P_AE14 | RENATER-100GB-LL1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1530,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 576,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "lag-5",
+    "bundle": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02457 | AMS-AMS",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177285,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "et-0/0/1"
+    ],
+    "bundle-parents": [
+      "et-0/0/1"
+    ],
+    "description": "LAG CUSTOMER RENAM SRF21066 $GA-02016 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 588,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.202",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT INTERNET2 #UK-INTERNET2-NEA3R-202 $GS-00919 | ASN11537 | NEA3R-Internet2",
+    "circuits": [
+      {
+        "id": 709338,
+        "name": "UK-INTERNET2-NEA3R-202",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 836,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 606,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO HBKU #HBKU-GEO-UK-1 $GA-01458 |  SRF18085 | Equinix ID: 20873393 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 748,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "HBKU",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HBKU",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-0/0/45",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PSY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 545,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.976",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET REDIRIS #SLCUTH-02498 $GS-02498|",
+    "circuits": [
+      {
+        "id": 745414,
+        "name": "SLCUTH-02498",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 734,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/45",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 685,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae15.990",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET RENATER #AMS-MAR-ITER-IFERC-SINET-RENATER-24039 $GS-00637 |",
+    "circuits": [
+      {
+        "id": 738726,
+        "name": "AMS-MAR-ITER-IFERC-SINET-RENATER-24039",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 732,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4083",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSETHOMASMORE-02475 $GS-02475",
+    "circuits": [
+      {
+        "id": 744238,
+        "name": "MSETHOMASMORE-02475",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.31",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER CESNET MICROSOFT #CESNET-NACIT-ExpressRoute-VLAN401 $GS-02175  | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 724682,
+        "name": "CESNET-NACIT-EXPRESSROUTE-VLAN401",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 611,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.50",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #DASHBOARD-SERVER-AMS-VLAN50 | DBOARD",
+    "circuits": [
+      {
+        "id": 736875,
+        "name": "DASHBOARD-SERVER-AMS-VLAN50",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1515,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1340,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "1/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER EENET P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917505,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "EENET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EENET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae12.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2"
+    ],
+    "description": "SRV_IAS PUBLIC AMS-IX #IX-PEERINGS-IN-AMS-IX $GS-00955 |",
+    "circuits": [
+      {
+        "id": 734937,
+        "name": "IX-PEERINGS-IN-AMS-IX",
+        "type": "IP PEERING - NON R&E (PUBLIC)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1337,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PUBLIC"
+    ],
+    "dashboard_info": {
+      "name": "AMS-IX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-IX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1313,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae10.2805",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KIFU REDIRIS #UPV/EHU-REDIRIS-KIFU-SLICES-SZTAKI $GS-02518 | ",
+    "circuits": [
+      {
+        "id": 739311,
+        "name": "UPV/EHU-REDIRIS-KIFU-SLICES-SZTAKI",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 882,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae30.2001",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/0/5",
+      "xe-4/1/2",
+      "xe-4/2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS SUPERPOP #ESXI-Management-Par $GS-00075 | ESXI MANAGEMENT",
+    "circuits": [
+      {
+        "id": 712148,
+        "name": "ESXI-MANAGEMENT-PAR",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 964,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae47.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2"
+    ],
+    "description": "SRV_IAS PRIVATE FACEBOOK #FACEBOOK-32934-FRA-PCDE-90606625 $GS-02484| ASN32934",
+    "circuits": [
+      {
+        "id": 737788,
+        "name": "FACEBOOK-32934-FRA-PCDE-90606625",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1609,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "FACEBOOK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FACEBOOK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae13.422",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SANET ACONET #BRA-VIE-ACONET-SANET $GS-02379 |",
+    "circuits": [
+      {
+        "id": 729694,
+        "name": "BRA-VIE-ACONET-SANET",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 616,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.11",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #NE-ESXI-FRA-DE-TNMS-VLAN11 | ne-esxi-prod-fra-1 TNMS-VMs Portgroup",
+    "circuits": [
+      {
+        "id": 732631,
+        "name": "NE-ESXI-FRA-DE-TNMS-VLAN11",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1404,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01846 | LON-LON2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "2/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | PRA-VIE | to MX1.VIE et-1/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162114,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-9/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER SURF P_AE11 | 200GB AP2 1_2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1404,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "et-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER FCCN P_AE10 SRF9928603",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 552,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 636,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae3.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-bra-sk $GS-00149 | SW1-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 731619,
+        "name": "EX3400-MANAGEMENT-BRA-SK",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 622,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "et-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | BREN AP2 upgrade - needs SR4 optic | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 607,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "et-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE3 | CHI-KIE | RETN CID: OC-904687-3.MD.CSN.TRB-UA.KIV.KPI-50GHZ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 619,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-KIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-KIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 807,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-8/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED FOR DTN-Second port| Needs optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 944,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae12.840",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT SINGAREN #FR-IC1-SINGAREN $GS-02320 | ASN134148 | ",
+    "circuits": [
+      {
+        "id": 727611,
+        "name": "FR-IC1-SINGAREN",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 586,
+    "dashboards": [
+      "IC1",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915970,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 564,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/18",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE14    | LON2-PRD-ESX20 NIC2 PORT4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 669,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1039,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c13/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LON2-PAR-ROLR-IPTRUNK $GS-50066 | LON2-PAR | ",
+    "circuits": [
+      {
+        "id": 746141,
+        "name": "LON2-PAR-ROLR-IPTRUNK$GS-50066",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 9,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-BRU-IPTRUNK $GS-00008 | AMS-BRU | ",
+    "circuits": [
+      {
+        "id": 744129,
+        "name": "AMS-BRU-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 6,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-BRU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-BRU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-1/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae1 | MAR-MIL2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 678,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae30.3007",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #INFOBLOX-FRA-DE | Infoblox vFRA",
+    "circuits": [
+      {
+        "id": 733007,
+        "name": "INFOBLOX-FRA-DE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1135,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae10.1945",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER FCCN MICROSOFT #FCCN-NoveSBE-ExpressRoute-Vlan1945 $GS-01142 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707126,
+        "name": "FCCN-NOVESBE-EXPRESSROUTE-VLAN1945",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 738,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-lhc-par-fr.geant.org pS OWAMP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1291,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae19",
+    "bundle": [
+      "xe-5/1/6",
+      "xe-5/3/4"
+    ],
+    "bundle-parents": [
+      "xe-5/1/6",
+      "xe-5/3/4"
+    ],
+    "description": "LAG UPSTREAM COGENT SRF9946737 $GA-01898 | Cogent ID: 3-001176117 3-001176119",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 656,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.23",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER GARR MICROSOFT #GARR_UDMilano_ExpressRoute_Vlan4087 $GS-01146 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707644,
+        "name": "GARR-UDMILANO-EXPRESSROUTE-VLAN4087",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 604,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_AE2 SRF0000001 | rt1-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 559,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE8     | LON2-PRD-ESX12 NIC1 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 522,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.9",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEFGOV-01132 $GS-01132",
+    "circuits": [
+      {
+        "id": 744263,
+        "name": "MSEFGOV-01132",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1393,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 558,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT UBUNTUNET SRF0000001 $GA-01452 | GEANT+",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1465,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-1/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 679,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "lag-7",
+    "bundle": [
+      "1/1/c11/1",
+      "1/1/c11/2",
+      "1/1/c12/1"
+    ],
+    "bundle-parents": [
+      "1/1/c11/1",
+      "1/1/c11/2",
+      "1/1/c12/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02409 | POZ-PRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177287,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-PRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-PRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae17.420",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/3/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ASNET-AM ASNET-AM AP2 #fra-fra-EAP-ASNET-AM-AP2-CL-25091 $GS-02652 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1709,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "2/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | AMS-LON | to AMS01-GRV3 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162049,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae11.666",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/0/2",
+      "et-10/3/0"
+    ],
+    "description": "SRV_L3VPN CUSTOMER SURF #SURF-AP2-LHCONE $GS-02413 | ASN1103 |",
+    "circuits": [
+      {
+        "id": 732253,
+        "name": "SURF-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1355,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-22",
+    "bundle": [
+      "1/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER CARNET | $GA-01865 | #CARNET-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177302,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CARNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CARNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.21",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #PS-AMS-NL-IDRAC | PERFSONAR IDRAC",
+    "circuits": [
+      {
+        "id": 736089,
+        "name": "PS-AMS-NL-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1514,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "xe-3/0/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 538,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "irb.500",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #RE-AMS-NL-VRF-VLAN500 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1570,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-mgmt-par-fr.geant.org  pS MGMT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1266,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-5/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | rt1-sw3 (ex3400)|",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 828,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-8/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RESTENA P_AE18 | NEW-FRA-LUX | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 925,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RESTENA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.15",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSENCCN-01136 $GS-01136",
+    "circuits": [
+      {
+        "id": 744268,
+        "name": "MSENCCN-01136",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1399,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.56",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #EXFO-MANAGEMENT-VLAN56 | EXFO Management VLAN 30",
+    "circuits": [
+      {
+        "id": 745836,
+        "name": "EXFO-MANAGEMENT-VLAN56",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 729,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/1/4.411",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER ESNET #lon-lon-GEANTOpen-Esnet-Esnet-170391 $GS-00962 |",
+    "circuits": [
+      {
+        "id": 738643,
+        "name": "LON-LON-GEANTOPEN-ESNET-ESNET-170391",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1516,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae5.7",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/0",
+      "xe-0/3/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #NTP5.GEANT.NET",
+    "circuits": [
+      {
+        "id": 661176,
+        "name": "NTP5.GEANT.NET",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 685,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-8/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "temp cable connected to GRV2 1/1/8 to prove Infinera optic fault",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 916,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 603,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.161",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER RENATER #RENATER-AP-RTBH $GS-00503 | ASN2200 | For hearing RTBH routes only",
+    "circuits": [
+      {
+        "id": 661439,
+        "name": "RENATER-AP-RTBH",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 855,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/2/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-poz-pl-bwctl new | BWCTL CONTACT: ivan.garnizov@fau.de IMPLEMENTED: 20160524",
+    "circuits": [
+      {
+        "id": 708161,
+        "name": "PS-POZ-PL-BWCTL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 829,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.1620",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 SCION #par-par-SCION-INTERNET2-SCION-1 $GS-02295 |",
+    "circuits": [
+      {
+        "id": 736658,
+        "name": "PAR-PAR-SCION-INTERNET2-SCION-1",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1141,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #COR-COR-MGMT-IPTRUNK $GS-02618 | COR-COR | COR-COR-MGMT",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-COR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-COR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae22.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/0"
+    ],
+    "description": "SRV_IAS CUSTOMER IUCC #IUCC-AP2-IAS IASGWS $GS-00533 | ASN378 |",
+    "circuits": [
+      {
+        "id": 729998,
+        "name": "IUCC-AP2-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 987,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "IUCC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "IUCC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "xe-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 567,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02472 | PAR-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PAR-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "PAR-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-1/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT NETHERLIGHT | NETHERLIGHT PORT ID: Asd001B-JNX-06 et-0/1/3 (D76BFBF6)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 945,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 592,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mar.fr.geant.net",
+    "name": "lag-5",
+    "bundle": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02589 | MAR-MAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177285,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "2/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | PRA-VIE | to RT0.PRA 2/1/c9/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162177,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c30/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #KIE-POZ-IPTRUNK $GS-00046 | KIE-POZ | ",
+    "circuits": [
+      {
+        "id": 740201,
+        "name": "KIE-POZ-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 6,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-POZ",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-POZ",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae21",
+    "bundle": [
+      "et-2/0/2"
+    ],
+    "bundle-parents": [
+      "et-2/0/2"
+    ],
+    "description": "LAG CUSTOMER IUCC SRF9926387 $GA-01831 | IUCC-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 709,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "IUCC",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "IUCC",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915970,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-101.334",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SRV_IAS CUSTOMER BREN #BREN-AP2-IAS IASPS $GS-00558 | ASN6802 |",
+    "circuits": [
+      {
+        "id": 744964,
+        "name": "BREN-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "13",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "BREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae18.2001",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/2"
+    ],
+    "description": "SRV_IAS PUBLIC CIXP #IX-Peerings-in-CIXP $GS-00946 |",
+    "circuits": [
+      {
+        "id": 663212,
+        "name": "IX-PEERINGS-IN-CIXP",
+        "type": "IP PEERING - NON R&E (PUBLIC)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 864,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PUBLIC"
+    ],
+    "dashboard_info": {
+      "name": "CIXP",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CIXP",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae17.2128",
+    "bundle": [],
+    "bundle-parents": [
+      "et-10/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CANARIE SURF #PAR-PAR-CANARIE-SURF-20058 $GS-00749 |",
+    "circuits": [
+      {
+        "id": 679228,
+        "name": "PAR-PAR-CANARIE-SURF-20058",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1068,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CANARIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURFNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "2/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | LON-LON2 | to LON01.GRV2 - 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162049,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-11/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 863,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "irb.260",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN INFRASTRUCTURE ACCESS TAAS GTS #TAAS-CONTROL-LONDON | TAAS CONTROL",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1051,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE IT_INFRA | to QFX xe-1/0/18",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1315,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "ae7",
+    "bundle": [
+      "et-1/0/5",
+      "et-1/1/5"
+    ],
+    "bundle-parents": [
+      "et-1/0/5",
+      "et-1/1/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01932 | BUC-BUD",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 672,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae20",
+    "bundle": [
+      "xe-2/0/3",
+      "xe-2/1/1"
+    ],
+    "bundle-parents": [
+      "xe-2/0/3",
+      "xe-2/1/1"
+    ],
+    "description": "LAG CUSTOMER NKN $GA-02088 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 710,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NKN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "NKN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS PERFSONAR SRF0000001 | uat-psmp.lon2.uk.geant.net BWCTL",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1590,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 551,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE16 | QFX.LON2.UK xe-1/0/47",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1576,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4067",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEAZDELTA-02564 $GS-02564",
+    "circuits": [
+      {
+        "id": 744149,
+        "name": "MSEAZDELTA-02564",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-21.111",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c26/1"
+    ],
+    "description": "SRV_L3VPN CUSTOMER EENET #EENET-AP2-LHCONE $GS-00819 | ASN3221 | ",
+    "circuits": [
+      {
+        "id": 745973,
+        "name": "EENET-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "10",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "EENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1269,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae11.500",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-2/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CESNET #pra-vie-CESNET-AP1-CESNET-AP2 $GS-02344 |",
+    "circuits": [
+      {
+        "id": 728645,
+        "name": "PRA-VIE-CESNET-AP1-CESNET-AP2",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 964,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/19",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE15    | LON2-PRD-ESX21 NIC2 PORT2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 535,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.102",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE RARE #AMS-PAR-RARE-RARE-21101 $GS-00656 |",
+    "circuits": [
+      {
+        "id": 736095,
+        "name": "AMS-PAR-RARE-RARE-21101",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1529,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae32.3000",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/0",
+      "et-5/0/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS SUPERPOP #VM-Datanetwork-LON2-AE32 $TBA | VM DATA network",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 920,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SRX-2 To Switch Cluster ge-2/0/0",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 517,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 852,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 608,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/1/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LIS-PAR-IPTRUNK $GS-02633| LIS-PAR | ",
+    "circuits": [
+      {
+        "id": 745054,
+        "name": "LIS-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 728,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae25",
+    "bundle": [
+      "xe-11/2/6"
+    ],
+    "bundle-parents": [
+      "xe-11/2/6"
+    ],
+    "description": "LAG PRIVATE T-SYSTEMS SRF9939159 $GA-01947 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1141,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-21",
+    "bundle": [
+      "1/x1/1/c9/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c9/2"
+    ],
+    "description": "LAG CUSTOMER AMRES | $GA-02239 | #AMRES-AP2-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177301,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "AMRES",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMRES",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 591,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae11.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/1/5"
+    ],
+    "description": "SRV_IAS CUSTOMER UOM #UOM-AP1-IAS IASGWS $GS-00548 | ASN12046 | ",
+    "circuits": [
+      {
+        "id": 722111,
+        "name": "UOM-AP1-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 651,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "UOM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UOM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 607,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COGENT P_AE29 | Cogent ID: 3-001176140",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1051,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COGENT - VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT - VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.3001",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NETHERLIGHT QNREN #lon-par-GEANTOpen-Netherlight-QNREN-15032 $GS-00972 |",
+    "circuits": [
+      {
+        "id": 736886,
+        "name": "LON-PAR-GEANTOPEN-NETHERLIGHT-QNREN-15032",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1592,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "QNREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.29",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEUCLOUVAIN-02152 $GS-02152",
+    "circuits": [
+      {
+        "id": 744146,
+        "name": "MSEUCLOUVAIN-02152",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1411,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.210",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-uat-fra-de-idrac |perfSONAR UAT IDRAC",
+    "circuits": [
+      {
+        "id": 732656,
+        "name": "PS-UAT-FRA-DE-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1412,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-4/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC CIXP P_AE18 | CIXP port: e513-x-yjuxm-1/0/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1435,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "2/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | HAM-POZ | to MX1.POZ et-7/1/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162177,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae28.220",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 TENET #lon-par-GEANTOPEN-INTERNET2-TENET-19004 $GS-00970 |",
+    "circuits": [
+      {
+        "id": 736663,
+        "name": "LON-PAR-GEANTOPEN-INTERNET2-TENET-19004",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 646,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-21",
+    "bundle": [
+      "1/x1/1/c26/1",
+      "1/x1/1/c26/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c26/1",
+      "1/x1/1/c26/2"
+    ],
+    "description": "LAG CUSTOMER ULAKBIM | $GA-01904 | #ULAKBIM-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177301,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "lag-8.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-FRA-IPTRUNK $GS-00009 | AMS-FRA | ",
+    "circuits": [
+      {
+        "id": 739045,
+        "name": "AMS-FRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER MICROSOFT EXPRESSROUTE #2 P_AE31  | Interxion CID: DE133662-2 |  GEANT-FRA32-09XGMR-CIS-2-SEC-11012019",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 855,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-21.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c9/2"
+    ],
+    "description": "SRV_IAS CUSTOMER AMRES #AMRES-AP2-IAS IASGWS $GS-02241 | ASN13092 | ",
+    "circuits": [
+      {
+        "id": 744957,
+        "name": "AMRES-AP2-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "7",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "AMRES",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMRES",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.2023",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET INTERNET2 #AMS-PAR-GEANTOPEN-NORDUNET-INTERNET2-17008 $GS-00959 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1746,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01698 | LON2-PRD-ESX12 ESXI Traffic LAG - LACP Passive",
+    "circuits": [
+      {
+        "id": 658666,
+        "name": "LON2-PRD-ESX12-ESXI-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 598,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-0/0/17",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE                         | SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 534,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 659,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01693 | LON2-PRD-ESX10 ESXI Traffic LAG - LACP Passive Enabled",
+    "circuits": [
+      {
+        "id": 658665,
+        "name": "LON2-PRD-ESX10-ESXI-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 596,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-9/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | PAR-PAR | TO RT0.PAR  2/1/C19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 887,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PAR-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PAR-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/14",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 530,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/13",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE12    | LON2-PRD-ESX02 NIC1 PORT2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 527,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 914,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.27",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #LON2-DTN-SERVER-1-iDRAC",
+    "circuits": [
+      {
+        "id": 726226,
+        "name": "LON2-DTN-SERVER-1-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 623,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-22:705",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET BELNET #FED4FIRE-00668 $GS-00668",
+    "circuits": [
+      {
+        "id": 745508,
+        "name": "FED4FIRE-00668",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae37",
+    "bundle": [
+      "xe-11/2/5"
+    ],
+    "bundle-parents": [
+      "xe-11/2/5"
+    ],
+    "description": "PHY CUSTOMER AZSCIENCENET SRF19095 $GA-01599 | GEANT-10G-Baku-CO-Interxion|",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1690,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "AZSCIENCENET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AZSCIENCENET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 648,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "xe-3/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 537,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-8/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER REDIRIS P_AE16 SRF20096 |Equinix CID: M12I-03D-57/58(on.cable)  P1/P2 in odf-mmr pp0101:14102749 (direct)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1142,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-11/0/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-vie-at-management |perfSONAR MGMT",
+    "circuits": [
+      {
+        "id": 661769,
+        "name": "PS-VIE-AT-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 999,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-11/1/2.111",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS DTN-PROJECT SRF0000001 | LHCone 100G Testing CONTACT: Richard.Hughes-Jones@geant.org IMPLEMENTED: ????????",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1425,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae1.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/0",
+      "xe-3/0/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-bil-es $GS-00148 | SW1-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 709869,
+        "name": "EX3400-MANAGEMENT-BIL-ES",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 522,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1277,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "1/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | MIL2-MIL2 | to RT1.MIL2.IT et-1/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900034,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/3.1305",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SWITCH KREONET #lon-par-SCION-KREONET-SWITCH $GS-02293 |",
+    "circuits": [
+      {
+        "id": 727330,
+        "name": "LON-PAR-SCION-KREONET-SWITCH",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1292,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KREONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "xe-0/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 569,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae10.3015",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-5/0/2",
+      "et-9/0/5",
+      "et-11/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC JISC #DUB-LON-NRENBBEXT-JISC-13015 $GS-00690 | backup for niran",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 733,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "xe-3/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 661,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/3.1303",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SWITCH KREONET #ams-par-SCION-KREONET-SWITCH $GS-02291 |",
+    "circuits": [
+      {
+        "id": 727383,
+        "name": "AMS-PAR-SCION-KREONET-SWITCH",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1293,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/2/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 615,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-22",
+    "bundle": [
+      "2/x1/1/c2/1"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c2/1"
+    ],
+    "description": "LAG CUSTOMER GRNET | $GA-01364 | #GRNET-LHCONE | GRNET-LHCONE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177302,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.500",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NEA3R SURF #LON-LON-NEA3R-SURF-22015 $GS-00707 |",
+    "circuits": [
+      {
+        "id": 718304,
+        "name": "LON-LON-NEA3R-SURF-22015",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1002,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NEA3R",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NEA3R",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SURFNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN $GA-02076 | rt1-sw3 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1017,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae31.300",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/3/5",
+      "xe-8/0/0"
+    ],
+    "description": "SRV_INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 - VM BGP | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 936,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-lhc-owd-fra.de.geant.org pS OWAMP (OWAMP)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 552,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.3020",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #AMS-LON-SINET-SD-WAN-SINET-SINET-17084 $GS-00648 |",
+    "circuits": [
+      {
+        "id": 740717,
+        "name": "AMS-LON-SINET-SD-WAN-SINET-SINET-17084",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 669,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-9/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC LINX P_AE20 | LINX port: core4-tch-re1 - et-7/5/2  |  Equinix CID: 23049089",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1405,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | PAR-LON2-QFX | to QFX xe-0/0/42",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1275,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/0/0.666",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #RARE-PAR-FR | RARE CONTACT: frederic.loui@renater.fr ",
+    "circuits": [
+      {
+        "id": 716843,
+        "name": "RARE-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 584,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c8/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MIL2-THE-IPTRUNK $GS-02609 | MIL2-THE | MIL2-THE",
+    "circuits": [
+      {
+        "id": 745270,
+        "name": "MIL2-THE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 8,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-THE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-THE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ULAKBIM P_lag-21",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917505,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "xe-0/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | BUC-CHI | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 569,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE DTN-Project #DTN-LON2-10G-DATA $GA-02284 | Under testing ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1572,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | SPLUNK LON2 PEER01 link Slot4 P1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1581,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/1.10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX1-SRX2-CH-OFFICE |",
+    "circuits": [
+      {
+        "id": 662954,
+        "name": "SRX1-SRX2-CH-OFFICE",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 535,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/5",
+      "et-0/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LIS-POR-IPTRUNK $GS-00050 | LIS-POR IP TRUNK",
+    "circuits": [
+      {
+        "id": 708705,
+        "name": "LIS-POR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 593,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-POR IP TRUNK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-POR IP TRUNK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER CESNET #ams-pra-IX-CESNET-AMS-12016 $GS-00786|",
+    "circuits": [
+      {
+        "id": 720237,
+        "name": "AMS-PRA-IX-CESNET-AMS-12016",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1307,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE3 | MX1-SW1 | (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 573,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MX1-SW1",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MX1-SW1",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae13.106",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ESNET #CH-ESNET-IPV6 $GS-00873 | ASN293 | IPv6",
+    "circuits": [
+      {
+        "id": 730105,
+        "name": "CH-ESNET-IPV6",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1285,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1197,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.2301",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER LAT SURF #LOFAR-02584 $GS-02584",
+    "circuits": [
+      {
+        "id": 745938,
+        "name": "LOFAR-02584",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1707,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 559,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/2/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 600,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae13.37",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-10/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET SCION #FED4FIRE-00682 $GS-00682",
+    "circuits": [
+      {
+        "id": 745343,
+        "name": "FED4FIRE-00682",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 735,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/2/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #ams-fra-IT_INFRA-QFX-GEANT $GS-02556 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1686,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "1/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-6 | KAU-POZ | to RT2.KAU.LT et-0/0/1 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900034,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-10/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CERN EXT-2 P_AE22 SRF23043-2 | 18:2a:d3:0f:bd:b0 519 E773-E-RJUXM-2.cern.ch",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1250,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/2/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 587,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-2/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No Optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1035,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-1/0/28",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae0     | RT1 xe-7/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 542,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-101.31",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "SRV_IAS PRIVATE OPTIMA-TELEKOM #HR-EduZone $GS-00936 | For Eduzone",
+    "circuits": [
+      {
+        "id": 747941,
+        "name": "HR-EDUZONE",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "5",
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "OPTIMA-TELEKOM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "OPTIMA-TELEKOM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-23.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3"
+    ],
+    "description": "SRV_IAS CUSTOMER MARNET #MARNET-AP2-IAS IASPS $GS-00537 | ASN44224 | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "18",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "MARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-6 | FRA-PRA | to RT0.FRA 1/1/C9/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900033,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-5/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 988,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bra.sk.geant.net",
+    "name": "1/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | BRA-BRA-MGMT | to RT1.BRA XE-0/1/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA-MGMT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA-MGMT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae49.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/1"
+    ],
+    "description": "SRV_IAS PRIVATE GOOGLE #GOOGLE-FRA15-15169-DE $GS-00934 | ASN15169",
+    "circuits": [
+      {
+        "id": 746058,
+        "name": "GOOGLE-FRA15-15169-DE",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1441,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "GOOGLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GOOGLE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE5 SRF0000001 | RT1.MIL2 to SW2.MIL2 Connected to SW2.MIL2 xe-0/2/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 603,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 589,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 590,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "1/1/c12/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | PRA-PRA | to RT1.PRA et-0/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900226,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/1/5",
+      "et-1/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BIL-POR-IPTRUNK $GS-00017 | BIL-POR IP TRUNK",
+    "circuits": [
+      {
+        "id": 709122,
+        "name": "BIL-POR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 592,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-POR IP TRUNK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-POR IP TRUNK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.906",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 GEANT #lon-lon-MISC-GEANT-INTERNET2-9940197 $GS-00726 |",
+    "circuits": [
+      {
+        "id": 661593,
+        "name": "LON-LON-MISC-GEANT-INTERNET2-9940197",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1587,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-9/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | no optic installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1137,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ge-1/0/37",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX11 IDRAC",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 691,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-1/3/0.3104",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER AARNET SINGAREN #lon-lon-GEANTOpen-AARNET-SINGAREN-CAE1-20044-VL3104 $GS-00960 | ",
+    "circuits": [
+      {
+        "id": 705943,
+        "name": "LON-LON-GEANTOPEN-AARNET-SINGAREN-CAE1-20044-VL3104",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 991,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "AARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.310",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #DTN-PROJECT-VLAN310 $GS-00142 | DTN-Project CONTACT: anura.hettiarachchi@geant.org IMPLEMENTED: 20171206",
+    "circuits": [
+      {
+        "id": 740700,
+        "name": "DTN-PROJECT-VLAN310",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 633,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | FRA-LON2-QFX | to QFX xe-1/0/43",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 547,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "2/x1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CYNET P_lag-21 | CYNET-AP1-IP1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178114,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CYNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CYNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "1/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER HEANET P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917505,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae44.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/1/0"
+    ],
+    "description": "SRV_IAS PRIVATE GOOGLE #GOOGLE-2-FRA15-15169-DE $GS-02226 | ASN15169",
+    "circuits": [
+      {
+        "id": 731227,
+        "name": "GOOGLE-2-FRA15-15169-DE",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1005,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "GOOGLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GOOGLE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.3910",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #Nordunet-HHU-ExpressRoute-Vlan3910 $GS-01156 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 706560,
+        "name": "NORDUNET-HHU-EXPRESSROUTE-VLAN3910",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1201,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4068",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-AZDELTA-ExpressRoute-VLAN4068 GS-02565 | ",
+    "circuits": [
+      {
+        "id": 740640,
+        "name": "BELNET-AZDELTA-EXPRESSROUTE-VLAN4068",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1681,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "2/x1/1/c6/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | ATH2-THE | ATH2-THE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178369,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-THE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-THE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 | mx1-sw1(ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1053,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-3/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 697,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-5/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic present",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 684,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1069,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "1/1/c12/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | VIE-VIE | to MX1.VIE et-1/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900226,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "VIE-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "VIE-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae3.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/8",
+      "xe-3/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-MAR-FR | ",
+    "circuits": [
+      {
+        "id": 719643,
+        "name": "DCN-MANAGEMENT-MAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 605,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae34",
+    "bundle": [
+      "xe-4/2/5",
+      "xe-4/3/1"
+    ],
+    "bundle-parents": [
+      "xe-4/2/5",
+      "xe-4/3/1"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | NEMO DDOS Detection 2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 979,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c12/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900225,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-9/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Disable due to interface flapping",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 564,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:cp-1290",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET RENATER #IMINDS-00670 $GS-00670",
+    "circuits": [
+      {
+        "id": 744061,
+        "name": "IMINDS-00670",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.991",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-LON2-UK | ",
+    "circuits": [
+      {
+        "id": 713898,
+        "name": "DCN-MANAGEMENT-LON2-UK",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 658,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae30.3001",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/0/5",
+      "xe-4/1/2",
+      "xe-4/2/2"
+    ],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-CONTROL-NAGIOS-PAR-FR $GS-00864 | NAGIOS gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 712156,
+        "name": "TAAS-CONTROL-NAGIOS-PAR-FR",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 846,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-10/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 901,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-101.103",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-SOF-BG-VRF-VLAN103 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "3",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/3.501",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX1-City-House-WAN-Gateway |",
+    "circuits": [
+      {
+        "id": 663189,
+        "name": "SRX1-CITY-HOUSE-WAN-GATEWAY",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 545,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-5/0/6.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER ROEDUNET #buc-chi-RENAM-ROEDUNET-240752 $GS-02576 |",
+    "circuits": [
+      {
+        "id": 743607,
+        "name": "BUC-CHI-RENAM-ROEDUNET-240752",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 900,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "ROEDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ROEDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "2/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | BRA-VIE | to RT1.BRA et-0/0/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162178,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "et-3/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | LON2-LON2 | TO RT0.LON2.UK-2/1/C19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 680,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "1/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER BELNET P_lag-23",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915972,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01697 | LON2-SEC-ESX21 ESXI Traffic LAG - No LACP",
+    "circuits": [
+      {
+        "id": 658516,
+        "name": "LON2-SEC-ESX21-ESXI-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 595,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1040,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/7.105",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF SRF21105 $GS-00686 | #BUD-PRA-RARE-BMS8",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 972,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4069",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-RIZIV-INAMI-ExpressRoute-VLAN4069 $GS-02521 | ",
+    "circuits": [
+      {
+        "id": 739661,
+        "name": "BELNET-RIZIV-INAMI-EXPRESSROUTE-VLAN4069",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1662,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "et-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae1 | BRA-BRA",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 596,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/29",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX12 NIC1 PORT3 - VSAN PORT",
+    "circuits": [
+      {
+        "id": 658459,
+        "name": "LON2-PRD-ESX12-NIC1-PORT3",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 648,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "1/x1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | COR-DUB | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916354,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-DUB",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-DUB",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-20:420",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT DFN NKN #AMS-HAM-DFN-NKN-02211 $GS-02211",
+    "circuits": [
+      {
+        "id": 745577,
+        "name": "AMS-HAM-DFN-NKN-02211",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae13",
+    "bundle": [
+      "xe-4/0/6",
+      "xe-4/0/7"
+    ],
+    "bundle-parents": [
+      "xe-4/0/6",
+      "xe-4/0/7"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | NEMO DDOS Detection 1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1003,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-101.103",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-ZAG-HR-VRF-VLAN103 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "3",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 610,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae29.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/0/7",
+      "xe-11/1/2"
+    ],
+    "description": "SRV_IAS UPSTREAM COLT #COLT-GWS-FRA $GS-00069 | ASN3353",
+    "circuits": [
+      {
+        "id": 732143,
+        "name": "COLT-GWS-FRA",
+        "type": "GWS - UPSTREAM",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1154,
+    "dashboards": [
+      "IAS_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COLT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COLT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae10.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER RENAM #RENAM-AP1 $GS-00500 | ASN9199 |",
+    "circuits": [
+      {
+        "id": 714072,
+        "name": "RENAM-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 554,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 599,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.3333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT OMREN #NL-OMREN $GS-00900 | ASN206350 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1754,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "OMREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "OMREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.204",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT NISN #UK-NISN-NEA3R-204 $GS-00922 | ASN297 | NEA3R-NISN",
+    "circuits": [
+      {
+        "id": 661526,
+        "name": "UK-NISN-NEA3R-204",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 862,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "NISN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NISN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "lag-6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c9/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #KAU-POZ-IPTRUNK $GS-00043 | KAU-POZ | ",
+    "circuits": [
+      {
+        "id": 746527,
+        "name": "KAU-POZ-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-POZ",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-POZ",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | RARE BMS SERVER 6",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1449,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-20.111",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_L3VPN CUSTOMER EENET #EENET-AP1-LHCONE $GS-00818 | ASN3221 | ",
+    "circuits": [
+      {
+        "id": 746449,
+        "name": "EENET-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "5",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "EENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO Netherlight #Netherlight-GEO-UK-1 $GA-01481 |  SRF9928315 | GeO NETHERLIGHT 100G | NETHERLIGHT ID: e0404963",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1558,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-4/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 999,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 605,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1343,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.240",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #LON-SINET-EDGE-DEVICE-IDRAC | SINET edge-device-iDRAC",
+    "circuits": [
+      {
+        "id": 740702,
+        "name": "LON-SINET-EDGE-DEVICE-IDRAC",
+        "type": "SERVER LINK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 648,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-26.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/4"
+    ],
+    "description": "SRV_IAS PRIVATE SETCOR #SETCOR-HR-61211 $GS-00942 | ASN 61211",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "SETCOR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SETCOR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-ECMWF2 $GS-01077",
+    "circuits": [
+      {
+        "id": 732674,
+        "name": "GRE-MULTICAST-TUNNEL-ECMWF2",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1212,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-0/0/18",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE5 | 10_GBS to RT1.FRA.DE xe-0/3/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 535,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1306,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 582,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/4.1337",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION SURF #ams-gen-SCION-SURF-SCION-23012 $GS-02263 |",
+    "circuits": [
+      {
+        "id": 726378,
+        "name": "AMS-GEN-SCION-SURF-SCION-23012",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1259,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "ae2.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-CHI2-MD $GS-00128 | DCN MANAGEMENT ",
+    "circuits": [
+      {
+        "id": 715035,
+        "name": "DCN-MANAGEMENT-CHI2-MD",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 612,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_AE2 SRF0000001 | rt1-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 563,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.4",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS Customer BELNET MICROSOFT #BELNET-SCIENSAN0-ExpressRoute-VLAN4073 $GS-02536 | ",
+    "circuits": [
+      {
+        "id": 739673,
+        "name": "BELNET-SCIENSAN0-EXPRESSROUTE-VLAN4073",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 587,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-21",
+    "bundle": [
+      "2/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER EENET | $GA-01737 | #EENET-AP2-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177301,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "EENET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "EENET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1460,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-9",
+    "bundle": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01896 | AMS-HAM",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177289,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-HAM",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-HAM",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-2/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE FACEBOOK P_AE47 | META ID: PCDE-90606625",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 675,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.2637",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA AUTOGOLE Test Connection | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 804,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-1/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | VIE-VIE | to RT0.VIE 1/1/c12/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 922,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "VIE-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "VIE-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.300",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ENSTINET #NL-ENSTINET-AP1 $GS-00892 | ASN6879 | AP1",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1731,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ENSTINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ENSTINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.32",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS Customer BELNET MICROSOFT #BELNET-THOMASMORE-ExpressRoute-VLAN4086 $GS-02476  | ",
+    "circuits": [
+      {
+        "id": 739668,
+        "name": "BELNET-THOMASMORE-EXPRESSROUTE-VLAN4086",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 630,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "xe-3/0/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P10",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 663,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/0.10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX1-AMS-Infrastructure-Management |",
+    "circuits": [
+      {
+        "id": 663032,
+        "name": "SRX1-AMS-INFRASTRUCTURE-MANAGEMENT",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 553,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #SOF-THE-IPTRUNK $GS-02424 | SOF-THE | ",
+    "circuits": [
+      {
+        "id": 745269,
+        "name": "SOF-THE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 14,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-THE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-THE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 604,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae13.3507",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-10/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE RARE P4 #RARE-00774 $GS-00774 |",
+    "circuits": [
+      {
+        "id": 747031,
+        "name": "RARE-00774",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 568,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4093",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEMOBILIT-02169 $GS-02169",
+    "circuits": [
+      {
+        "id": 744269,
+        "name": "MSEMOBILIT-02169",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.3532",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER RARE #RARE-02644 $GS-02644 |",
+    "circuits": [
+      {
+        "id": 745529,
+        "name": "RARE-02644",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 903,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/0/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT GEANT #bud-poz-RARE-P4-9951383 $GS-00685 | RARE P4 TESTBED",
+    "circuits": [
+      {
+        "id": 708292,
+        "name": "BUD-POZ-RARE-P4-9951383",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 799,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae10.3250",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-5/0/2",
+      "et-9/0/5",
+      "et-11/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC NETHERLIGHT #ams-lon-GEANTOpen-JISC-NEA3R $GS-02400 |",
+    "circuits": [
+      {
+        "id": 732708,
+        "name": "AMS-LON-GEANTOPEN-JISC-NEA3R",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1165,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4072",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSESCIENSAN-02535 $GS-02535",
+    "circuits": [
+      {
+        "id": 744226,
+        "name": "MSESCIENSAN-02535",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-7/0/4",
+      "et-7/1/4"
+    ],
+    "bundle-parents": [
+      "et-7/0/4",
+      "et-7/1/4"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02465 | LON-LON",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1157,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/46",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE31    | MX1.LON2.UK xe-1/2/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 547,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4071",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS Customer BELNET MICROSOFT #BELNET-FEDPOL-ExpressRoute-VLAN4071 $GS-02525  | ",
+    "circuits": [
+      {
+        "id": 739671,
+        "name": "BELNET-FEDPOL-EXPRESSROUTE-VLAN4071",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1663,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae1.25",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/1/7",
+      "xe-2/2/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #SCION-gen-ch  | SCION SERVERS",
+    "circuits": [
+      {
+        "id": 740081,
+        "name": "SCION-GEN-CH",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1468,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.3007",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #Infoblox-Trinzic805-Lon2-VLAN3007 | Infoblox Trinzic 805 - DNS",
+    "circuits": [
+      {
+        "id": 679409,
+        "name": "INFOBLOX-TRINZIC805-LON2-VLAN3007",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 797,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/30",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik A Data Port 2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 678,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "lag-9",
+    "bundle": [
+      "1/1/c11/1",
+      "1/1/c11/2"
+    ],
+    "bundle-parents": [
+      "1/1/c11/1",
+      "1/1/c11/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01853 | BUD-VIE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177289,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-VIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-VIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae7.10",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #LON2-LON2-AMT-RELAYLINK $GS-02304 | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 930,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.2",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER FCCN MICROSOFT #FCCN_NoveSBE_ExpressRoute_Vlan1945 $GS-01142 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707126,
+        "name": "FCCN-NOVESBE-EXPRESSROUTE-VLAN1945",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 585,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-0/0/19",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 536,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | MAD-MAR | connected to MAR01-GRV1 1/1/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 676,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-20.12",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER HEANET #HEANET-AP2 $GS-00474 | ASN1213 | ",
+    "circuits": [
+      {
+        "id": 747414,
+        "name": "HEANET-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "5",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.88",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER EUMETSAT #EUMET-BUCC-BIL-20117 $GS-00458 | VLAN 88 MONITORING 86",
+    "circuits": [
+      {
+        "id": 721130,
+        "name": "EUMET-BUCC-BIL-20117",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 843,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "EUMETSAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EUMETSAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-20:715",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET NORDUNET #ATH2-HAM-02500 $GS-02500",
+    "circuits": [
+      {
+        "id": 747639,
+        "name": "ATH2-HAM-02500",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/0/2:2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 534,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae35.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_IAS PRIVATE CLOUDFERRO #DE-CLOUDFERRO-IAS $GS-00603 |ASN200999 |",
+    "circuits": [
+      {
+        "id": 708235,
+        "name": "DE-CLOUDFERRO-IAS",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1031,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "CLOUDFERRO",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CLOUDFERRO",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-par-fr.geant.org pS OWAMP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 756,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/0/0.111",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN RE_INTERCONNECT CNGI-6IX #UK-CNGI-6IX-CERNET-LHCONE $GS-00815 | ASN23911 |",
+    "circuits": [
+      {
+        "id": 661398,
+        "name": "UK-CNGI-6IX-CERNET-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1063,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CNGI-6IX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CNGI-6IX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae18",
+    "bundle": [
+      "et-4/0/2"
+    ],
+    "bundle-parents": [
+      "et-4/0/2"
+    ],
+    "description": "LAG PUBLIC CIXP SRF9930443 $GA-01881 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 708,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "irb.50",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS SRF22066 #SCION-SCION-GEN-INTERNAL-BRIDGE",
+    "circuits": [
+      {
+        "id": 723798,
+        "name": "SCION-SCION-GEN-INTERNAL-BRIDGE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 692,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.375",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINGAREN RARE #AMS-LON-SINGAREN-RARE-123034 $GS-02315 | ",
+    "circuits": [
+      {
+        "id": 736108,
+        "name": "AMS-LON-SINGAREN-RARE-123034",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1530,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-3/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-lis-pt.geant.org pS OWAMP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 700,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae45",
+    "bundle": [
+      "et-10/1/5"
+    ],
+    "bundle-parents": [
+      "et-10/1/5"
+    ],
+    "description": "LAG PRIVATE APPLE SRF9934309 $GA-02394 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 990,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER MICROSOFT  EXPRESSROUTE #2 P_AE20 | Equinix CID: 22903012 | GEANT-EXRJ02-MAD31-SEC-07192024 --P24 in ODF3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 580,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS2-LON-AMT-IPTRUNK $GS-00012 | ",
+    "circuits": [
+      {
+        "id": 736813,
+        "name": "AMS2-LON-AMT-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 584,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15",
+    "bundle": [
+      "et-1/0/5"
+    ],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "LAG RE_INTERCONNECT MANLAN SRF21042 $GA-01821 | ANA-100G to MANLAN",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 687,
+    "dashboards": [
+      "ANA",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "MANLAN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MANLAN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae17.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/1/5"
+    ],
+    "description": "SRV_IAS PRIVATE FACEBOOK #FACEBOOK-32934-LON-FA-1026202 $GS-00928 | ASN32934",
+    "circuits": [
+      {
+        "id": 708275,
+        "name": "FACEBOOK-32934-LON-FA-1026202",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1041,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "FACEBOOK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FACEBOOK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/6.2703",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION WACREN #fra-lon-SCION-WACREN $GS-02496 | ",
+    "circuits": [
+      {
+        "id": 737890,
+        "name": "FRA-LON-SCION-WACREN",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1610,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae22.602",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-10/0/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER UBUNTUNET WACREN #lon-lon-UBUNTUNET-WACREN-20103 $GS-00731 |",
+    "circuits": [
+      {
+        "id": 705895,
+        "name": "LON-LON-UBUNTUNET-WACREN-20103",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1232,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.buc.ro.geant.net",
+    "name": "lag-20.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER ROEDUNET #ROEDUNET-AP1 $GS-00509 | ASN2614 | ",
+    "circuits": [
+      {
+        "id": 747908,
+        "name": "ROEDUNET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "3",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ROEDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ROEDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-7/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | LON-LON | to RT0.LON 1/1/c19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1381,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae23.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/0/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L3VPN CUSTOMER CESNET #CESNET-AP2-LHCONE $GS-02455 | ASN2852",
+    "circuits": [
+      {
+        "id": 733852,
+        "name": "CESNET-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1109,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE ORACLE P_AE40 | Interxion CID: DE188623| Oracle CID: GEANT-Interxion-2-1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 902,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae41.300",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/2/1",
+      "xe-0/2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 - VM BGP | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1356,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-1/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENATER P_AE14 | RENATER-100GB-LL3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1347,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1061,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.252",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_IAS CUSTOMER REDIRIS #REDIRIS-AP1-IAS IASPS $GS-00581 | ASN766",
+    "circuits": [
+      {
+        "id": 719126,
+        "name": "REDIRIS-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 860,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.519",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT RE_INTERCONNECT NISN RENATER #lon-par-CNES-NISN-RENATER $GS-00736 |",
+    "circuits": [
+      {
+        "id": 709305,
+        "name": "LON-PAR-CNES-NISN-RENATER",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 826,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NISN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NISN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4",
+      "et-3/1/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LON2-LON2-IPTRUNK $GS-02470| LON2-LON2 | RT0.LON2-MX1.LON2",
+    "circuits": [
+      {
+        "id": 738843,
+        "name": "LON2-LON2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1137,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-LON2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-LON2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT UBUNTUNET SRF996314 $GA-01463",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1471,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.3503",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER RARE #RARE-02641 $GS-02641 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 871,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.31",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS Customer CESNET MICROSOFT #CESNET-NACIT-ExpressRoute-VLAN400 $GS-02174  | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 725107,
+        "name": "CESNET-NACIT-EXPRESSROUTE-VLAN400",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1413,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16",
+    "bundle": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "LAG CUSTOMER REDIRIS SRF21114 $GA-01800 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 654,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/4.200",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION SWITCH #gen-gen-SCION-SWITCH $GS-02199 |",
+    "circuits": [
+      {
+        "id": 720418,
+        "name": "GEN-GEN-SCION-SWITCH",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 728,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | rt1-sw2 (ex3400) | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 538,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1468,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae18.2602",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER RESTENA #RESTENA-AP1 $GS-00507 | ASN2602 |",
+    "circuits": [
+      {
+        "id": 732142,
+        "name": "RESTENA-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1162,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RESTENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae27.4002",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/2"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT T-SYSTEMS #NL-T-SYSTEMS-R&E $GS-02329 | ASN6878 |",
+    "circuits": [
+      {
+        "id": 734872,
+        "name": "NL-T-SYSTEMS-R&E",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1319,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "T-SYSTEMS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "T-SYSTEMS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae17.400",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/3/4"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER ASNET-AM #ASNET-AM-AP2 $GS-02650 | ASN47623 |",
+    "circuits": [
+      {
+        "id": 746552,
+        "name": "ASNET-AM-AP2",
+        "type": "GEANT IP",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1452,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ASNET-AM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASNET-AM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/0/1:2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 530,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.25",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER NORDUNet SUNET #NORDUNet-SUNET-ExpressRoute-VLAN3914 $GS-01160 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 713462,
+        "name": "NORDUNET-SUNET-EXPRESSROUTE-VLAN3914",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1408,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae10.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/0/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER LITNET #LITNET-AP2 $GS-00487 | ASN2847 |",
+    "circuits": [
+      {
+        "id": 745339,
+        "name": "LITNET-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 881,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LITNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LITNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-0/0/17",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae13    | 10_GBS to RT1.FRA.DE xe-5/0/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 534,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4073",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS Customer BELNET MICROSOFT #BELNET-SCIENSAN0-ExpressRoute-VLAN4073 $GS-02536  | ",
+    "circuits": [
+      {
+        "id": 739673,
+        "name": "BELNET-SCIENSAN0-EXPRESSROUTE-VLAN4073",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1664,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/0/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT GEANT #bud-poz-RARE-P4-9951383 $GS-00685 | RARE P4 TESTBED",
+    "circuits": [
+      {
+        "id": 708292,
+        "name": "BUD-POZ-RARE-P4-9951383",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 786,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS SUPERPOP P_AE30 | QFX xe-0/0/28",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 543,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae11.1103",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/0/2",
+      "et-10/3/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER SURF #SURF-AP2 $GS-00513 | ASN1103 |",
+    "circuits": [
+      {
+        "id": 660540,
+        "name": "SURF-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 859,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/0/6.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-par-fr-management |perfSONAR MGMT",
+    "circuits": [
+      {
+        "id": 722336,
+        "name": "PS-PAR-FR-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1050,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "lag-6",
+    "bundle": [
+      "1/1/c9/2"
+    ],
+    "bundle-parents": [
+      "1/1/c9/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01812 | KAU-POZ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177286,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-POZ",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-POZ",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae13.104",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/4"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ESNET #UK-ESNET-IPV4 $GS-00915 | ASN293 | Lon-ESnet-IPv4-400G",
+    "circuits": [
+      {
+        "id": 730143,
+        "name": "UK-ESNET-IPV4",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 964,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | SPLUNK AMS PEER01 link 1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 630,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.2128",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CANARIE SURF #PAR-PAR-CANARIE-SURF-20058 $GS-00749 |",
+    "circuits": [
+      {
+        "id": 679228,
+        "name": "PAR-PAR-CANARIE-SURF-20058",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1067,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CANARIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURFNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/0/2:1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 536,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LON-LON2-IPTRUNK $GS-00052 | LON-LON2 | ",
+    "circuits": [
+      {
+        "id": 738842,
+        "name": "LON-LON2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-LJU-SI-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "4",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-20.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c25/1"
+    ],
+    "description": "SRV_IAS CUSTOMER DFN #DFN-AP2-IAS IASPS $GS-00567 | ASN680 | ",
+    "circuits": [
+      {
+        "id": 745580,
+        "name": "DFN-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "7",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 556,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c6/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #ATH2-THE-IPTRUNK $GS-02421 | ATH2-THE | ",
+    "circuits": [
+      {
+        "id": 745464,
+        "name": "ATH2-THE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 9,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-THE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-THE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/2",
+      "xe-0/1/3",
+      "xe-0/1/4",
+      "xe-0/1/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUC-CHI-IPTRUNK $GS-90022| BUC-CHI | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 553,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "1/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER BELNET P_lag-23",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915971,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-5",
+    "bundle": [
+      "2/x1/1/c8/1",
+      "2/x1/1/c8/2"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c8/1",
+      "2/x1/1/c8/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01733 | BUC-SOF",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177285,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-SOF",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-SOF",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae1.26",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/1/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ddos-det2-vie-at-idrac | NEMO DDOS Detection 2 iDRAC | MT-TEST-DEV01-VIE",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 663,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS PERFSONAR SRF SRF0000001 | uat-psmp.lon2.uk.geant.net MGMT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1589,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS PERFSONAR SRF0000001 | psmp-gn-bw-lon-uk.geant.org pS BWCTL",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1450,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "1/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | AMS-FRA | to AMS01-GRV1 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900097,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "lag-5",
+    "bundle": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01888 | FRA-GEN",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177285,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.2703",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER BELNET #SLCIMEC-02488 $GS-02488",
+    "circuits": [
+      {
+        "id": 745341,
+        "name": "SLCIMEC-02488",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 777,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE RARE #AMS-FRA-RARE-P4-9951375 $GS-00635 | RARE P4 TESTBED",
+    "circuits": [
+      {
+        "id": 736076,
+        "name": "AMS-FRA-RARE-P4-9951375",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1526,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 656,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-2/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GARR P_AE10 SRF21107|",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 711,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae16.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/3/0"
+    ],
+    "description": "SRV_IAS PRIVATE FACEBOOK #FACEBOOK-32934-VIE-FC-203126783 $GS-00930 | ASN32934",
+    "circuits": [
+      {
+        "id": 738665,
+        "name": "FACEBOOK-32934-VIE-FC-203126783",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 722,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "FACEBOOK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FACEBOOK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-2/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae4 | GEN-MAR | to rt0.gen  2/1/c9/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 700,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-2/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT TENET P_AE24 SRF21084 | Interxion CID NL189955",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 957,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "TENET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | SPLUNK AMS PEER01 link 2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 631,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "et-5/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS IT REFRESH P_AE30 | qfx1.lon2.uk et-1/0/52",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 747,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-3/2/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-lis-pt-bwctl new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 722353,
+        "name": "PS-LIS-PT-BWCTL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 803,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 939,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-2/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC DE-CIX P_AE22 | Digital Realty CID: FR261961 |  DE-CIX ID: : DXDB:PNI:31850",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 698,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae30.3003",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/0/5",
+      "xe-4/1/2",
+      "xe-4/2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-throughput-network-par-fr $GS-00354 | Throughput network",
+    "circuits": [
+      {
+        "id": 712151,
+        "name": "PS-THROUGHPUT-NETWORK-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1468,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/2/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-loc-xx-management |perfSONAR MGMT",
+    "circuits": [
+      {
+        "id": 721398,
+        "name": "PS-LOC-XX-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 828,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.334",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_IAS PRIVATE NORDUNET #NL-NORDUNET-IX-2603 $GS-00939 | ASN2603 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1734,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae4",
+    "bundle": [
+      "et-1/0/5",
+      "et-1/1/2",
+      "et-2/0/2"
+    ],
+    "bundle-parents": [
+      "et-1/0/5",
+      "et-1/1/2",
+      "et-2/0/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02087 | BIL-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 520,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LON2-LON2-IPTRUNK $GS-02470 | LON2-LON2 | RT0.LON2-MX1.LON2",
+    "circuits": [
+      {
+        "id": 738843,
+        "name": "LON2-LON2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-LON2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-LON2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 650,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "2/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | LON2-PAR | TO PAR.GRV3 - 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162241,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-5/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT SINET P_AE20 | Digital Realty  CID: NL248167",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 990,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/13",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE12    | LON2-PRD-ESX02 NIC2 PORT2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 664,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-20.83",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER LAT #LAT-AP1 $GS-00484 | ASN5538 | ",
+    "circuits": [
+      {
+        "id": 745983,
+        "name": "LAT-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.673",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT KREONET #NL-KREONET $GS-00897 | ASN17579 |",
+    "circuits": [
+      {
+        "id": 734548,
+        "name": "NL-KREONET",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1116,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "KREONET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KREONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-6 | FRA-PRA | TO RT1.PRA.CZ-et-0/1/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900033,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae32.3000",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/5",
+      "et-8/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS SUPERPOP #VM-Datanetwork-AMS-IRB $TBA | VM DATA network",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1719,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 752,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | NEMO DDOS SERVER link 2 Node 2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1286,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.25",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01161 $GS-01161",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 606,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 620,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-10/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 910,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER URAN SRF21-059|URAN Circuit ID:GEANT-POZ-IEV-2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 561,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "xe-0/1/0"
+    ],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 $GA-02025 | rt1-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 580,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-2/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae4 | BIL-PAR | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1029,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.991",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-COP-DK | DCN MANAGEMENT",
+    "circuits": [
+      {
+        "id": 714243,
+        "name": "DCN-MANAGEMENT-COP-DK",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 945,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4080",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEUCLOUVAIN-02152 $GS-02152",
+    "circuits": [
+      {
+        "id": 744146,
+        "name": "MSEUCLOUVAIN-02152",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "ae10.333",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/1",
+      "xe-0/1/2"
+    ],
+    "description": "SRV_IAS CUSTOMER URAN #URAN-AP2-IAS IASPS $GS-00594 | ASN12687 |",
+    "circuits": [
+      {
+        "id": 714004,
+        "name": "URAN-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 611,
+    "dashboards": [
+      "EAP",
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-1/3/0.1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO AARNET #AARNET-GEO-UK-1 |  SRF20044|",
+    "circuits": [
+      {
+        "id": 719818,
+        "name": "AARNET-GEO-UK-1",
+        "type": "GEANT OPEN PORT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1169,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "AARNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AARNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY Surfnet Secondary - Service ID: 3287IR2 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 515,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02196 |SCION server 1 external port",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1282,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/14",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE13    | LON2-PRD-ESX03 NIC1 PORT2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 528,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "irb.518",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #CORIANT-MGMT-LON2-UK-VRF-VLAN518 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1575,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c18/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ARNES P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916994,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1339,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae22.201",
+    "bundle": [],
+    "bundle-parents": [
+      "et-10/0/2",
+      "et-11/0/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER CERN #CERN-AP1-EXT2 $GS-00443 | ASN513 |",
+    "circuits": [
+      {
+        "id": 701593,
+        "name": "CERN-AP1-EXT2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1237,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE ORACLE P_AE19 | Interxion CID: DE129680 | Oracle CID: GEANT-Interxion-1-1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 865,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae1.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/4",
+      "xe-3/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-pra-cz| SW2-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 725173,
+        "name": "EX3400-MANAGEMENT-PRA-CZ",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 948,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/3/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER AZSCIENCENET AZSCIENCENET #fra-fra-EAP-AZSCIENCENET-CL-190961 $GS-00694 | ",
+    "circuits": [
+      {
+        "id": 723801,
+        "name": "FRA-FRA-EAP-AZSCIENCENET-CL-190961",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1035,
+    "dashboards": [
+      "EAP",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "AZSCIENCENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AZSCIENCENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-20.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1"
+    ],
+    "description": "SRV_IAS CUSTOMER BREN #BREN-AP1-IAS IASPS $GS-00557 | ASN6802 | ",
+    "circuits": [
+      {
+        "id": 744956,
+        "name": "BREN-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "9",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "BREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/25",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX02 NIC2 PORT3 - VSAN PORT",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 673,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 571,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae20",
+    "bundle": [
+      "et-9/1/2",
+      "et-11/0/2"
+    ],
+    "bundle-parents": [
+      "et-9/1/2",
+      "et-11/0/2"
+    ],
+    "description": "LAG PUBLIC LINX SRF9929379 $GA-01839 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 716,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Was IUCC:  GNT-E10-006",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 852,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-101.103",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-TAR-EE-VRF-VLAN103 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "8",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 806,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.33",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS Customer BELNET MICROSOFT #BELNET-KULEUVEN-EXPRESSROUTE-4084 $GS-01135  | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739669,
+        "name": "BELNET-KULEUVEN-EXPRESSROUTE-4084",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 671,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "1/1/c2/1",
+      "1/1/c2/2"
+    ],
+    "bundle-parents": [
+      "1/1/c2/1",
+      "1/1/c2/2"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.701",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NETHERLIGHT RARE #AMS-AMS-NETHERLIGHT-RARE-9952733 $GS-00626 | ",
+    "circuits": [
+      {
+        "id": 736101,
+        "name": "AMS-AMS-NETHERLIGHT-RARE-9952733",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1532,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/1/4.2031",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET ESNET #lon-lon-GEANTOpen-Esnet-NORDUNET-15039-3 $GS-00965 |",
+    "circuits": [
+      {
+        "id": 738641,
+        "name": "LON-LON-GEANTOPEN-ESNET-NORDUNET-15039-3",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1519,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "xe-0/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE3 | rt1-sw2(ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 562,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae1.403",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/0",
+      "xe-1/2/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS WP6 Netronome server # Netronome-MANAGEMENT-LON2-UK |SRV MGMT CONTACT: pavle.vuletic@amres.ac.rs IMPLEMENTED: 20180502",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 903,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "1/1/c13/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | LON2-PAR | connected to PAR.GRV6 port 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900289,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.953",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KIFU REDIRIS #UPV/EHU-REDIRIS-KIFU-SLICES-SZTAKI $GS-02518 |",
+    "circuits": [
+      {
+        "id": 739311,
+        "name": "UPV/EHU-REDIRIS-KIFU-SLICES-SZTAKI",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 902,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 649,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae11.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/0/2",
+      "et-10/3/0"
+    ],
+    "description": "SRV_IAS CUSTOMER SURF #SURF-AP2-IAS IASPS $GS-00588 | ASN1103 |",
+    "circuits": [
+      {
+        "id": 660399,
+        "name": "SURF-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 860,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 515,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae14.1290",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5",
+      "et-8/0/2",
+      "et-8/1/2",
+      "et-8/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET RENATER #IMINDS-00670 $GS-00670",
+    "circuits": [
+      {
+        "id": 744061,
+        "name": "IMINDS-00670",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 774,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-4/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC DE-CIX P_AE14 | DXDB:PNI:11663 Equinix CID: 23175631",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 977,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/0/1:0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 528,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "irb.999",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS INFINERA #infinera-vie-at-mgmt-vrf-vlan999|",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 683,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c11/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900161,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae45",
+    "bundle": [
+      "et-2/0/5"
+    ],
+    "bundle-parents": [
+      "et-2/0/5"
+    ],
+    "description": "LAG PRIVATE APPLE SRF9934309 $GA-02396 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 704,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #COR-PAR-IPTRUNK $GS-02477 | COR-PAR | ",
+    "circuits": [
+      {
+        "id": 747412,
+        "name": "COR-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 7,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:2103",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET PIONIER #HAM-POZ-02494 $GS-02494",
+    "circuits": [
+      {
+        "id": 747540,
+        "name": "HAM-POZ-02494",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #KAU-POZ-IPTRUNK $GS-00043 | KAU-POZ | ",
+    "circuits": [
+      {
+        "id": 746527,
+        "name": "KAU-POZ-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-POZ",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-POZ",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/13",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 529,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 928,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae17.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-1/1/2"
+    ],
+    "description": "SRV_IAS CUSTOMER CERN #CERN-AP1-IAS IASPS $GS-00562 | ASN513",
+    "circuits": [
+      {
+        "id": 663049,
+        "name": "CERN-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 748,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COGENT P_AE32  | Interxion ID: IXDE-17030 | Cogent ID: 3-001176128",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 858,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COGENT - FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT - FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12",
+    "bundle": [
+      "et-2/1/2"
+    ],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "LAG RE_INTERCONNECT CAE1 SRF19005 $GA-01843 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1705,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CAE1",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CAE1",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "ae14",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN            | QFX.LON2.UK AE29",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 593,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-9/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae7 | BUC-BUD",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1128,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.3018",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #AMS-PAR-SINET-SD-WAN-SINET-SINET-17091 $GS-00660 |",
+    "circuits": [
+      {
+        "id": 736074,
+        "name": "AMS-PAR-SINET-SD-WAN-SINET-SINET-17091",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1081,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae28.420",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER TENET NEA3R #lon-lon-GEANTOPEN-NEA3R-TENET-18097 $GS-00971 |",
+    "circuits": [
+      {
+        "id": 718087,
+        "name": "LON-LON-GEANTOPEN-NEA3R-TENET-18097",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 694,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "TENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/5.1500",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT RE_INTERCONNECT UBUNTUNET NETHERLIGHT #AMS-LON-JIVE-NETHERLIGHT-UBUNTUNET-12008 $GS-00645 |",
+    "circuits": [
+      {
+        "id": 734613,
+        "name": "AMS-LON-JIVE-NETHERLIGHT-UBUNTUNET-12008",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1494,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "1/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC INEX P_lag-21",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915971,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.10",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #GEANT-CORPORATE-ViaVodafone | GEANT Corporate to SRX2.CH - Via Vodafone",
+    "circuits": [
+      {
+        "id": 740704,
+        "name": "GEANT-CORPORATE-VIAVODAFONE",
+        "type": "CORPORATE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 831,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1264,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-10/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | WAS BIL-MAD",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1046,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-24.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER RASH #RASH-AP2 $GS-00497 | ASN57961 | ",
+    "circuits": [
+      {
+        "id": 745010,
+        "name": "RASH-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "15",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RASH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RASH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae12.1005",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT CSTNET #FR-IC1-CSTNET-PRIMARY $GS-02358 | ASN7497 | ",
+    "circuits": [
+      {
+        "id": 729009,
+        "name": "FR-IC1-CSTNET-PRIMARY",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 621,
+    "dashboards": [
+      "IC1",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CSTNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CSTNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.mad.es.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02592 | MAD-MAD",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | GEN-MIL2 | to RT1.MIL2 et-9/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/3/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | RESERVED FOR LAN SW - AK",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 611,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS DTN SRF0000001 $GA-01478 | DATA 10G",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 849,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "ae2.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-KIE1-UA $GS-00131 | DCN MANAGEMENT ",
+    "circuits": [
+      {
+        "id": 713312,
+        "name": "DCN-MANAGEMENT-KIE1-UA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 584,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "1/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | FRA-GEN | to GEN01-GRV2 port 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899905,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae34",
+    "bundle": [
+      "xe-11/3/3"
+    ],
+    "bundle-parents": [
+      "xe-11/3/3"
+    ],
+    "description": "LAG CUSTOMER MICROSOFT EXPRESSROUTE #2 FOR NORDUNET SRF19135 $GA-01965 | GEANT-FRA32-09XGMR-CIS-2-SEC-12062019",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1204,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-11/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC P_AE10 SRF18084 | JISC-AP1-LL2 | JISC ID: TCF:21304-23275",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1655,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "irb.3006",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-CONTROL-IMS-MEDIATION-LOGICAL-INTERFACE-PAR-FR $GS-00863 | IMS Mediation Gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 712153,
+        "name": "TAAS-CONTROL-IMS-MEDIATION-LOGICAL-INTERFACE-PAR-FR",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 782,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "irb.370",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN CUSTOMER SCION SRF22092 #SCION-SCION-PAR-INTERNAL-VPN-VL370 $GS-02215 |",
+    "circuits": [
+      {
+        "id": 723805,
+        "name": "SCION-SCION-PAR-INTERNAL-VPN-VL370",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1098,
+    "dashboards": [
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1336,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.1214",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER HEANET RARE #ams-cor-00633 $GS-00633",
+    "circuits": [
+      {
+        "id": 747413,
+        "name": "AMS-COR-00633",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1535,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "HEANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-7/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | BUD-ZAG",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1133,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:3505",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER BELNET #SLCIMEC-02488 $GS-02488",
+    "circuits": [
+      {
+        "id": 745341,
+        "name": "SLCIMEC-02488",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "1/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | COR-COR | TO RT1.COR.IE-XE-0/1/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-COR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-COR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.39",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSERVAONEM-02431 $GS-02431",
+    "circuits": [
+      {
+        "id": 744145,
+        "name": "MSERVAONEM-02431",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1420,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-20:cp-2009",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER LAT SURF #LOFAR-00663 $GS-00663",
+    "circuits": [
+      {
+        "id": 745942,
+        "name": "LOFAR-00663",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3160",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT SINGAREN #UK-CAE1-SINGAREN $GS-00912 | ASN23855 | CAE1-WL065785-VL3160",
+    "circuits": [
+      {
+        "id": 661924,
+        "name": "UK-CAE1-SINGAREN",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1709,
+    "dashboards": [
+      "CAE1",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1263,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-7/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | 1X100GE CFP installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 584,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-CBG-Lab $GS-00791",
+    "circuits": [
+      {
+        "id": 732673,
+        "name": "GRE-MULTICAST-TUNNEL-CBG-LAB",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1210,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-8/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | no optic installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1149,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-NCI-CSIRO $GS-01084",
+    "circuits": [
+      {
+        "id": 732658,
+        "name": "GRE-MULTICAST-TUNNEL-NCI-CSIRO",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1211,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02189 |SCION server 2 internal port",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1307,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "1/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC INEX P_lag-21",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915972,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae17.1",
+    "bundle": [],
+    "bundle-parents": [
+      "et-10/0/5"
+    ],
+    "description": "PHY CUSTOMER_GEO SURF #SURF-GEO-FR-1 |  P_AE17 SRF18071|Circuit ID: FR108917 | Netherlight Port:Pr003a-jnx-01: et-0/0/1",
+    "circuits": [
+      {
+        "id": 719822,
+        "name": "SURF-GEO-FR-1",
+        "type": "GEANT OPEN PORT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 639,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-20.200",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_IAS CUSTOMER EENET #EENET-AP1-IAS IASPS $GS-00568 | ASN3221 | ",
+    "circuits": [
+      {
+        "id": 746448,
+        "name": "EENET-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "EENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae28.2062",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/0/5"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT REDCLARA #REDCLARA-TENET-LON-LHCONE $GS-02167 | ASN27750",
+    "circuits": [
+      {
+        "id": 720027,
+        "name": "REDCLARA-TENET-LON-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1230,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.18",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-IMPA $GS-01079",
+    "circuits": [
+      {
+        "id": 732669,
+        "name": "GRE-MULTICAST-TUNNEL-IMPA",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1221,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | VIE EX3400 XE-0/2/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1052,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE4     | LON2-PRD-ESX20 NIC2 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 524,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "1/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | PRA-PRA | to RT1.PRA et-0/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900034,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-8/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 990,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "1/x1/1/c4/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC P_lag-22",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916097,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 565,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15",
+    "bundle": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "LAG CUSTOMER REDIRIS | $GA-01780 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 688,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-SOF-BG-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "4",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae23.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_IAS CUSTOMER SWITCH #SWITCH-AP1-IAS IASPS $GS-00589 | ASN559",
+    "circuits": [
+      {
+        "id": 663229,
+        "name": "SWITCH-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1273,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-23.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c27/1",
+      "2/x1/1/c26/1"
+    ],
+    "description": "SRV_IAS CUSTOMER ULAKBIM #ULAKBIM-AP2-IAS IASPS $GS-00592 | ASN8517 | ",
+    "circuits": [
+      {
+        "id": 745011,
+        "name": "ULAKBIM-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "19",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 | mx1-sw1  (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 922,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-2/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 728,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-20:710",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET BELNET #SLCIMEC-02518 $GS-02518|",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.500",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER INTERNET2 #INTERNET2-TESTVLAN-RTT $GS-00475 | TEST VLAN FOR NYC-PAR RTT",
+    "circuits": [
+      {
+        "id": 677814,
+        "name": "INTERNET2-TESTVLAN-RTT",
+        "type": "GEANT IP",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 858,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae45.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-10/1/5"
+    ],
+    "description": "SRV_IAS PRIVATE APPLE #DE-APPLE-IAS $GS-02395 | ASN714 |",
+    "circuits": [
+      {
+        "id": 730364,
+        "name": "DE-APPLE-IAS",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 991,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "APPLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "APPLE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER BELNET #BELNET-AP2 $GS-00436 | ASN2611 |",
+    "circuits": [
+      {
+        "id": 739643,
+        "name": "BELNET-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1654,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.46",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ASREN ASREN #lon-lon2-GEANTOpen-ASREN-ASREN-190491 $GS-00984 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 642,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae30.3008",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE Access link #INFOBLOX-DNS-FRA-DE $GS-00200| TEST - Infoblox GRID /// NMAAS IS-IS Listener",
+    "circuits": [
+      {
+        "id": 733008,
+        "name": "INFOBLOX-DNS-FRA-DE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1136,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 526,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-101.103",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-LJU-SI-VRF-VLAN103 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "3",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 568,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 590,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-2/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER IUCC P_AE21 | IUCC-AP1-LL1 - Tamares Telecom ID:  GNT-E100-010",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 694,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "IUCC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "IUCC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "et-0/0/2"
+    ],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02033 | AMS-AMS |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 579,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.14",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #DRACS-LON2-UK | LON2 DRACS",
+    "circuits": [
+      {
+        "id": 661540,
+        "name": "DRACS-LON2-UK",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1183,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae42.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/2/3",
+      "xe-0/2/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 2 MGMT | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1358,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-1/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 680,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/3/5.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-bud-hu-management |perfSONAR MGMT",
+    "circuits": [
+      {
+        "id": 724898,
+        "name": "PS-BUD-HU-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1176,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "xe-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 560,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "2/x1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02350 | HAM-TAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-TAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-TAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "2/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | BIL-PAR | to RT1.BIL.ES - et-1/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162114,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae30.104",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ESNET #NL-ESNET-IPV4 $GS-00889 | ASN293 | AMS-ESNET-400G",
+    "circuits": [
+      {
+        "id": 734112,
+        "name": "NL-ESNET-IPV4",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1030,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae23.200",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION SWITCH #gen-gen-SCION-SWITCH $GS-02199 |",
+    "circuits": [
+      {
+        "id": 720418,
+        "name": "GEN-GEN-SCION-SWITCH",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 725,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "lag-9.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c11/1",
+      "1/1/c11/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUD-VIE-IPTRUNK $GS-00026 | BUD-VIE | ",
+    "circuits": [
+      {
+        "id": 740790,
+        "name": "BUD-VIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-VIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-VIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "1/1/c9/2",
+      "1/1/c12/1",
+      "1/1/c12/2"
+    ],
+    "bundle-parents": [
+      "1/1/c9/2",
+      "1/1/c12/1",
+      "1/1/c12/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02562 | VIE-VIE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "VIE-VIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "VIE-VIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER KIAE P_AE16 | Digital Realty CID: NL134571 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 650,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KIAE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIAE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae12",
+    "bundle": [
+      "et-4/0/5",
+      "et-8/0/5",
+      "et-11/0/2"
+    ],
+    "bundle-parents": [
+      "et-4/0/5",
+      "et-8/0/5",
+      "et-11/0/2"
+    ],
+    "description": "LAG CUSTOMER GARR SRF9916009 $GA-01883 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 699,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 513,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "1/x1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | LJU-MIL2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916354,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-101.103",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-SOF-BG-VRF-VLAN103 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "10",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 609,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/28",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX11 NIC2 PORT3 - VSAN PORT",
+    "circuits": [
+      {
+        "id": 658619,
+        "name": "LON2-PRD-ESX11-NIC2-PORT3",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 676,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 668,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.956",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET REDIRIS #BIL-HAM-02517 $GS-02517",
+    "circuits": [
+      {
+        "id": 747545,
+        "name": "BIL-HAM-02517",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 903,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/0/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS  #DTN-LON2-10G-DATA $GS-02355",
+    "circuits": [
+      {
+        "id": 727045,
+        "name": "DTN-LON2-10G-DATA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1015,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:2101",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET NORDUNET #ATH2-HAM-02500 $GS-02500",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.2300",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CSTNET CERN #ams-gen-IHEP-CERN-CSTNET $GS-02415 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1749,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-21.100",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER EENET #EENET-AP2 $GS-00455 | ASN3221 | ",
+    "circuits": [
+      {
+        "id": 745984,
+        "name": "EENET-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "8",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "EENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_IAS CUSTOMER BELNET #BELNET-AP2-IAS IASPS $GS-00523 | ASN2611",
+    "circuits": [
+      {
+        "id": 739626,
+        "name": "BELNET-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1655,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae1.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/1/1",
+      "xe-5/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-bud-hu | SW1-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 739254,
+        "name": "EX3400-MANAGEMENT-BUD-HU",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 887,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 563,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 931,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.1",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "PHY CUSTOMER_GEO NEA3R #IndianaUni-GEO-UK-1 |  P_AE26 SRF20098|NEA3R",
+    "circuits": [
+      {
+        "id": 719685,
+        "name": "INDIANAUNI-GEO-UK-1",
+        "type": "GEANT OPEN PORT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1158,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "NEA3R",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NEA3R",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae1.28",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/1/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ddos-mit2-vie-at-idrac | NEMO DDOS Mitigation 2 iDRAC | Stage.Nemo",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 665,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.28",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #AMS-SPLUNK-SERVER1-iDRAC",
+    "circuits": [
+      {
+        "id": 736084,
+        "name": "AMS-SPLUNK-SERVER1-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1018,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae37.300",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/2/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER AZSCIENCENET #AZSCIENCENET-AP1 $GS-00433 | ASN202993 |",
+    "circuits": [
+      {
+        "id": 743174,
+        "name": "AZSCIENCENET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1692,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "AZSCIENCENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AZSCIENCENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SRX-1 To Switch Cluster ge-0/0/4",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 516,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.38",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-02412 $GS-02412",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 680,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae7 | MIL2-MIL2 | RT0.MIL2.IT 1/1/c12/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 658,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-9/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE FACEBOOK SRF9934785 P_AE17 | FB ID: FA-1026202",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1406,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.20",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #psmp-par-fr-drac | psmp drac",
+    "circuits": [
+      {
+        "id": 739104,
+        "name": "PSMP-PAR-FR-DRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1218,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.buc.ro.geant.net",
+    "name": "2/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | BUC-BUC | Connected to RT1.BUC - et-4/0/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611179649,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "1/x1/1/c4/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC INEX P_lag-21",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916098,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "2/1/c11/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | LJU-MIL2 | to RT1.LJU.SI et-1/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162306,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.por.pt.geant.net",
+    "name": "1/x1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | POR-POR | to RT1.POR.PT et-1/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916417,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POR-POR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POR-POR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT ARN SRF22085 |Equinix CID: M21-43I-10-5/6  | ES-ARN-AP1-LL1 --P17/P18 in odf-mmr PP:0101:14103252 (direct)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 794,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ARN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:3501",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET BELNET #SLCIMEC-02518 $GS-02518",
+    "circuits": [
+      {
+        "id": 745336,
+        "name": "MSEJUST-02318",
+        "type": "EXPRESS ROUTE",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c11/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900162,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-7.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c9/2",
+      "1/1/c12/2",
+      "2/1/c9/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MIL2-MIL2-IPTRUNK $GS-02548 | MIL2-MIL2 | MIL2-MIL2-MGMT",
+    "circuits": [
+      {
+        "id": 740951,
+        "name": "MIL2-MIL2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-MIL2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-MIL2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 593,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae19.112",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/1/3",
+      "xe-11/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ORACLE CERN #fra-gen-ORACLE-CERN-20150 $GS-00699 |",
+    "circuits": [
+      {
+        "id": 705439,
+        "name": "FRA-GEN-ORACLE-CERN-20150",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1053,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ORACLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-4/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae4 | GEN-MAR | to rt0.gen  2/1/c8/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 579,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-9/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER UOM P_AE11 SRF22076 | #UOM-AP1-LL1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 835,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "UOM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UOM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.375",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINGAREN RARE #AMS-LON-SINGAREN-RARE-123034 $GS-02315 | ",
+    "circuits": [
+      {
+        "id": 736108,
+        "name": "AMS-LON-SINGAREN-RARE-123034",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1250,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae33.4005",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER NORDUNET #NL-NORDUNET-LHCONE-IPV6 $GS-00839 | ASN2603 |",
+    "circuits": [
+      {
+        "id": 740765,
+        "name": "NL-NORDUNET-LHCONE-IPV6",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1695,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1474,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "et-0/0/3"
+    ],
+    "bundle-parents": [
+      "et-0/0/3"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02037 | CHI-CHI |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 585,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-CHI",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-CHI",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "2/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | LON2-PAR | TO PAR.GRV3 - 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161921,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.29",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #LON2-SPLUNK-SERVER2-iDRAC",
+    "circuits": [
+      {
+        "id": 732529,
+        "name": "LON2-SPLUNK-SERVER2-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 598,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.105",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #SPLUNK-PAR-FR | Splunk1 CONTACT: evangelos.spatharas@geant.org IMPLEMENTED 20160825",
+    "circuits": [
+      {
+        "id": 733979,
+        "name": "SPLUNK-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 717,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "et-7/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | POZ-POZ | to RT0.POZ.PL 2/1/c11/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1061,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "xe-3/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 658,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae18.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-10/1/0"
+    ],
+    "description": "SRV_IAS PRIVATE FACEBOOK #FACEBOOK-32934-LON-FC-26603 $GS-00931 | ASN32934",
+    "circuits": [
+      {
+        "id": 708242,
+        "name": "FACEBOOK-32934-LON-FC-26603",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1042,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "FACEBOOK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FACEBOOK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae12",
+    "bundle": [
+      "et-4/1/5"
+    ],
+    "bundle-parents": [
+      "et-4/1/5"
+    ],
+    "description": "LAG RE_INTERCONNECT IC-1 SRF22102 $GA-02233 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 585,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "IC-1",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "IC-1",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/15",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 531,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.2503",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA | deltaId+9d8cec2f-9947-4af2-b473-05ea523a7d0f:uuid+c58223b9-fa23-44df-a947-b0759ced1994 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1539,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "et-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | BUC-SOF | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 662,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-SOF",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-SOF",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02466 | LON-LON",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae21",
+    "bundle": [
+      "et-11/1/0"
+    ],
+    "bundle-parents": [
+      "et-11/1/0"
+    ],
+    "description": "LAG CUSTOMER ROEDUNET AP2 SRF20069 $GA-01850 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 701,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ROEDUNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ROEDUNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-2/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER IUCC P_AE22 | IUCC-AP2-LL1 -Tamares Telecom ID: GNT-E100-011",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 671,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "IUCC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "IUCC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | MAD-MAR | connected to MAR01-GRV1 1/1/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 680,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-4/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1000,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "1/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915971,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "2/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-9 | AMS-HAM | to AMS01-GRV5 1/1/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162114,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-HAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-HAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae17",
+    "bundle": [
+      "xe-11/3/4"
+    ],
+    "bundle-parents": [
+      "xe-11/3/4"
+    ],
+    "description": "LAG CUSTOMER ASNET-AM SRF9931823 $GA-01953 | ASNET-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1164,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ASNET-AM",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASNET-AM",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 612,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "irb.50",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS SRF22066 #SCION-SCION-PAR-INTERNAL-BRIDGE",
+    "circuits": [
+      {
+        "id": 723800,
+        "name": "SCION-SCION-PAR-INTERNAL-BRIDGE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 615,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "2/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | BRU-PAR | to RT0.PAR 1/1/c8/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178497,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRU-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRU-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.611",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT REDCLARA #UK-CLARA-NEA3R $GS-00914 | ASN27750",
+    "circuits": [
+      {
+        "id": 709307,
+        "name": "UK-CLARA-NEA3R",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 866,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/2/5.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-fra-de-bwctl UAT | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 733939,
+        "name": "PS-FRA-DE-BWCTL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1352,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/1/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-vie-at-bwctl new | BWCTL CONTACT: ivan.garnizov@fau.de IMPLEMENTED: 20160524",
+    "circuits": [
+      {
+        "id": 736085,
+        "name": "PS-VIE-AT-BWCTL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1524,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "2/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | FRA-GEN | TO FRA01-GRV1  port 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161665,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-1/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO NEA3R #IndianaUni-GEO-UK-1 |  P_AE26 SRF20098|NEA3R",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 851,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "NEA3R",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NEA3R",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.42",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER REDIRIS MICROSOFT #REDIRIS-ICN2-ExpressRoute-VLAN692 $GS-02560 | ",
+    "circuits": [
+      {
+        "id": 740768,
+        "name": "REDIRIS-ICN2-EXPRESSROUTE-VLAN692",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 686,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 608,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/0/4",
+      "et-9/1/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #PAR-PAR-IPTRUNK $GS-02473| PAR-PAR | RT0.PAR-MX1.PAR IPTRUNK",
+    "circuits": [
+      {
+        "id": 739437,
+        "name": "PAR-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1180,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PAR-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PAR-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.200",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #NE-ESXI-FRA-DE-IDRAC | ne-esxi-prod-fra-1-idrac",
+    "circuits": [
+      {
+        "id": 732681,
+        "name": "NE-ESXI-FRA-DE-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1405,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.40",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NETHERLIGHT SWITCH #AMS-PAR-SCION-SWITCH-NETHERLIGHT-20019 $GS-00658 |",
+    "circuits": [
+      {
+        "id": 714175,
+        "name": "AMS-PAR-SCION-SWITCH-NETHERLIGHT-20019",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1112,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "ae13",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01727  | QFX.FRA.DE AE13",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 592,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02198 |SCION server 2 external port",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1266,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae19.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/1/6",
+      "xe-5/3/4"
+    ],
+    "description": "SRV_IAS UPSTREAM COGENT #COGENT-GWS-BUD $GS-00065 | ASN174",
+    "circuits": [
+      {
+        "id": 708282,
+        "name": "COGENT-GWS-BUD",
+        "type": "GWS - UPSTREAM",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 554,
+    "dashboards": [
+      "IAS_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COGENT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-3/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": " PHY RE_INTERCONNECT ESNET P_AE30 400G | Digital Realty CID: NL205425",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 718,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 674,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 830,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | OLD PSMP BWCTL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 930,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC P_AE10 SRF9925125 | JISC-AP1-LL1 | JISC ID: TCF:25315-27877",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1203,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.951",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDIRIS BELNET #SLCIMEC-02515 $GS-02515",
+    "circuits": [
+      {
+        "id": 745337,
+        "name": "SLCIMEC-02515",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 910,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-5/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER BENOCS | Interxion CID DE236793",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 831,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BENOCS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BENOCS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #COR-PAR-IPTRUNK $GS-02477 | COR-PAR | ",
+    "circuits": [
+      {
+        "id": 747412,
+        "name": "COR-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-2/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 680,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1276,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "1/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | AMS-LON | to LON01.GRV1 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899521,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.17",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet_ARPGAN_ExpressRoute_VLAN4080 $GS-01122 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739674,
+        "name": "BELNET-ARPGAN-EXPRESSROUTE-VLAN4080",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 599,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "lag-8",
+    "bundle": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01945 | AMS-FRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177288,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:3919",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-02412 $GS-02412",
+    "circuits": [
+      {
+        "id": 747634,
+        "name": "AMS-HAM-MSE-02412",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MICROSOFT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae18.52",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2"
+    ],
+    "description": "SRV_IAS CUSTOMER ACONET #ACONET-AP2-IAS IASPS $GS-00551 | ASN1853",
+    "circuits": [
+      {
+        "id": 661759,
+        "name": "ACONET-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 804,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ACONET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ACONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "et-4/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | no optic installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 802,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae33",
+    "bundle": [
+      "et-2/1/2"
+    ],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 742,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.28",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #SCION-par-fr  | SCION SERVERS",
+    "circuits": [
+      {
+        "id": 739096,
+        "name": "SCION-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1223,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-20.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_IAS CUSTOMER HEANET #HEANET-AP1-IAS IASPS $GS-00572 | ASN1213 | ",
+    "circuits": [
+      {
+        "id": 747283,
+        "name": "HEANET-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "5",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 607,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "2/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | LON-LON2 | to LON01.GRV2 - 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161665,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mad.es.geant.net",
+    "name": "1/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | MAD-MAD | to MX1.MAD xe-7/0/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae23.34",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NETHERLIGHT SWITCH #AMS-GEN-SCION-NETHERLIGHT-SWITCH-20018 $GS-00639 |",
+    "circuits": [
+      {
+        "id": 734612,
+        "name": "AMS-GEN-SCION-NETHERLIGHT-SWITCH-20018",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 675,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "et-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae7 | BUC-BUD",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 609,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "ae10.333",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/6",
+      "xe-0/1/7"
+    ],
+    "description": "SRV_IAS CUSTOMER RENAM #RENAM-AP2-IAS IASGWS $GS-00542 | ASN9199",
+    "circuits": [
+      {
+        "id": 714067,
+        "name": "RENAM-AP2-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 610,
+    "dashboards": [
+      "EAP",
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/7.500",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF #PRA-POZ-RARE-BMS8 $GS-02629",
+    "circuits": [
+      {
+        "id": 744388,
+        "name": "BUD-POZ-RARE-BMS8",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1027,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | FRA-PAR-QFX | to QFX xe-1/0/41",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1290,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae12.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/5",
+      "et-8/0/5",
+      "et-11/0/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER GARR #GARR-AP2-LHCONE $GS-00826 | ASN137",
+    "circuits": [
+      {
+        "id": 663175,
+        "name": "GARR-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 700,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "2/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | LON-LON2 | to LON01.GRV2 - 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161921,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-10/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO SURF #SURF-GEO-FR-1 P_AE17 | SRF18071 | Circuit ID: FR108917 | Netherlight Port:Pr003a-jnx-01: et-0/0/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1001,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1578,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #KAU-RIG-IPTRUNK $GS-00044 | KAU-RIG | ",
+    "circuits": [
+      {
+        "id": 746526,
+        "name": "KAU-RIG-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 8,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-RIG",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-RIG",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER NORDUNET P_lag-21 | NORDUNET-AP2-IP1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610901121,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/4.1627",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION INTERNET2 #gen-par-SCION-SCION-INTERNET2-1 $GS-02297 |",
+    "circuits": [
+      {
+        "id": 736637,
+        "name": "GEN-PAR-SCION-SCION-INTERNET2-1",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1261,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-101.520",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c2/1",
+      "1/1/c2/2"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #IDRAC-MGMT-HAM-DE-VRF-VLAN520 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "2",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae1.21",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/1/7",
+      "xe-2/2/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #hades-gen-ch-DRAC | HADES DRAC",
+    "circuits": [
+      {
+        "id": 740084,
+        "name": "HADES-GEN-CH-DRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1471,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | BRU-PAR | to RT2.BRU.BE - et-0/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRU-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRU-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.203",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #A10-DDOS-SCRUBBING-FRA -NEW- | A10 Management- NEW",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1602,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 657,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae24",
+    "bundle": [
+      "xe-3/1/7"
+    ],
+    "bundle-parents": [
+      "xe-3/1/7"
+    ],
+    "description": "LAG PRIVATE ORACLE #UK-ORACLE-IAS-LAG $GA-02082 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 720,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.3021",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #AMS-SINET-INTERNET-ACCESS | SINET INTERNET ACCESS",
+    "circuits": [
+      {
+        "id": 736099,
+        "name": "AMS-SINET-INTERNET-ACCESS",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1521,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mar.fr.geant.net",
+    "name": "1/x1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | MAR-MAR | to RT1.MAR xe-3/2/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915970,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 828,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae14.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER CYNET #CYNET-AP1 $GS-02441 | ASN3268 |",
+    "circuits": [
+      {
+        "id": 733814,
+        "name": "CYNET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 720,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CYNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CYNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "xe-0/1/0"
+    ],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 $GA-02017 | rt1-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 586,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 599,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 670,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | PAR-FRA-QFX | to QFX xe-0/0/41",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1271,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.51",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "PHY INFRASTRUCTURE ACCESS FLOWMON SRF0000001 | FlowMon2 Management + FanOut CONTACT: evangelos.spatharas@geant.org IMPLEMENTED 20170708",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 643,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.3009",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #INFOBLOX-GRID-FRA-DE $GS-00201 | Infoblox Grid-FRA",
+    "circuits": [
+      {
+        "id": 729102,
+        "name": "INFOBLOX-GRID-FRA-DE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 974,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 519,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-20:2112",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER LAT EENET #GENOMICS-00752 $GS-00752",
+    "circuits": [
+      {
+        "id": 745982,
+        "name": "GENOMICS-00752",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "EENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/0/0.102",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE RARE #AMS-PAR-RARE-RARE-21101 $GS-00656 |",
+    "circuits": [
+      {
+        "id": 736095,
+        "name": "AMS-PAR-RARE-RARE-21101",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 950,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-23.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c27/1",
+      "2/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER ULAKBIM #ULAKBIM-AP2 $GS-00518 | ASN8517 | ",
+    "circuits": [
+      {
+        "id": 745009,
+        "name": "ULAKBIM-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "18",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP P_AE30 | QFX xe-0/0/18",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1278,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae11",
+    "bundle": [
+      "et-9/1/5"
+    ],
+    "bundle-parents": [
+      "et-9/1/5"
+    ],
+    "description": "LAG CUSTOMER UOM SRF22076 #UOM-AP1-LAG $GA-01344 | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 649,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "UOM",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "UOM",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 565,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 924,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae19",
+    "bundle": [
+      "xe-0/0/2",
+      "xe-0/0/3"
+    ],
+    "bundle-parents": [
+      "xe-0/0/2",
+      "xe-0/0/3"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | splunk-ams-peer02.geant.org | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 963,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.2708",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET PIONIER #HAM-POZ-02494 $GS-02494",
+    "circuits": [
+      {
+        "id": 747540,
+        "name": "HAM-POZ-02494",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 675,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.34",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-RIZIV-INAMI-ExpressRoute-VLAN4069 $GS-02521 | ",
+    "circuits": [
+      {
+        "id": 739661,
+        "name": "BELNET-RIZIV-INAMI-EXPRESSROUTE-VLAN4069",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 669,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae12.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/5",
+      "et-8/0/5",
+      "et-11/0/2"
+    ],
+    "description": "SRV_IAS CUSTOMER GARR #GARR-AP2-IAS IASPS $GS-00571 | ASN137",
+    "circuits": [
+      {
+        "id": 663118,
+        "name": "GARR-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 745,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.3400",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT RE_INTERCONNECT ESNET UBUNTUNET #lon-par-ESnet-UbuntuNet-14020 $GS-00737 |",
+    "circuits": [
+      {
+        "id": 706028,
+        "name": "LON-PAR-ESNET-UBUNTUNET-14020",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 897,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "irb.998",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #qfx-management-dub-ie| EXFO management",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 960,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_AE2 | rt1-sw3 xe-0/2/0 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1457,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT ORIENTPLUS SRF9917037 $GA-01479|",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 847,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ORIENTPLUS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORIENTPLUS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae11.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/4"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER DFN #DFN-AP1 $GS-00452 | ASN680 | DFN ID: GE100/ANWD-KA2994-FRA-0GEANT DFN AP",
+    "circuits": [
+      {
+        "id": 743295,
+        "name": "DFN-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 781,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae13.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/6",
+      "xe-4/0/7"
+    ],
+    "description": "SRV_INFRASTRUCTURE ACCESS | NEMO DDOS Detection 1",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1004,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-20:711",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET KIFU #SLCUTH-02497 $GS-02497",
+    "circuits": [
+      {
+        "id": 745594,
+        "name": "SLCUTH-02497",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "1/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | SOF-ZAG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916353,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | HAM-POZ | to RT0.HAM.DE 2/1/c8/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae7",
+    "bundle": [
+      "et-8/0/5"
+    ],
+    "bundle-parents": [
+      "et-8/0/5"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS $GA-02303 | FRA-AMT |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 587,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-8.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LON2-PAR-IPTRUNK $GS-00053 | LON2-PAR | ",
+    "circuits": [
+      {
+        "id": 739436,
+        "name": "LON2-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae32.533",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/5",
+      "et-8/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE Access #TOOLS-ACCESS-AMS-NL  | TOOLS ACCESS",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1722,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "2/x1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02278 | BRU-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRU-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRU-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae1.25",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/1/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ddos-det1-vie-at-idrac | NEMO DDOS Detection 1 iDRAC",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 660,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae20",
+    "bundle": [
+      "et-1/0/2",
+      "et-1/0/5"
+    ],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-1/0/5"
+    ],
+    "description": "LAG PUBLIC DE-CIX SRF9924381 $GA-01956 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 604,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | AMS-BRU | to AMS01-GRV6 1/1/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-BRU",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-BRU",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-2/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ACONET P_AE18 AP_B  |MIL02-GRV5 1/1/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 707,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ACONET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ACONET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CESNET",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 653,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.1305",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KREONET SWITCH #lon-par-SCION-KREONET-SWITCH $GS-02293 |",
+    "circuits": [
+      {
+        "id": 727330,
+        "name": "LON-PAR-SCION-KREONET-SWITCH",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1231,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KREONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-5/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENAM | Prime Telecom CID: 1022641",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 680,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-11/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | LIS-PAR TRUNK",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1198,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "1/x1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02031 | KAU-RIG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-RIG",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-RIG",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae18",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01695 | LON2-PRD-ESX12 VM TRAFFIC LAG",
+    "circuits": [
+      {
+        "id": 658657,
+        "name": "LON2-PRD-ESX12-VM-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 606,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae21.3552",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CSTNET CERN #gen-mar-IHEP-CERN-CSTNET $GS-02414 |",
+    "circuits": [
+      {
+        "id": 732309,
+        "name": "GEN-MAR-IHEP-CERN-CSTNET",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1290,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CSTNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CSTNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae48.740",
+    "bundle": [],
+    "bundle-parents": [
+      "et-10/0/5",
+      "et-10/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #A10-DDOS-SCRUBBING-FRA-Clean-traffic $GS-00087 | Clean-Traffic CONTACT: SOC@geant.org IMPLEMENTED: 20240701",
+    "circuits": [
+      {
+        "id": 741337,
+        "name": "A10-DDOS-SCRUBBING-FRA-CLEAN-TRAFFIC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1616,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 556,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "xe-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 565,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.4020",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NETHERLIGHT WIX #lon-par-GEANTOpen-Internet2-Netherlight-15034 $GS-00968 |",
+    "circuits": [
+      {
+        "id": 736741,
+        "name": "LON-PAR-GEANTOPEN-INTERNET2-NETHERLIGHT-15034",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1598,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae5",
+    "bundle": [
+      "et-7/0/4",
+      "et-7/1/4"
+    ],
+    "bundle-parents": [
+      "et-7/0/4",
+      "et-7/1/4"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02456 | AMS-AMS",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1323,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.2706",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV-L2CIRCUIT CUSTOMER PIONIER REDIRIS #PSNC-RedIRIS-SLICES-UC3M $GS-02492|",
+    "circuits": [
+      {
+        "id": 738289,
+        "name": "PSNC-REDIRIS-SLICES-UC3M",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 630,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "1/x1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | SOF-ZAG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916354,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "1/x1/1/c6/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c6/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01795 | ATH2-MIL2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-MIL2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-MIL2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae10.112",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ORACLE CERN #fra-gen-ORACLE-CERN-20150 $GS-00699 |",
+    "circuits": [
+      {
+        "id": 705439,
+        "name": "FRA-GEN-ORACLE-CERN-20150",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 852,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ORACLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "et-1/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae4 | POR-POR | to RT0.POR.PT 1/x1/1/c9/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 558,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POR-POR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POR-POR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4063",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEULB-02363 $GS-02363",
+    "circuits": [
+      {
+        "id": 744144,
+        "name": "MSEULB-02363",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE7     | LON2-PRD-ESX11 NIC2 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 659,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE FW1-SNM",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 662,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.3920",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER AARNET SINGAREN #AMS-LON-AARNET-SINGAREN-23049 $GS-02342 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1757,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/31",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik B Data Port 1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 538,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c5/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MIL2-VIE-IPTRUNK $GS-00057 | MIL2-VIE | ",
+    "circuits": [
+      {
+        "id": 740950,
+        "name": "MIL2-VIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-VIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-VIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-TAR-EE-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "9",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 529,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-4/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae4 | GEN-MAR | to rt0.gen  2/1/c9/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 583,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae18.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-7/0/6"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ARN #ES-ARN-AP1 $GS-00880 | ASN3208 |",
+    "circuits": [
+      {
+        "id": 724758,
+        "name": "ES-ARN-AP1",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1166,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ARN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ge-0/0/34",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik C IPMI",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 552,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae12",
+    "bundle": [
+      "et-2/0/5"
+    ],
+    "bundle-parents": [
+      "et-2/0/5"
+    ],
+    "description": "LAG PRIVATE GOOGLE SRF9931047 $GA-01771 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 762,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-7/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | BUD-ZAG",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1132,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3104",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER AARNET SINGAREN #lon-lon-GEANTOpen-AARNET-SINGAREN-CAE1-20044-VL3104 $GS-00960 |",
+    "circuits": [
+      {
+        "id": 705943,
+        "name": "LON-LON-GEANTOPEN-AARNET-SINGAREN-CAE1-20044-VL3104",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 990,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "AARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/1/4.1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO SINGAREN #SingAREN-GEO-UK-1 | SRF19075 |",
+    "circuits": [
+      {
+        "id": 725081,
+        "name": "SINGAREN-GEO-UK-1",
+        "type": "GEANT OPEN PORT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 773,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae11",
+    "bundle": [
+      "et-0/0/2",
+      "et-2/1/5"
+    ],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-2/1/5"
+    ],
+    "description": "LAG CUSTOMER CESNET SRF9927551 $GA-01829 | CESNET AP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 923,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-COR-IE-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "9",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE GOOGLE P_AE13 | Interxion CID DE236100-3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 851,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/17",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE18    | LON2-PRD-ESX12 NIC2 PORT2",
+    "circuits": [
+      {
+        "id": 658622,
+        "name": "LON2-PRD-ESX12-NIC2-PORT2",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 668,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BRA-BRA-IPTRUNK $GS-01205| BRA-BRA",
+    "circuits": [
+      {
+        "id": 731789,
+        "name": "BRA-BRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 612,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "1/1/c11/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | MAR-MIL2 | to RT1.MAR.FR et-1/0/5 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900161,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae1.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/0",
+      "xe-1/2/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-lon2-uk $GS-00151 | SW3-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 743294,
+        "name": "EX3400-MANAGEMENT-LON2-UK",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 810,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-21",
+    "bundle": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4",
+      "1/x1/1/c4/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4",
+      "1/x1/1/c4/2"
+    ],
+    "description": "LAG PUBLIC INEX | $GA-01924",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177301,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-1/0/43",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae14    | 10_GBS to RT1 xe-7/0/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 694,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1459,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE3 | MX1-SW1 | (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 574,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MX1-SW1",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MX1-SW1",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-1/0/44",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | was | 10_GBS to MX1.FRA.DE xe-9/3/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 645,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "et-5/1/4"
+    ],
+    "bundle-parents": [
+      "et-5/1/4"
+    ],
+    "description": "LAG CUSTOMER CERN #2 SRF9921193 $GA-01885 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 697,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 934,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae10.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L3VPN CUSTOMER KIFU #KIFU-AP1-LHCONE $GS-02282 | ASN1955 |",
+    "circuits": [
+      {
+        "id": 726626,
+        "name": "KIFU-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 823,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae43",
+    "bundle": [
+      "et-1/1/5"
+    ],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1326,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "ae4",
+    "bundle": [
+      "xe-0/1/7"
+    ],
+    "bundle-parents": [
+      "xe-0/1/7"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt2-sw2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 609,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-9 | AMS-HAM | to RT0.AMS 2/1/C8/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-HAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-HAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.12",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01150 $GS-01150",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 595,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-5/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE GOOGLE P_AE44 | Interxion CID DE236900",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 826,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4088",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSENCCN-01136 $GS-01136",
+    "circuits": [
+      {
+        "id": 744268,
+        "name": "MSENCCN-01136",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "xe-3/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | rt1-sw1(ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 655,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/2/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | MAR-MAR | to RT0.MAR 1/x1/1/c2/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 672,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1",
+      "2/1/c9/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #GEN-MAR-IPTRUNK $GS-00038 | GEN-MAR | ",
+    "circuits": [
+      {
+        "id": 739738,
+        "name": "GEN-MAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 6,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae10.2806",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KIFU NORDUNET #BUD-HAM-02513 $GS-02513",
+    "circuits": [
+      {
+        "id": 747547,
+        "name": "BUD-HAM-02513",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 880,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4066",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSERVAONEM-02431 $GS-02431",
+    "circuits": [
+      {
+        "id": 744145,
+        "name": "MSERVAONEM-02431",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/12",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 528,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 561,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-3/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 696,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "1/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | AMS-FRA | To  FRA01-GRV2- 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899905,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.11",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01159 $GS-01159",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1395,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 534,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae28.2061",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/0/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT REDCLARA #UK-REDCLARA $GS-02166| ASN27750 |",
+    "circuits": [
+      {
+        "id": 720021,
+        "name": "UK-REDCLARA",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1216,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "ae5",
+    "bundle": [
+      "et-0/0/2"
+    ],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02003 | BUC-CHI",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 608,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER SWITCH P_AE13 SRF19030 | SWITCH BACKUP",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1149,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CERN SRF9925993 $GA-01541 | LHC-CERN via SWITCH GN+",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 556,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/x1/1/c6/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c6/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02423 | ATH2-THE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-THE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-THE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-5/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER SWITCH P_AE14 | Digital Realty CID: NL132369",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 992,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 593,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.2021",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET WIX #NORDU-TO-WIX-2021 $GS-00743 | NORDU-to-WIX 2021",
+    "circuits": [
+      {
+        "id": 736882,
+        "name": "NORDU-TO-WIX-2021",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1274,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/1/5",
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BIL-MAD-IPTRUNK $GS-02203 | BIL-MAD |",
+    "circuits": [
+      {
+        "id": 719646,
+        "name": "BIL-MAD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 838,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-MAD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-MAD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-TBA | QFX1.LON2.UK AE9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 739,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "lag-6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #FRA-PRA-IPTRUNK $GS-00033 | FRA-PRA | ",
+    "circuits": [
+      {
+        "id": 740465,
+        "name": "FRA-PRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-PRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-PRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01692 | LON2-SEC-ESX20 ESXI Traffic LAG - No LACP",
+    "circuits": [
+      {
+        "id": 658685,
+        "name": "LON2-SEC-ESX20-ESXI-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 594,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae23.1390",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER SWITCH #GEN-PAR-SCION-RENATER-SWITCH-20026 $GS-00717 |",
+    "circuits": [
+      {
+        "id": 714179,
+        "name": "GEN-PAR-SCION-RENATER-SWITCH-20026",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 689,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "2/1/c30/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | KIE-POZ | to RT1.KIE.UA et-0/0/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611163521,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02187 |SCION server 1 internal port",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1299,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "1/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | MIL2-VIE | to RT0.MIL2 2/1/c5/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899777,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "2/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-9 | AMS-HAM | to AMS01-GRV5 1/1/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162177,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-HAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-HAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-24.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_IAS CUSTOMER RASH #RASH-AP2-IAS IASGWS $GS-00540 | ASN57961 | ",
+    "circuits": [
+      {
+        "id": 745019,
+        "name": "RASH-AP2-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "16",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RASH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RASH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.23",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-fra-de-idrac |perfSONAR IDRAC",
+    "circuits": [
+      {
+        "id": 729101,
+        "name": "PS-FRA-DE-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 968,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae16.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/0/4",
+      "xe-0/1/7",
+      "xe-0/3/1"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT KIAE #NL-KIAE $GS-00896 | ASN59624 |",
+    "circuits": [
+      {
+        "id": 734246,
+        "name": "NL-KIAE",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1053,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "KIAE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIAE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS PERFSONAR SRF0000001 | psmp-lhc-mgmt-lon-uk.geant.org pS MGMT (LHCONE)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1449,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.17",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #VIRGIN-MEDIA-EX1-LON2-TO-CAM-SRX-VLAN17 |",
+    "circuits": [
+      {
+        "id": 660718,
+        "name": "VIRGIN-MEDIA-EX1-LON2-TO-CAM-SRX-VLAN17",
+        "type": "CORPORATE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1847,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 523,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "1/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER LITNET P_lag-21",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917505,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LITNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LITNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-4/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | 400GBASE-DR4 optic installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 571,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae18.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/2"
+    ],
+    "description": "SRV_IAS CUSTOMER RESTENA #RESTENA-AP1-IAS IASPS $GS-00585 | ASN2602 |",
+    "circuits": [
+      {
+        "id": 732134,
+        "name": "RESTENA-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1160,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RESTENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "2/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | LON2-PAR | TO PAR.GRV3 - 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161665,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.221",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT TWAREN #FR-TWAREN-221 $GS-00886 | ASN7539 | MANLAN ID: 221",
+    "circuits": [
+      {
+        "id": 661630,
+        "name": "FR-TWAREN-221",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 873,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "TWAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TWAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-8/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENATER P_AE14 | RENATER-100GB-LL2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1531,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae15.51",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER ACONET #ACONET-AP1 $GS-00422 | ASN1853 |",
+    "circuits": [
+      {
+        "id": 660433,
+        "name": "ACONET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 831,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ACONET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ACONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae20.210",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/2/3"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRENA COGENT #vie-vie-EAP-GRENA-COGENT-22035 $GS-00695",
+    "circuits": [
+      {
+        "id": 719668,
+        "name": "VIE-VIE-EAP-GRENA-COGENT-22035",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 997,
+    "dashboards": [
+      "EAP",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "GRENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae27.4003",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER T-SYSTEMS #NL-T-SYSTEMS-COPERNICUS $GS-02331 | ASN6878",
+    "circuits": [
+      {
+        "id": 734864,
+        "name": "NL-T-SYSTEMS-COPERNICUS",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1320,
+    "dashboards": [
+      "COPERNICUS",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "T-SYSTEMS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "T-SYSTEMS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-1/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 616,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae32.991",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/5",
+      "et-8/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE Access #CORIANT-LIBRENMS-ACCESS-AMS-NL | OPTICAL LIBRENMS ACCESS",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1723,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | DDOS Mitigation Server link 1 Node 1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1067,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "xe-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | BUC-CHI | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 567,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.518",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT RE_INTERCONNECT NISN RENATER #LON-GEN-CNES-NISN-RENATER-09201 $GS-00723 |",
+    "circuits": [
+      {
+        "id": 709299,
+        "name": "LON-GEN-CNES-NISN-RENATER-09201",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 811,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NISN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-22.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "SRV_IAS CUSTOMER RESTENA #RESTENA-AP2-IAS $GS-00586 | ASN2602 | ",
+    "circuits": [
+      {
+        "id": 744074,
+        "name": "RESTENA-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "4",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RESTENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-11/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 866,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "1/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER BREN P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915969,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BREN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BREN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae20.3019",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-5/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #AMS-LON-SINET-SD-WAN-SINET-SINET-17088 $GS-00649 |",
+    "circuits": [
+      {
+        "id": 740719,
+        "name": "AMS-LON-SINET-SD-WAN-SINET-SINET-17088",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1289,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae15",
+    "bundle": [
+      "et-3/0/0"
+    ],
+    "bundle-parents": [
+      "et-3/0/0"
+    ],
+    "description": "LAG CUSTOMER ACONET SRF996718 $GA-01864 | ACONET AP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 695,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ACONET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ACONET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | RARE EDGECORE WEDGE100BF-32X xe-0",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 682,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.977",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KIFU REDIRIS #SZTAKI-KIFU-RedIRIS-SLICES-UC3M $GS-02512|",
+    "circuits": [
+      {
+        "id": 738341,
+        "name": "SZTAKI-KIFU-REDIRIS-SLICES-UC3M",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 803,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:3908",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01159 $GS-01159",
+    "circuits": [
+      {
+        "id": 747631,
+        "name": "AMS-HAM-MSE-01159",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MICROSOFT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/30",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik A Data Port 1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 536,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.1200",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NEA3R WACREN #lon-lon-GEANTOPEN-NEA3R-WACREN-190131 $GS-00982 |",
+    "circuits": [
+      {
+        "id": 709339,
+        "name": "LON-LON-GEANTOPEN-NEA3R-WACREN-190131",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 805,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NEA3R",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NEA3R",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:2100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET NORDUNET #BRU-HAM-02519 $GS-02519",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/0/3.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER NetherLight $GS-00784 #ams-par-LOFAR-RENATER-NetherLight-10001 |",
+    "circuits": [
+      {
+        "id": 734546,
+        "name": "AMS-PAR-LOFAR-RENATER-NETHERLIGHT-10001",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 724,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | rt1-sw3 (ex3400)|",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 886,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.15",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT EUMETSAT #LON-EUMETSAT-SERVER-DATA-TRAFFIC $GS-02313 | LON-EUMETSAT-1G",
+    "circuits": [
+      {
+        "id": 740679,
+        "name": "LON-EUMETSAT-SERVER-DATA-TRAFFIC",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 777,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "EUMETSAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EUMETSAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-3/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | FRA-FRA | TO RT0.FRA.DE- 2/1/c19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 659,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.26",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEJUST-02318 $GS-02318",
+    "circuits": [
+      {
+        "id": 745336,
+        "name": "MSEJUST-02318",
+        "type": "EXPRESS ROUTE",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1409,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 596,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/3/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #fra-ams-IT_INFRA-QFX-GEANT $GS-02556 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1680,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/0/2",
+      "et-7/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUD-ZAG-IPTRUNK $GS-00027 | BUD-ZAG |",
+    "circuits": [
+      {
+        "id": 747898,
+        "name": "BUD-ZAG-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 740,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-ZAG",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-ZAG",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "2/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | SOF-THE | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178497,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-THE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-THE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20.2",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER BELNET #BELNET-AP1 $GS-00437 | ASN2611 | ",
+    "circuits": [
+      {
+        "id": 744240,
+        "name": "BELNET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "9",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae23",
+    "bundle": [
+      "et-9/0/5",
+      "et-10/1/5"
+    ],
+    "bundle-parents": [
+      "et-9/0/5",
+      "et-10/1/5"
+    ],
+    "description": "LAG CUSTOMER CESNET $GA-01899 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1097,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae12.790",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET ITER #MAR-MAR-02645 $GS-02645 |",
+    "circuits": [
+      {
+        "id": 746076,
+        "name": "MAR-MAR-02645",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 864,
+    "dashboards": [
+      "IC1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ITER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/13",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 528,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-10/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS | A10 DDOS 100G #2 connected to X50",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 660,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/2.103",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE RARE #FRA-PAR-RARE-RARE-21101 $GS-00705 |",
+    "circuits": [
+      {
+        "id": 716207,
+        "name": "FRA-PAR-RARE-RARE-21101",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1445,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "1/1/c12/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | MAR-MIL2 | to RT1.MAR.FR et-1/1/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900225,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 532,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-2/0/5.2100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER AARNET NETHERLIGHT #lon-lon-GEANTOpen-AARNET-NETHERLIGHT-21003 $GS-00284 |",
+    "circuits": [
+      {
+        "id": 709856,
+        "name": "LON-LON-GEANTOPEN-AARNET-NETHERLIGHT-21003",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 663,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "AARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.2021",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET WIX #NORDU-TO-WIX-2021 $GS-00743 | NORDU-to-WIX 2021",
+    "circuits": [
+      {
+        "id": 736882,
+        "name": "NORDU-TO-WIX-2021",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1158,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "xe-3/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | rt1-sw1(ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 654,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/2/7.903",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 GEANT #par-par-MISC-GEANT-INTERNET2-9940539 $GS-00747 |",
+    "circuits": [
+      {
+        "id": 705916,
+        "name": "PAR-PAR-MISC-GEANT-INTERNET2-9940539",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 927,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-2/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 644,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-owd- bud.hu.geant.org pS OWAMP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 942,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "2/1/c12/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-6 | ATH2-MIL2 | to RT2.ATH2.GR et-0/0/1 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162369,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-5/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CERN LHCONE P_AE21 SRF22071 | B513-B773 link (LR4)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 862,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.1624",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 SCION #fra-par-SCION-SCION-INTERNET2-1 $GS-02296 |",
+    "circuits": [
+      {
+        "id": 736667,
+        "name": "FRA-PAR-SCION-SCION-INTERNET2-1",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1144,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 743,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.320",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER REDIRIS #REDIRIS-AP2 $GS-00499 | ASN766 |",
+    "circuits": [
+      {
+        "id": 718229,
+        "name": "REDIRIS-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 689,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_AE2 | rt1-sw3 xe-0/2/3 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 675,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #KAU-RIG-IPTRUNK $GS-00044 | KAU-RIG | ",
+    "circuits": [
+      {
+        "id": 746526,
+        "name": "KAU-RIG-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 11,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-RIG",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-RIG",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae23.401",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/0/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_GCS CUSTOMER CESNET MICROSOFT #CESNET-NACIT-ExpressRoute-VLAN401 $GS-02175  | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 724682,
+        "name": "CESNET-NACIT-EXPRESSROUTE-VLAN401",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1099,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-20.111",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c25/1"
+    ],
+    "description": "SRV_L3VPN CUSTOMER DFN #DFN-AP2-LHCONE $GS-00817 | ASN680 | ",
+    "circuits": [
+      {
+        "id": 745581,
+        "name": "DFN-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "8",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/3/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 651,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SRX-1 To TS eth0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 519,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/2",
+      "et-5/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LIS-MAD-IPTRUNK $GS-00048 | LIS-MAD 200G |",
+    "circuits": [
+      {
+        "id": 712769,
+        "name": "LIS-MAD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 761,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-MAD 200G",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-MAD 200G",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #POR-POR-IPTRUNK $GS-02587| POR-POR | POR-POR",
+    "circuits": [
+      {
+        "id": 742668,
+        "name": "POR-POR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 628,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POR-POR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POR-POR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3140",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET SINGAREN #LON-LON-GEANTOPEN-NORDUNET-SINGAREN-CAE1-19074-VL3140 $GS-00975 |",
+    "circuits": [
+      {
+        "id": 705918,
+        "name": "LON-LON-GEANTOPEN-NORDUNET-SINGAREN-CAE1-19074-VL3140",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 760,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.3020",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #AMS-PAR-SINET-SD-WAN-SINET-SINET-17090 $GS-00659 |",
+    "circuits": [
+      {
+        "id": 736070,
+        "name": "AMS-PAR-SINET-SD-WAN-SINET-SINET-17090",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1520,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "irb.3002",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-latency-network-fra-de-IRB $GS-00312 |  Perfsonar test VMs - latency measurement VLAN",
+    "circuits": [
+      {
+        "id": 733022,
+        "name": "PS-LATENCY-NETWORK-FRA-DE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1231,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01682 | FRA-PRD-ESX02 VM Traffic LAG",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 579,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.488",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER ESNET #lon-par-NCSA-LAAS-ESNET-RENATER-15057 $GS-00738 |",
+    "circuits": [
+      {
+        "id": 738739,
+        "name": "LON-PAR-NCSA-LAAS-ESNET-RENATER-15057",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 937,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 SRF0000001 | rt1-sw2 (ex3400) | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 540,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/0.1100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER CERN GARR #gen-gen-GARR-CERNlight-CERN-GARR-16011 $GS-00708 | ",
+    "circuits": [
+      {
+        "id": 707040,
+        "name": "GEN-GEN-GARR-CERNLIGHT-CERN-GARR-16011",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 858,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c26/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ULAKBIM P_lag-21",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917506,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "xe-3/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 534,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE2 | BIL-POR | Infinera BIL-GRV1 Facing POR-GRV2 1/1/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 673,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-POR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-POR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE2 | BIL-POR | Infinera BIL-GRV1 Facing POR-GRV2 1/1/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 671,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-POR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-POR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-8/0/2",
+      "et-8/0/5"
+    ],
+    "bundle-parents": [
+      "et-8/0/2",
+      "et-8/0/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01907 | BUD-VIE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 617,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-VIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-VIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1302,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.4020",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NETHERLIGHT WIX #lon-par-GEANTOpen-Internet2-Netherlight-15034 $GS-00968 |",
+    "circuits": [
+      {
+        "id": 736741,
+        "name": "LON-PAR-GEANTOPEN-INTERNET2-NETHERLIGHT-15034",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1169,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-5/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No Optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 852,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 603,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_AE7 | AMT RELAY LINK #1 | TO AMT1.AMS.NL et-0/0/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 939,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE GOOGLE P_AE13 | Interxion CID DE236100-2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 849,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/12",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 527,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "2/1/c11/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-6 | LIS-PAR | LIS-PAR 100G | Digital Realty CID: FR266695",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162305,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "et-0/1/5",
+      "et-1/0/5"
+    ],
+    "bundle-parents": [
+      "et-0/1/5",
+      "et-1/0/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02028 | BIL-POR |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 577,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-POR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-POR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae19.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/0/2",
+      "xe-0/0/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | SPLUNK AMS PEER02 MGMT | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 968,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.17",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-ARPGAN-01130 $GS-01130",
+    "circuits": [
+      {
+        "id": 744143,
+        "name": "BELNET-ARPGAN-01130",
+        "type": "EXPRESS ROUTE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1400,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.854",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER RESTENA #fra-par-MISC-RESTENA-RENATER-20030 $GS-00704 |",
+    "circuits": [
+      {
+        "id": 733000,
+        "name": "FRA-PAR-MISC-RESTENA-RENATER-20030",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 981,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RESTENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_AE2 SRF0000001 | rt2-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 563,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae30.3006",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-GTS-IMS-MEDIATION-FRANKFURT $GS-00866 | IMS Mediation Gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 733017,
+        "name": "TAAS-GTS-IMS-MEDIATION-FRANKFURT",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1134,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "et-3/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER PIONIER P_AE11 SRF9937611 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 764,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae37.220",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/2/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER AZSCIENCENET AZSCIENCENET #fra-fra-EAP-AZSCIENCENET-CL-190961 $GS-00694 | ",
+    "circuits": [
+      {
+        "id": 723801,
+        "name": "FRA-FRA-EAP-AZSCIENCENET-CL-190961",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1691,
+    "dashboards": [
+      "EAP",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "AZSCIENCENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AZSCIENCENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "ae10.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/6",
+      "xe-0/1/7"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER RENAM #RENAM-AP2 $GS-00501 | ASN9199 |",
+    "circuits": [
+      {
+        "id": 714069,
+        "name": "RENAM-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 608,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-1/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | NEMO DDOS Mitigation Server 1 DATA link | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1569,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-1/2/0",
+      "xe-1/2/4"
+    ],
+    "bundle-parents": [
+      "xe-1/2/0",
+      "xe-1/2/4"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | mx1-sw2(ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 809,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.2704",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER GRNET #SLCUTH-02489 $GS-02489|",
+    "circuits": [
+      {
+        "id": 745413,
+        "name": "SLCUTH-02489",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 603,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae20.990",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-5/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET RENATER #AMS-MAR-ITER-IFERC-SINET-RENATER-24039 $GS-00637 |",
+    "circuits": [
+      {
+        "id": 738726,
+        "name": "AMS-MAR-ITER-IFERC-SINET-RENATER-24039",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1285,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "et-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae1 | BRA-BRA",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 630,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae1.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/3/0",
+      "xe-1/3/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN_MANAGEMENT-POZ-PL | ",
+    "circuits": [
+      {
+        "id": 724826,
+        "name": "DCN_MANAGEMENT-POZ-PL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 821,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-7/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | GEN-GEN | to RT0.GEN.CH 1/1/c19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 812,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 633,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "2/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | POZ-POZ | to MX1.POZ.PL et-7/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162178,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-1/0/16",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 648,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "irb.3002",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-par-fr-latency-testvm $GS-00313 | Perfsonar test VMs - latency measurement VLAN",
+    "circuits": [
+      {
+        "id": 712150,
+        "name": "PS-LATENCY-NETWORK-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1457,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae14.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5",
+      "et-8/0/2",
+      "et-8/1/2",
+      "et-8/1/5"
+    ],
+    "description": "SRV_L3VPN CUSTOMER RENATER #RENATER-AP2-IPv4-LHCONE $GS-00855 | ASN2200",
+    "circuits": [
+      {
+        "id": 733481,
+        "name": "RENATER-AP2-IPV4-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1381,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:cp-1125",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET INTERNET2 #IMINDS-00681 $GS-00681",
+    "circuits": [
+      {
+        "id": 744066,
+        "name": "IMINDS-00681",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-3/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-bw-lis-pt.geant.org pS BWCTL",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 701,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae1.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/0",
+      "xe-3/0/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-por-pt $GS-00158 | SW1-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 712190,
+        "name": "EX3400-MANAGEMENT-POR-PT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 590,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.1337",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SURF SCION #ams-gen-SCION-SURF-SCION-23012 $GS-02263 |",
+    "circuits": [
+      {
+        "id": 726378,
+        "name": "AMS-GEN-SCION-SURF-SCION-23012",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1120,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae14",
+    "bundle": [
+      "et-4/0/0",
+      "et-10/1/2"
+    ],
+    "bundle-parents": [
+      "et-4/0/0",
+      "et-10/1/2"
+    ],
+    "description": "LAG PUBLIC DE-CIX SRF9943055 $GA-01779 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 652,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/4.142",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDCLARA #gen-lis-SCION-REDCLARA $GS-02436 ",
+    "circuits": [
+      {
+        "id": 732905,
+        "name": "GEN-LIS-SCION-REDCLARA",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1328,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-2/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No Optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1033,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 936,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 844,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c2/1",
+      "2/x1/1/c2/3"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-BRU-BE-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 636,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/4.1630",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRnet SCION SCION-02381 $GS-02381|",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 803,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "1/x1/1/c4/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20 | GRNET-AP1-IP4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916099,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae5.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/0",
+      "xe-0/3/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-mil2-it| SW2-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 726155,
+        "name": "EX3400-MANAGEMENT-MIL2-IT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 678,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_IAS CUSTOMER BELNET #BELNET-AP1-IAS $GS-00524 | ASN2611 | ",
+    "circuits": [
+      {
+        "id": 744232,
+        "name": "BELNET-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "10",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-1/0/29",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae0     | RT1 xe-5/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 545,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE FW1-SNM",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 680,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae42.300",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/2/3",
+      "xe-0/2/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 2 - VM BGP | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1359,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 585,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae10.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-2/1/5",
+      "et-11/1/0"
+    ],
+    "description": "SRV_IAS CUSTOMER GARR #GARR-AP1-IAS IASPS $GS-00570 | ASN137",
+    "circuits": [
+      {
+        "id": 660627,
+        "name": "GARR-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 792,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT ASREN P_AE17 SRF9943959|",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1025,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ASREN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASREN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-2/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE GOOGLE P_AE12",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 709,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT ITER P_AE15 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 675,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ITER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ITER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 588,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1334,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/3.22",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | #psmp-gn-owd-lon-uk.geant.org pS OWAMP",
+    "circuits": [
+      {
+        "id": 678566,
+        "name": "PSMP-GN-OWD-LON-UK.GEANT.ORG",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1023,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 578,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.3151",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET SINGAREN #LON-LON-GEANTOPEN-NORDUNET-SINGAREN-CAE1-19074-VL3151 $GS-00976 |",
+    "circuits": [
+      {
+        "id": 705892,
+        "name": "LON-LON-GEANTOPEN-NORDUNET-SINGAREN-CAE1-19074-VL3151",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 769,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.buc.ro.geant.net",
+    "name": "1/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ROEDUNET P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917505,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ROEDUNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ROEDUNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "1/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | GEN-PAR | Connected to PAR01.GRV2 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899777,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.416",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ORACLE PIONIER SRF23002 #fra-poz-ORACLE-PIONIER-23002-VL416 $GS-02243",
+    "circuits": [
+      {
+        "id": 726355,
+        "name": "FRA-POZ-ORACLE-PIONIER-23002-VL416",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 803,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ORACLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "xe-2/0/1",
+      "xe-2/0/2"
+    ],
+    "bundle-parents": [
+      "xe-2/0/1",
+      "xe-2/0/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE | MX1-SW1 (EX3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 617,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MX1-SW1 (EX3400)",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MX1-SW1 (EX3400)",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_AE2 | rt1-sw3 xe-1/2/0  (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 671,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/2/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 601,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | LON-LON2 | TO LON02 GRV1 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899521,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-1/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC BIX P_AE18 | GEANT 100G (capped at 40G by BIX)  - BIX-VI90P383",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 676,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX2-AMS-TO-SURFNET-SECONDARY | Surfnet Secondary - Service ID: 3287IR2",
+    "circuits": [
+      {
+        "id": 708260,
+        "name": "SRX2-AMS-TO-SURFNET-SECONDARY",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 528,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-11/3/0.100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS DTN-PROJECT #DTN-PAR-100G-DATA $GS-00277 | 100G Testing CONTACT: Richard.Hughes-Jones@geant.org",
+    "circuits": [
+      {
+        "id": 708301,
+        "name": "DTN-PAR-100G-DATA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 633,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4093",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet-Premier-ExpressRoute-VLAN4093 $GS-01127 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739681,
+        "name": "BELNET-PREMIER-EXPRESSROUTE-VLAN4093",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1677,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "et-4/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER FCCN P_AE10 SRF21070 | FCCN AP1 100G",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 801,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae30.3002",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/4",
+      "xe-4/0/5",
+      "xe-4/1/2",
+      "xe-4/2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-latency-network-par-fr $GS-00313 | Latency network",
+    "circuits": [
+      {
+        "id": 712150,
+        "name": "PS-LATENCY-NETWORK-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1467,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 565,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | New Leased Span Frankfurt-Poznan",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 566,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.36",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-MSER-ULB-ExpressRoute-VLAN4064 $GS-02364 | ",
+    "circuits": [
+      {
+        "id": 739666,
+        "name": "BELNET-MSER-ULB-EXPRESSROUTE-VLAN4064",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 678,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae13",
+    "bundle": [
+      "xe-5/2/0",
+      "xe-11/0/3",
+      "xe-11/0/5"
+    ],
+    "bundle-parents": [
+      "xe-5/2/0",
+      "xe-11/0/3",
+      "xe-11/0/5"
+    ],
+    "description": "LAG PRIVATE GOOGLE $TE-01943 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 998,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 579,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-BRU-IPTRUNK $GS-00008 | AMS-BRU | ",
+    "circuits": [
+      {
+        "id": 744129,
+        "name": "AMS-BRU-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 11,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-BRU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-BRU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.106",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #QFX-Management-Par| QFX MANAGEMENT ",
+    "circuits": [
+      {
+        "id": 733984,
+        "name": "QFX-MANAGEMENT-PAR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 710,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/5",
+      "et-4/0/2",
+      "et-4/0/5",
+      "et-4/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #GEN-MAR-IPTRUNK $GS-00038| GEN-MAR | ",
+    "circuits": [
+      {
+        "id": 739738,
+        "name": "GEN-MAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 620,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/14",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 530,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "irb.532",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #tools-access-LON2-UK-VRF-VLAN532 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 866,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae48.720",
+    "bundle": [],
+    "bundle-parents": [
+      "et-10/0/5",
+      "et-10/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #A10-DDOS-SCRUBBING-FRA-Dirty-Traffic $GS-00088| Dirty-Traffic CONTACT: SOC@geant.org IMPLEMENTED: 20240701",
+    "circuits": [
+      {
+        "id": 741338,
+        "name": "A10-DDOS-SCRUBBING-FRA-DIRTY-TRAFFIC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1615,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae6 | BIL-MAD |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 674,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.1002",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET TEIN #lon-lon-GEANTOpen-NORDUNET-TEIN-17026 $GS-00977 |",
+    "circuits": [
+      {
+        "id": 705906,
+        "name": "LON-LON-GEANTOPEN-NORDUNET-TEIN-17026",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1272,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TEIN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/4.1726",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION KAUST #gen-ams-KAUST-SCION $GS-02418| ",
+    "circuits": [
+      {
+        "id": 732831,
+        "name": "AMS-GEN-KAUST-SCION",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1316,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAUST",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.1391",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER SWITCH #PAR-PAR-GRID5000-RENATER-SWITCH-20026 $GS-00750 |",
+    "circuits": [
+      {
+        "id": 714182,
+        "name": "PAR-PAR-GRID5000-RENATER-SWITCH-20026",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 874,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae11.353",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER DFN SINET #fra-par-JAXA-DFN-SINET-14005 $GS-00703 |",
+    "circuits": [
+      {
+        "id": 706059,
+        "name": "FRA-PAR-JAXA-DFN-SINET-14005",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 913,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 550,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER KIAE P_AE16 | Digital Realty CID: NL144294 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 667,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KIAE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIAE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER MICROSOFT EXPRESSROUTE #2 FOR NORDUNET P_AE34 | Interxion CID: DE131269-2 | GEANT-FRA32-09XGMR-CIS-2-SEC-12062019",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 885,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae1.23",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/1/7",
+      "xe-2/2/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-gen-ch-idrac |perfSONAR iDRAC LHCONE",
+    "circuits": [
+      {
+        "id": 740083,
+        "name": "PS-GEN-CH-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1472,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-8/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Needs optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1591,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-4/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 994,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.3005",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER RARE #RARE-02643 $GS-02643 |",
+    "circuits": [
+      {
+        "id": 712147,
+        "name": "RARE-PAR-RENATER",
+        "type": "L2SERVICES",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 628,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "xe-0/1/0"
+    ],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "LAG CUSTOMER MICROSOFT EXPRESSROUTE#2 | GEANT-EXR02-AMS21-SEC-06162020 $GA-02034",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 581,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "2/x1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | BUD-ZAG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178498,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/4.1623",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION INTERNET2 #par-par-SCION-INTERNET2-SCION-2 $GS-02309 |",
+    "circuits": [
+      {
+        "id": 736659,
+        "name": "PAR-PAR-SCION-INTERNET2-SCION-2",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1254,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.980",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET REDIRIS #HAM-MAD-02516 $GS-02516",
+    "circuits": [
+      {
+        "id": 747543,
+        "name": "HAM-MAD-02516",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 903,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae22.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-10/0/0"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT WACREN #UK-WACREN $GS-00910 | ASN37288 |",
+    "circuits": [
+      {
+        "id": 661300,
+        "name": "UK-WACREN",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1336,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "WACREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3179",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINGAREN SINGAREN #lon-lon2-GEANT2-SingAREN-SingAREN-17085 $GS-00724 |",
+    "circuits": [
+      {
+        "id": 726769,
+        "name": "LON-LON2-GEANT2-SINGAREN-SINGAREN-17085",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 581,
+    "dashboards": [
+      "CAE1",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.45",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSECREDENDO-02654 $GS-02654",
+    "circuits": [
+      {
+        "id": 747544,
+        "name": "MSECREDENDO-02654",
+        "type": "EXPRESS ROUTE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1769,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 568,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.2010",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET ESNET #lon-lon-GEANTOpen-ESnet-NORDUNET-15039-2 $GS-00964 |",
+    "circuits": [
+      {
+        "id": 738645,
+        "name": "LON-LON-GEANTOPEN-ESNET-NORDUNET-15039-2",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1273,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-1/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 531,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 589,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-11/0/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-vie-at-owamp new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 734087,
+        "name": "PS-VIE-AT-OWAMP",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1000,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.15",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-NOAA2 $GS-01087",
+    "circuits": [
+      {
+        "id": 732675,
+        "name": "GRE-MULTICAST-TUNNEL-NOAA2",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1218,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/0/2.106",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE WP7T2SF SRF21106 $GS-00687 | #BUD-PRA-RARE-BMS9",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1155,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-22.111",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c2/1"
+    ],
+    "description": "SRV_L3VPN CUSTOMER GRNET #GRNET-ATH-LHCONE $GS-00827 | ASN5408 | ",
+    "circuits": [
+      {
+        "id": 745496,
+        "name": "GRNET-ATH-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "8",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "ae1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BRA-BRA-IPTRUNK $GS-01205| BRA-BRA",
+    "circuits": [
+      {
+        "id": 731789,
+        "name": "BRA-BRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 600,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/2/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 601,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "2/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | BUD-ZAG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178497,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "xe-0/1/0"
+    ],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 $GA-02047 | rt2-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 586,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER CESNET #ams-pra-IX-CESNET-AMS-18088 $GS-00787|",
+    "circuits": [
+      {
+        "id": 720236,
+        "name": "AMS-PRA-IX-CESNET-AMS-18088",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1308,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-6 | DUB-LON | to MX1.DUB et-9/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "DUB-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DUB-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "1/1/c11/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-9 | BUD-VIE | to MX1.BUD et-8/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900161,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.2643",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA AUTOGOLE DUB-SAO.T13 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 820,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-11/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GARR P_AE10 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 733,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-10/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE FACEBOOK P_AE18 SRF9934787 | FB ID: FC-26603",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 905,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-2/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 635,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/3.141",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDCLARA #lis-par-SCION-REDCLARA $GS-02435 |",
+    "circuits": [
+      {
+        "id": 732906,
+        "name": "LIS-PAR-SCION-REDCLARA",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 564,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "xe-3/0/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 662,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.3250",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC NETHERLIGHT #ams-lon-GEANTOpen-JISC-NETHERLIGHT $GS-02400 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1753,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "1/1/c27/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER PIONIER P_lag-22 | PIONIER-AP2-IP1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610901185,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae6",
+    "bundle": [
+      "et-5/1/5"
+    ],
+    "bundle-parents": [
+      "et-5/1/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02634 | LIS-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 542,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.610",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT REDCLARA #FR-CLARA $GS-00883 | ASN27750 |",
+    "circuits": [
+      {
+        "id": 660557,
+        "name": "FR-CLARA",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1071,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE FW1-SNM",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1596,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae13.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/4"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT ESNET #ESNET-LON-LHCONE $GS-00821 | ASN293",
+    "circuits": [
+      {
+        "id": 730146,
+        "name": "ESNET-LON-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 970,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae10.1947",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER FCCN MICROSOFT #FCCN-IPP-ExpressRoute-Vlan1947 $GS-01141 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707124,
+        "name": "FCCN-IPP-EXPRESSROUTE-VLAN1947",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 749,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 609,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE |DDOS SERVER 2 10Gb_1 | P_ae22",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1055,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "lag-6",
+    "bundle": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01827 | FRA-PRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177286,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-PRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-PRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/2/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 601,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-owd-ams.nl.geant.org pS OWAMP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1454,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae1.519",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/0",
+      "xe-1/2/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #snm-server-mgmt $GS-00151 | IT Refresh SERVER MGMT",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 833,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #CHI-CHI-IPTRUNK $GS-00028 | CHI-CHI |",
+    "circuits": [
+      {
+        "id": 713273,
+        "name": "CHI-CHI-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 549,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-CHI",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-CHI",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae12.1100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/5",
+      "et-8/0/5",
+      "et-11/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER GARR CERN #gen-gen-GARR-CERNlight-CERN-GARR-16011 $GS-00708 |",
+    "circuits": [
+      {
+        "id": 707040,
+        "name": "GEN-GEN-GARR-CERNLIGHT-CERN-GARR-16011",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 765,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "xe-0/1/0"
+    ],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 $GA-02039 | rt2-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 586,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "2/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | PRA-VIE | to MX1.VIE et-1/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162113,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "2/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | LON2-LON2 | TO MX1.LON2.UK-et-3/1/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162817,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-FRA-DE $GS-00117| ",
+    "circuits": [
+      {
+        "id": 729104,
+        "name": "DCN-MANAGEMENT-FRA-DE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 970,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-3/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | FRA-FRA | TO RT0.FRA.DE- 1/1/c19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 649,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae20.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-1/0/5"
+    ],
+    "description": "SRV_IAS PUBLIC DE-CIX #IX-Peerings-in-DE-CIX-FRA $GS-00947 |",
+    "circuits": [
+      {
+        "id": 730796,
+        "name": "IX-PEERINGS-IN-DE-CIX-FRA",
+        "type": "IP PEERING - NON R&E (PUBLIC)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 668,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PUBLIC"
+    ],
+    "dashboard_info": {
+      "name": "DE-CIX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DE-CIX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.101",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER MAEEN INTERNET2 #LON-PAR-GEANTOpen-MAEEN-INTERNET2-21086 $GS-00728 | ",
+    "circuits": [
+      {
+        "id": 736648,
+        "name": "LON-PAR-GEANTOPEN-MAEEN-INTERNET2-21086",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1132,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MAEEN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MAEEN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4088",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-UCLOUVAIN-ExpressRoute-VLAN4088 $GS-02161 |  UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739665,
+        "name": "BELNET-UCLOUVAIN-EXPRESSROUTE-VLAN4088",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1672,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-3/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ACONET P_AE15 SRF20026 | ACONET ID: Linz-Wien EP 36 (0203/1702673)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 628,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ACONET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ACONET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 560,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "1/x1/1/c8/1",
+      "1/x1/1/c8/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c8/1",
+      "1/x1/1/c8/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02368 | SOF-ZAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-ZAG",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-ZAG",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae10.1955",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KIFU GEANT #bud-bud-KIFU-RARE-200100 $GS-00683 | ",
+    "circuits": [
+      {
+        "id": 705914,
+        "name": "BUD-BUD-KIFU-RARE-200100",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 814,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.24",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET_MICROSOFT_ExpressRoute_VLAN_4083 $GS-01128 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739677,
+        "name": "BELNET-STADKORTRIJK-EXPRESSROUTE-VLAN-4083",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 605,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-lhc-bw-par-fr.geant.org pS BWCTL",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1202,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 536,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae23.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER SWITCH #SWITCH-AP1 $GS-00514 | ASN559 |",
+    "circuits": [
+      {
+        "id": 663078,
+        "name": "SWITCH-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1271,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 597,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae19",
+    "bundle": [
+      "et-1/0/2"
+    ],
+    "bundle-parents": [
+      "et-1/0/2"
+    ],
+    "description": "LAG CUSTOMER UOM SRF19046 $GA-02163 | #UOM-AP2-100G-LAG | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 622,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "UOM",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "UOM",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SRX1-to-SRX2-AMS",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 514,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02268 | AMS-LON",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-8/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE AKAMAI  P_AE27 | Interxion ID: DP76931",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 996,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-7/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | LON-LON | to RT0.LON 2/1/c19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1390,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae15",
+    "bundle": [
+      "xe-2/1/0"
+    ],
+    "bundle-parents": [
+      "xe-2/1/0"
+    ],
+    "description": "LAG RE_INTERCONNECT MARWAN $GA-02449 | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 801,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "MARWAN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MARWAN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS | EX1 MGMT - ex1.lon2.uk.geant.net",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 523,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:3060",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET ORACLE #OFCFODMOB-02630 $GS-02630",
+    "circuits": [
+      {
+        "id": 744345,
+        "name": "OFCFODMOB-02630",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "1/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | AMS-LON | to LON01.GRV1 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899777,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-2/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | DDOS Mitigation Server 1 DATA link | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 931,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-4/0/2",
+      "et-4/0/5"
+    ],
+    "bundle-parents": [
+      "et-4/0/2",
+      "et-4/0/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01787 | LIS-POR |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 539,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-POR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-POR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.2733",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT MULTI_DOMAIN_OPEN_NSA AUTOGOLE SAO-DUB | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 810,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 527,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-2/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | BUC-CHI | ROEDUNET CID: BUC-CHI-040-4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 556,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c6/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | MIL2-THE | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916226,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-THE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-THE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "xe-0/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENAM P_AE10 SRF21066 | RENAM ID: MX240 xe-2/0/2-AP2-L2 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 562,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 603,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "xe-0/1/3.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER RENAM #buc-chi-RENAM-ROEDUNET-240752 $GS-02576 |",
+    "circuits": [
+      {
+        "id": 743607,
+        "name": "BUC-CHI-RENAM-ROEDUNET-240752",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 539,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "1/1/c13/1"
+    ],
+    "bundle-parents": [
+      "1/1/c13/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-50068 | LON2-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX2-SRX1-AMS-OFFICE |",
+    "circuits": [
+      {
+        "id": 708319,
+        "name": "SRX2-SRX1-AMS-OFFICE",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 522,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "2/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | PAR-PAR | TO MX1.PAR.FR et-9/1/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162817,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PAR-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PAR-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae16.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/1",
+      "xe-1/2/3",
+      "xe-2/0/7",
+      "xe-2/1/2"
+    ],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #GEANT-Slough-Access $GS-00469 | Fortigate WAN GEANT-IT",
+    "circuits": [
+      {
+        "id": 661315,
+        "name": "GEANT-SLOUGH-ACCESS",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1037,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 561,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-11/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GARR P_AE12 SRF21107 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1214,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-22.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER CARNET #CARNET-AP1 $GS-00440 | ASN2108 | ",
+    "circuits": [
+      {
+        "id": 747838,
+        "name": "CARNET-AP1",
+        "type": "GEANT IP",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "15",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1337,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "lag-6.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #DUB-LON-IPTRUNK $GS-00031 | DUB-LON | ",
+    "circuits": [
+      {
+        "id": 747278,
+        "name": "DUB-LON-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "DUB-LON",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DUB-LON",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.908",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 GEANT #AMS-PAR-MISC-GEANT-INTERNET2-9940543 $GS-00654 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1738,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.207",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT SINET #FR-SINET $GS-00885 | ASN2907 | MANLAN ID: 207",
+    "circuits": [
+      {
+        "id": 661583,
+        "name": "FR-SINET",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 869,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae2.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/2/2",
+      "xe-3/2/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-lis-pt $GS-00153 | SW1-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 679551,
+        "name": "EX3400-MANAGEMENT-LIS-PT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 736,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/3/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 610,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #SOF-THE-IPTRUNK $GS-02424 | SOF-THE | ",
+    "circuits": [
+      {
+        "id": 745269,
+        "name": "SOF-THE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 8,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-THE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-THE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-0/0/0"
+    ],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02040 | CHI-KIE |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 587,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-KIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-KIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-22:1630",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET SCION #SCION-02381 $GS-02381",
+    "circuits": [
+      {
+        "id": 745491,
+        "name": "SCION-02381",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c12/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900226,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae13",
+    "bundle": [
+      "et-3/0/4"
+    ],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "LAG RE_INTERCONNECT ESNET  $GA-01549 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 703,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/x1/1/c8/1",
+      "1/x1/1/c8/2",
+      "1/x1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c8/1",
+      "1/x1/1/c8/2",
+      "1/x1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01741 | LJU-MIL2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-MIL2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-MIL2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12",
+    "bundle": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "LAG CUSTOMER RENATER $GA-01816 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 678,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae11.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/4"
+    ],
+    "description": "SRV_IAS CUSTOMER DFN #DFN-AP1-IAS IASPS $GS-00566 | ASN680 |",
+    "circuits": [
+      {
+        "id": 743293,
+        "name": "DFN-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 784,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "lag-7.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #POZ-PRA-IPTRUNK $GS-02407 | POZ-PRA | ",
+    "circuits": [
+      {
+        "id": 740495,
+        "name": "POZ-PRA-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-PRA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-PRA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae20.111",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/0/3",
+      "xe-2/1/1"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT NKN #NKN-GEN-LHCONE $GS-00833 | ASN9885",
+    "circuits": [
+      {
+        "id": 678079,
+        "name": "NKN-GEN-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 897,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "NKN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NKN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "et-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae5 | BUC-CHI | Connected to GRV02 1/1/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 593,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae11.3061",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/1"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET ORACLE #OFCFODMOB-02631 $GS-02631",
+    "circuits": [
+      {
+        "id": 744387,
+        "name": "OFCFODMOB-02631",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 690,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ORACLE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae2.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-CHI1-MD $GS-00127 | DCN MANAGEMENT ",
+    "circuits": [
+      {
+        "id": 713270,
+        "name": "DCN-MANAGEMENT-CHI1-MD",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 550,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY To Switch Cluster vme.0",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 518,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "lag-5",
+    "bundle": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01961 | FRA-GEN",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177285,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/2/4.1629",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION INTERNET2 #gen-par-SCION-SCION-INTERNET2-2 $GS-02311 |",
+    "circuits": [
+      {
+        "id": 736653,
+        "name": "GEN-PAR-SCION-SCION-INTERNET2-2",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1262,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae5",
+    "bundle": [
+      "et-0/0/0"
+    ],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02018 | BUC-CHI",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 613,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER URAN SRF21-059 P_AE10 | URAN Circuit ID:GEANT-POZ-IEV-1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 560,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae16",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01704 | LON2-PRD-ESX10 VM TRAFFIC LAG",
+    "circuits": [
+      {
+        "id": 658674,
+        "name": "LON2-PRD-ESX10-VM-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 604,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-20.12",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER HEANET #HEANET-AP1 $GS-00473 | ASN1213 | ",
+    "circuits": [
+      {
+        "id": 747282,
+        "name": "HEANET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "4",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HEANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT GEANT #CAM-OFFICE-TO-AMS-OFFICE-L2CIRCUIT |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1547,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-2/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC VIX P_AE10 | DR ID: AT275860 | VIX ID: 1298-1761569",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 926,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.3240",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET HARNET #lon-lon-GEANTOpen-HARNET-NORDUNET $GS-02606 | ",
+    "circuits": [
+      {
+        "id": 742671,
+        "name": "LON-LON-GEANTOPEN-HARNET-NORDUNET",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 631,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "HARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.938",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CESNET #pra-ams-CESNET-SURF-FABRIC $GS-02649 |",
+    "circuits": [
+      {
+        "id": 747231,
+        "name": "PRA-AMS-CESNET-SURF-FABRIC",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1763,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/1/3.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #par-fra-SUPERPOP-QFX-GEANT $GS-00078 |",
+    "circuits": [
+      {
+        "id": 729477,
+        "name": "FRA-PAR-SUPERPOP-QFX-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1121,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae15",
+    "bundle": [
+      "et-3/1/5"
+    ],
+    "bundle-parents": [
+      "et-3/1/5"
+    ],
+    "description": "LAG PRIVATE GOOGLE $GA-02247 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 769,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-1/3/0.2100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER AARNET NETHERLIGHT #lon-lon-GEANTOpen-AARNET-NETHERLIGHT-21003 $GS-00284 |",
+    "circuits": [
+      {
+        "id": 709856,
+        "name": "LON-LON-GEANTOPEN-AARNET-NETHERLIGHT-21003",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 662,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "AARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-2/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GARR P_AE10 SRF9926135 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 712,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "et-7/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_AE7 | AMT RELAY LINK #1 | TO AMT1.LON2.UK et-0/0/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 893,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-4/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 992,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02469 | LON2-LON2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-LON2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-LON2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-7/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE T-SYSTEMS P_AE21 SRF22104 |T-systems CID:237419053/230216-2621",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 544,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "et-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE1 | CHI-CHI |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 594,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-CHI",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-CHI",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "1/x1/1/c2/2",
+      "1/x1/1/c2/3"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/2",
+      "1/x1/1/c2/3"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-1/3/0.3101",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SURF AARNET #lon-lon-SURF-AARNET-23009 $GS-02249 |",
+    "circuits": [
+      {
+        "id": 726158,
+        "name": "LON-LON-SURF-AARNET-23009",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1141,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/3/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 624,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.26",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-MULTICAST-TUNNEL-UTWENTE  $GS-02448",
+    "circuits": [
+      {
+        "id": 736888,
+        "name": "GRE-MULTICAST-TUNNEL-UTWENTE",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1585,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.13",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET_ICT_ExpressRoute_Vlan4091 $GS-01125 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739679,
+        "name": "BELNET-ICT-EXPRESSROUTE-VLAN4091",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 596,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "2/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | GEN-PAR | connected to GEN01.GRV5 port 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162049,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 622,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae1.27",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/4",
+      "xe-3/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #PRA-DTN-SERVER-1-iDRAC",
+    "circuits": [
+      {
+        "id": 725644,
+        "name": "PRA-DTN-SERVER-1-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 958,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-11/2/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-vie-at-bwctl new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 723851,
+        "name": "PS-VIE-AT-OWAMP-NEW",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 912,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:1006",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET GRNET #FED4FIRE-00669 $GS-00669",
+    "circuits": [
+      {
+        "id": 747356,
+        "name": "FED4FIRE-00669",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | MAD-MAR | connected to MAR01-GRV1 1/1/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 679,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 605,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae11.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/1/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER UOM #UOM-AP1 $GS-00519 | ASN12046 | ",
+    "circuits": [
+      {
+        "id": 722110,
+        "name": "UOM-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 650,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "UOM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UOM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.7",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-IMEC-ExpressRoute-VLAN4085 $GS-02091 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739663,
+        "name": "BELNET-IMEC-EXPRESSROUTE-VLAN4085",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 590,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/5.2100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT HBKU #FR-HBKU $GS-00879 | ASN34945 |",
+    "circuits": [
+      {
+        "id": 661713,
+        "name": "FR-HBKU",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1526,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "HBKU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HBKU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.3003",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER LAT SURF #EVLBI-JIVE-00662 $GS-00662",
+    "circuits": [
+      {
+        "id": 745967,
+        "name": "EVLBI-JIVE-00662",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1125,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.2200",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER GEANT #AMS-PAR-RENATER-RARE-20070 $GS-00657 |",
+    "circuits": [
+      {
+        "id": 736080,
+        "name": "AMS-PAR-RENATER-RARE-20070",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1082,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-6",
+    "bundle": [
+      "2/1/c11/1"
+    ],
+    "bundle-parents": [
+      "2/1/c11/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02635 | LIS-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177286,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/5.2369",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT RE_INTERCONNECT UBUNTUNET ESNET #lon-par-ESnet-ubuntunet-14020 $GS-00737 |",
+    "circuits": [
+      {
+        "id": 706028,
+        "name": "LON-PAR-ESNET-UBUNTUNET-14020",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1495,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "1/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | AMS-LON | to LON01.GRV1 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899905,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-LON",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-LON",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 520,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/0/4",
+      "et-7/1/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-AMS-IPTRUNK $GS-02458| AMS-AMS | AMS-AMS-NOKIA",
+    "circuits": [
+      {
+        "id": 735616,
+        "name": "AMS-AMS-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1326,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 637,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-20.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER BREN #BREN-AP1 $GS-00438 | ASN6802 | ",
+    "circuits": [
+      {
+        "id": 744953,
+        "name": "BREN-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "8",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "1/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | GEN-GEN | to MX1.GEN.CH et-7/0/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900673,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO SINGAREN #SingAREN-GEO-UK-1 $GA-02230| SRF19075 | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1579,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.351",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #FLOWMON-PAR-FR-IDRAC | FlowMon1 Management + FanOut CONTACT: evangelos.spatharas@geant.org",
+    "circuits": [
+      {
+        "id": 739098,
+        "name": "FLOWMON-PAR-FR-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1363,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "xe-0/1/1",
+      "xe-0/1/2"
+    ],
+    "bundle-parents": [
+      "xe-0/1/1",
+      "xe-0/1/2"
+    ],
+    "description": "LAG CUSTOMER URAN SRF21-056 $GA-02024 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 582,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT MARWAN P_ae15 SRF23094 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1573,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "MARWAN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MARWAN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "irb.518",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #CORIANT-MGMT-LON2-UK-VRF-VLAN518 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 817,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae7",
+    "bundle": [
+      "et-7/0/5"
+    ],
+    "bundle-parents": [
+      "et-7/0/5"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS $GA-02301 | LON2-AMT |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 624,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.204",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT CANARIE #FR-CANARIE-vlan204 $GS-00881 | ASN6509 | MANLAN ID: 204",
+    "circuits": [
+      {
+        "id": 660638,
+        "name": "FR-CANARIE-VLAN204",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 877,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CANARIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae12.1006",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT CSTNET #FR-IC1-CSTNET-QUINARY $GS-02362 | ASN7497 | ",
+    "circuits": [
+      {
+        "id": 729006,
+        "name": "FR-IC1-CSTNET-QUINARY",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 636,
+    "dashboards": [
+      "IC1",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CSTNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CSTNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "bundle-parents": [
+      "1/1/c1/1",
+      "1/1/c5/1",
+      "1/1/c7/1",
+      "1/1/c10/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01761 | LON-LON2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-5",
+    "bundle": [
+      "1/x1/1/c6/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c6/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02608 | MIL2-THE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177285,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-THE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-THE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "et-0/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE1 | KIE-KIE | KIE-KIE-IP1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 536,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-KIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-KIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21.110",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER EUMETSAT-SVALBARD #EUMET-SVALBARD-HAM-MONITORINGVLAN $GS-02155 | NU-S800116 | - Monitoring Link 1",
+    "circuits": [
+      {
+        "id": 747590,
+        "name": "EUMET-SVALBARD-HAM-MONITORINGVLAN",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "14",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "EUMETSAT-SVALBARD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EUMETSAT-SVALBARD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 667,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/3/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS PERFSONAR SRF0000001 | perfSONAR iDRAC",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 563,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae14.116",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5",
+      "et-8/0/2",
+      "et-8/1/2",
+      "et-8/1/5"
+    ],
+    "description": "SRV_L3VPN CUSTOMER RENATER #RENATER-AP2-IPv6-LHCONE $GS-00856 | ASN2200",
+    "circuits": [
+      {
+        "id": 733483,
+        "name": "RENATER-AP2-IPV6-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1383,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "1/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915972,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1048,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae30",
+    "bundle": [
+      "et-3/0/4"
+    ],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "LAG RE_INTERCONNECT ESNET $GA-01594 | AMS-ESNET-400G",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1002,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae10.1944",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_GCS CUSTOMER FCCN MICROSOFT #FCCN-NoveSBE-ExpressRoute-Vlan1944 $GS-01144 | MANUALLY MIGRATED FROM MX1.LIS 25/08/21",
+    "circuits": [
+      {
+        "id": 706526,
+        "name": "FCCN-NOVESBE-EXPRESSROUTE-VLAN1944",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 613,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "et-0/0/2"
+    ],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02148 | BRA-BRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 595,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae44",
+    "bundle": [
+      "et-5/1/0"
+    ],
+    "bundle-parents": [
+      "et-5/1/0"
+    ],
+    "description": "LAG PRIVATE GOOGLE $GA-02225 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1004,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/0/5",
+      "et-7/1/2",
+      "et-7/1/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #POZ-POZ-IPTRUNK $GS-02528| POZ-POZ | POZ-POZ-MGMT",
+    "circuits": [
+      {
+        "id": 740149,
+        "name": "POZ-POZ-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 855,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-POZ",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-POZ",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 565,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "xe-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | BUC-CHI | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 560,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-CHI",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-CHI",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COLT P_AE28 | COLT ID: 444162877",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1042,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COLT - VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COLT - VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-10/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1564,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "ae1.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/8",
+      "xe-5/0/9"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-buc-ro| SW2-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 728006,
+        "name": "EX3400-MANAGEMENT-BUC-RO",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 894,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:705",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET GRNET #FED4FIRE-00668 $GS-00668",
+    "circuits": [
+      {
+        "id": 745508,
+        "name": "FED4FIRE-00668",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER AMS #ams-pra-IX-CESNET-AMS-18088 $GS-00787|",
+    "circuits": [
+      {
+        "id": 720236,
+        "name": "AMS-PRA-IX-CESNET-AMS-18088",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 928,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "AMS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae10.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/0/2"
+    ],
+    "description": "SRV_IAS CUSTOMER LITNET #LITNET-AP2-IAS IASGWS $GS-00535 | ASN2847 |",
+    "circuits": [
+      {
+        "id": 745338,
+        "name": "LITNET-AP2-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 882,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "LITNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LITNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "1/1/c5/1"
+    ],
+    "bundle-parents": [
+      "1/1/c5/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01854 | MIL2-VIE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-VIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-VIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 845,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c5/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | LON-LON2 | TO LON02 GRV1 1/3/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899777,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4066",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet-ONDD-ExpressRoute-Vlan4066 $GS-02390 | ",
+    "circuits": [
+      {
+        "id": 739660,
+        "name": "BELNET-ONDD-EXPRESSROUTE-VLAN4066",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1660,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.411",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER RedIRIS Microsoft #RedIRIS-UCLM-ExpressRoute-Vlan411 $GS-01166 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 706055,
+        "name": "REDIRIS-UCLM-EXPRESSROUTE-VLAN411",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 829,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 850,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-1/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 673,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae30.3001",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-CONTROL-FRANKFURT-VRF-VLAN3001 $GS-00861 | NAGIOS gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 733003,
+        "name": "TAAS-CONTROL-FRANKFURT-VRF-VLAN3001",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1129,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.52",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "PHY INFRASTRUCTURE ACCESS FLOWMON SRF0000001 | FlowMon2 Collector Interface CONTACT: evangelos.spatharas@geant.org IMPLEMENTED 20170708",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 688,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/8.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #DTN-PRA-10G-DATA $GS-02354",
+    "circuits": [
+      {
+        "id": 727980,
+        "name": "DTN-PRA-10G-DATA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 959,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "irb.500",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #RE-LON2-UK-VRF-VLAN500 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 812,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5",
+      "et-1/1/2",
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MAR-MIL2-IPTRUNK $GS-01185| MAR-MIL2 | MAR-MIL2",
+    "circuits": [
+      {
+        "id": 746147,
+        "name": "MAR-MIL2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 685,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MIL2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MIL2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae10.2804",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KIFU REDIRIS #SZTAKI-KIFU-RedIRIS-SLICES-UC3M $GS-02512|",
+    "circuits": [
+      {
+        "id": 738341,
+        "name": "SZTAKI-KIFU-REDIRIS-SLICES-UC3M",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 873,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "KIFU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KIFU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:3903",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01151 $GS-01151",
+    "circuits": [
+      {
+        "id": 747628,
+        "name": "AMS-HAM-MSE-01151",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MICROSOFT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "2/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | HAM-TAR | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178497,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-TAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-TAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE6     | LON2-PRD-ESX10 NIC2 PORT1",
+    "circuits": [
+      {
+        "id": 717189,
+        "name": "LON2-PRD-ESX10-NIC2-PORT1",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 658,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CERN P_AE17 SRF23043-1| fc:33:42:d1:f6:d0 547 E513-E-RJUXM-1.cern.ch ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1333,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/1/c9/2"
+    ],
+    "bundle-parents": [
+      "1/1/c9/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02349 | HAM-TAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-TAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-TAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT KREONET #NL-KREONET-LHCONE $GS-00837 | ASN17579",
+    "circuits": [
+      {
+        "id": 734566,
+        "name": "NL-KREONET-LHCONE",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1113,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "KREONET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KREONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1050,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 519,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae33.2013",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER NORDUNET #NL-NORDUNET-LHCONE-IPV4 $GS-00838 | ASN2603 |",
+    "circuits": [
+      {
+        "id": 740767,
+        "name": "NL-NORDUNET-LHCONE-IPV4",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1693,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-5/2/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS BENOCS #BENOCS-FRA  $GS-02434 | ASN209039",
+    "circuits": [
+      {
+        "id": 731223,
+        "name": "BENOCS-FRA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1003,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:cp-300",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET INTERNET2 #GENI-00628 $GS-00628",
+    "circuits": [
+      {
+        "id": 744064,
+        "name": "GENI-00628",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT ASREN SRF19049 $GA-01315 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1024,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ASREN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASREN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/0/4",
+      "et-7/1/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #GEN-GEN-IPTRUNK $GS-02464| GEN-GEN | RT0.GEN to MX1.GEN",
+    "circuits": [
+      {
+        "id": 739713,
+        "name": "GEN-GEN-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1459,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-GEN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-GEN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 927,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-11/2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 867,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon.uk.geant.net",
+    "name": "lag-6",
+    "bundle": [
+      "1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02006 | DUB-LON",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177286,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "DUB-LON",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "DUB-LON",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01774 | GEN-MIL2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MIL2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MIL2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "1/x1/1/c26/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RASH P_lag-24",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917505,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RASH",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RASH",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-0/0/40",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN            | pS Throughtput Tester Interface",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 542,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "ae1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #CHI-CHI-IPTRUNK $GS-00028 | CHI-CHI|",
+    "circuits": [
+      {
+        "id": 713273,
+        "name": "CHI-CHI-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 605,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-CHI",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-CHI",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-11/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO TENET #TENET-GEO-UK | P_AE28 SRF21083 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1653,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "TENET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae1.32",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/1/7",
+      "xe-2/2/7"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ESNET #ESNET-GEN-773-OOB $GS-00877 | ASN293 |",
+    "circuits": [
+      {
+        "id": 708223,
+        "name": "ESNET-GEN-773-OOB",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1488,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER LAT | $GA-02073 | #LAT-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LAT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/0/6.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-lon-uk-psmp-bwctl | psmp-gn-bw-lon-uk.geant.org pS BWCTL",
+    "circuits": [
+      {
+        "id": 708187,
+        "name": "PS-LON-UK-PSMP-BWCTL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1477,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1342,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-22.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/2"
+    ],
+    "description": "SRV_IAS CUSTOMER MARNET #MARNET-AP1-IAS IASGWS $GS-00536 | ASN44224 | ",
+    "circuits": [
+      {
+        "id": 744958,
+        "name": "MARNET-AP1-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "5",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "MARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-5/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae6 | BIL-MAD |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 933,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.991",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE Access PARIS #PAR-TNMS | Internal network",
+    "circuits": [
+      {
+        "id": 739097,
+        "name": "PAR-TNMS",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1226,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/26",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX03 NIC2 PORT3 - VSAN PORT",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 674,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "et-0/0/3"
+    ],
+    "bundle-parents": [
+      "et-0/0/3"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02023 | KIE-KIE|",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 579,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-KIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-KIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae15",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01703 | LON2-SEC-ESX21 VM Traffic LAG - No LACP",
+    "circuits": [
+      {
+        "id": 658690,
+        "name": "LON2-SEC-ESX21-VM-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 603,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae18.551",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RESTENA RENATER #fra-par-SLICES-RESTENA-RENATER-VL551 $GS-02485 | ",
+    "circuits": [
+      {
+        "id": 737780,
+        "name": "FRA-PAR-SLICES-RESTENA-RENATER-VL551",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1604,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RESTENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "1/x1/1/c4/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916099,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/40",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | pS Throughtput Tester Interface (em3 on psmp-gn-mgmt-lon2-uk.geant.org)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 540,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c2/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/1"
+    ],
+    "description": "LAG CUSTOMER BREN | $GA-01291 | #BREN-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BREN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BREN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE16 | QFX.LON2.UK xe-1/0/46",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1022,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Was PSMP Server",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 605,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae32.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/0/2",
+      "xe-11/2/3"
+    ],
+    "description": "SRV_IAS UPSTREAM COGENT #COGENT-GWS-FRA $GS-00066 | ASN174",
+    "circuits": [
+      {
+        "id": 731788,
+        "name": "COGENT-GWS-FRA",
+        "type": "GWS - UPSTREAM",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1028,
+    "dashboards": [
+      "IAS_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COGENT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 812,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 527,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE ORACLE P_AE23 | GEANT-Interxion-AMS8 1-1 | Digital Realty CID: NL159411",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 669,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "1/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | GEN-PAR | Connected to PAR01.GRV2 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899905,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae15.989",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ESNET RENATER #gen-mar-ESNET-RENATER-24038 $GS-02504 |",
+    "circuits": [
+      {
+        "id": 738302,
+        "name": "GEN-MAR-ESNET-RENATER-24038",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 728,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP P_AE30 | QFX xe-1/0/18",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1265,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "irb.532",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #tools-access-LON2-UK-VRF-VLAN532 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1659,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "1/x1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915970,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 596,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-23",
+    "bundle": [
+      "1/x1/1/c27/1",
+      "2/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c27/1",
+      "2/x1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER ULAKBIM | $GA-01962| #ULAKBIM-AP2-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177303,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "2/1/c10/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | GEN-PAR | connected to GEN01.GRV5 port 1/1/9",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162241,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER EENET | $GA-02053 | EENET-AP1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "EENET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "EENET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae20",
+    "bundle": [
+      "et-1/1/5"
+    ],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "LAG PUBLIC MIX SRF9929723 $GA-01772 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 694,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "2/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | LON2-PAR | TO PAR.GRV3 - 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162049,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-1/3/0.3920",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER AARNET SINGAREN #AMS-LON-AARNET-SINGAREN-23049 $GS-02342 |",
+    "circuits": [
+      {
+        "id": 728403,
+        "name": "AMS-LON-AARNET-SINGAREN-23049",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1257,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "AARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.28",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet-ONDD-ExpressRoute-Vlan4066 $GS-02390 | ",
+    "circuits": [
+      {
+        "id": 739660,
+        "name": "BELNET-ONDD-EXPRESSROUTE-VLAN4066",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 608,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1565,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 533,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 670,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.141",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDCLARA #lis-par-SCION-REDCLARA $GS-02435 ",
+    "circuits": [
+      {
+        "id": 732906,
+        "name": "LIS-PAR-SCION-REDCLARA",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 675,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.952",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET REDIRIS #SLCUTH-02499 $GS-02499|",
+    "circuits": [
+      {
+        "id": 745434,
+        "name": "SLCUTH-02499",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 913,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1458,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "xe-0/1/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER RENAM #chi-kie-EAP-RENAM-URAN-22087 $GS-02212|",
+    "circuits": [
+      {
+        "id": 723461,
+        "name": "CHI-KIE-EAP-RENAM-URAN-22087",
+        "type": "GEANT - GBS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 593,
+    "dashboards": [
+      "EAP",
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 519,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.3004",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC NETHERLIGHT #AMS-LON-EXPRES-NETHERLIGHT-JISC-18009 $GS-00644 |",
+    "circuits": [
+      {
+        "id": 734615,
+        "name": "AMS-LON-EXPRES-NETHERLIGHT-JISC-18009",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1126,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "1/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915972,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae11.600",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-2/1/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER CESNET #CESNET-AP1 $GS-00444 | ASN2852 |",
+    "circuits": [
+      {
+        "id": 725106,
+        "name": "CESNET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 936,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "et-2/0/2",
+      "et-2/1/5"
+    ],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-2/1/5"
+    ],
+    "description": "LAG PUBLIC VIX SRF9923739 $GA-01867 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 690,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-2/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 727,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "lag-6",
+    "bundle": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "bundle-parents": [
+      "1/1/c8/1",
+      "1/1/c8/2",
+      "1/1/c9/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01944 | FRA-PRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177286,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-PRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-PRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae10.700",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-5/0/2",
+      "et-9/0/5",
+      "et-11/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC INTERNET2 #LON-PAR-SYNGENTA-JISC-INTERNET2-17052 $GS-00730 |",
+    "circuits": [
+      {
+        "id": 736674,
+        "name": "LON-PAR-SYNGENTA-JISC-INTERNET2-17052",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1233,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae10.25",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-2/1/5",
+      "et-11/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER GARR UBUNTUNET #lon-mil2-ASI-BSC-to-Fucino-Ubuntunet-GARR-20007 $GS-00735 |",
+    "circuits": [
+      {
+        "id": 705891,
+        "name": "LON-MIL2-ASI-BSC-TO-FUCINO-UBUNTUNET-GARR-20007",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 790,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "et-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENAM P_AE10  | RENAM ID: TBC",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 623,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "et-1/0/5",
+      "et-1/1/2",
+      "et-1/1/5"
+    ],
+    "bundle-parents": [
+      "et-1/0/5",
+      "et-1/1/2",
+      "et-1/1/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02164 | MAR-MIL2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 684,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAR-MIL2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAR-MIL2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-21",
+    "bundle": [
+      "1/x1/1/c18/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c18/1"
+    ],
+    "description": "LAG CUSTOMER AMRES | $GA-01902 | #AMRES-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177301,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "AMRES",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMRES",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-22.111",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c27/1"
+    ],
+    "description": "SRV_L3VPN CUSTOMER PIONIER #PIONIER-AP2-LHCONE $GS-00843 | ASN8501 | ",
+    "circuits": [
+      {
+        "id": 747600,
+        "name": "PIONIER-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "10",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-SOF-BG-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "11",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | GEN-MIL2 | to RT1.MIL2 et-9/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899970,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.1237",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KREONET RARE #AMS-AMS-KREONET-RARE-22097 $GS-02218 | ",
+    "circuits": [
+      {
+        "id": 736100,
+        "name": "AMS-AMS-KREONET-RARE-22097",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1119,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "KREONET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KREONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/3.1640",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRnet SCION SCION-02382 $GS-02382",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1126,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.1916",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE INTERNET2 RNP #AMS-PAR-RARE-INTERNET2-RNP-20061 $GS-00655 |",
+    "circuits": [
+      {
+        "id": 736072,
+        "name": "AMS-PAR-RARE-INTERNET2-RNP-20061",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1537,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "2/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-22 | GRNET-LHCONE-IP1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178113,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "1/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | AMS-AMS | to RT1.AMS et-7/0/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900673,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae31",
+    "bundle": [
+      "xe-4/3/5",
+      "xe-8/0/0"
+    ],
+    "bundle-parents": [
+      "xe-4/3/5",
+      "xe-8/0/0"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 711,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 613,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-10/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | NORDUNET AP UPGRADE | LR4 Installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1560,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 601,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.3020",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #AMS-PAR-SINET-SD-WAN-SINET-SINET-17090 $GS-00659 |",
+    "circuits": [
+      {
+        "id": 736070,
+        "name": "AMS-PAR-SINET-SD-WAN-SINET-SINET-17090",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1080,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.612",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT REDCLARA #REDCLARA-PAR-COPERNICUS $GS-00849 | ASN27750",
+    "circuits": [
+      {
+        "id": 736650,
+        "name": "REDCLARA-PAR-COPERNICUS",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1136,
+    "dashboards": [
+      "COPERNICUS",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "1/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | AMS-FRA | to AMS01-GRV1 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899521,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/16",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE17    | LON2-PRD-ESX11 NIC2 PORT2",
+    "circuits": [
+      {
+        "id": 658557,
+        "name": "LON2-PRD-ESX11-NIC2-PORT2",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 667,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 534,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ge-0/0/36",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX01 IDRAC",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 553,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE3     | LON2-PRD-ESX03 NIC2 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 657,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/1/5.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER JISC #ams-lon-LOFAR-NETHERLIGHT-JISC-10007 $GS-00783",
+    "circuits": [
+      {
+        "id": 711990,
+        "name": "AMS-LON-LOFAR-NETHERLIGHT-JISC-10007",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 773,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE DTN-Project #HAM-DTN-10G-DATA $GA-02286",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899587,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c24/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ARNES P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917378,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae7.10",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #FRA-FRA-AMT-RELAYLINK $GS-02306 | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1713,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4070",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEFEDPOL-02524 $GS-02524",
+    "circuits": [
+      {
+        "id": 744256,
+        "name": "MSEFEDPOL-02524",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-4/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE- WAS FRA-GEN",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1439,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/3/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 611,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/3/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 610,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-5/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS SUPERPOP P_AE30  | QFX xe-1/0/29",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 823,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c8/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BRU-PAR-IPTRUNK $GS-02280 | BRU-PAR | ",
+    "circuits": [
+      {
+        "id": 744055,
+        "name": "BRU-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 6,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRU-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRU-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "2/x1/1/c2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-9 | BRU-BRU | to RT1.BRU xe0-0/1/7",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178116,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRU-BRU",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRU-BRU",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | NEMO DDOS SERVER link 1 Node 1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1281,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 520,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/1/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 535,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 925,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "et-1/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC MIX P_AE20 SRF9949654 | MIX ID: XCID202001-019",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 662,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | BRA-BRA-MGMT | to RT0.BRA.SK 1/X1/1/C2/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 563,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA-MGMT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA-MGMT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-21.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1",
+      "1/x1/1/c26/2"
+    ],
+    "description": "SRV_IAS CUSTOMER ULAKBIM #ULAKBIM-AP1-IAS IASPS $GS-00591 | ASN8517 | ",
+    "circuits": [
+      {
+        "id": 745293,
+        "name": "ULAKBIM-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "11",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER PIONIER SRF9915527 $GA-01372 | Connection to Pionier Project Switch",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 572,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 528,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 929,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ge-0/0/33",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik A IPMI",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 550,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.3005",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER RARE #RARE-02640 $GS-02640 |",
+    "circuits": [
+      {
+        "id": 732564,
+        "name": "RARE-P4-B1-FRA",
+        "type": "L2SERVICES",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1438,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/15",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE16    | LON2-PRD-ESX10 NIC2 PORT2",
+    "circuits": [
+      {
+        "id": 658650,
+        "name": "LON2-PRD-ESX10-NIC2-PORT2",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 666,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO ESnet #ESnet-GEO-UK-1 $GA-01449 | Lon-ESnet-OPEN-400G",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 870,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-20.111",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c11/1",
+      "1/1/c11/2",
+      "1/1/c12/1",
+      "1/1/c12/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER JISC #JISC-AP2-LHCONE $GS-02474 | ASN786 | ",
+    "circuits": [
+      {
+        "id": 743311,
+        "name": "JISC-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "7",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS PERFSONAR SRF0000001 | psmp-gn-owd-lon-uk.geant.org pS OWAMP",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 759,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/35",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik D Data Port 1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 733,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "et-5/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 799,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.300",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET INTERNET2 #GENI-00628 $GS-00628",
+    "circuits": [
+      {
+        "id": 744064,
+        "name": "GENI-00628",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 903,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-8.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LON2-PAR-IPTRUNK $GS-00053 | LON2-PAR | ",
+    "circuits": [
+      {
+        "id": 739436,
+        "name": "LON2-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY to Virgin Media NTU",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 517,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "1/x1/1/c26/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ARNES P_lag-20",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610917506,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.43",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-HoGENT-ExpressRoute-VLAN4070 $GS-02574 | ",
+    "circuits": [
+      {
+        "id": 741111,
+        "name": "BELNET-HOGENT-EXPRESSROUTE-VLAN4070",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 688,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae10.1931",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER FCCN #FCCN-AP2 $GS-00460 | ASN1930",
+    "circuits": [
+      {
+        "id": 712362,
+        "name": "FCCN-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 608,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "2/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | GEN-PAR | connected to GEN01.GRV5 port 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611161665,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae21.4003",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/1/0"
+    ],
+    "description": "SRV_L3VPN CUSTOMER T-SYSTEMS #DE-T-SYSTEMS-COPERNICUS $GS-02332 | ASN6878",
+    "circuits": [
+      {
+        "id": 727979,
+        "name": "DE-T-SYSTEMS-COPERNICUS",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 716,
+    "dashboards": [
+      "COPERNICUS",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "T-SYSTEMS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "T-SYSTEMS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "1/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | FRA-FRA | TO RT1.FRA.DE-et-3/0/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900673,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "irb.519",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SERVER-MGMT-LON2-UK-VRF-VLAN519 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 830,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-21.111",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c25/1"
+    ],
+    "description": "SRV_L3VPN CUSTOMER ARNES #ARNES-AP1-LHCONE $GS-00807 | ASN2107 | ",
+    "circuits": [
+      {
+        "id": 747535,
+        "name": "ARNES-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "10",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae13.106",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/0/4"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ESNET #UK-ESNET-IPV6 $GS-00916 | ASN293 | Lon-ESnet-IPv6-400G",
+    "circuits": [
+      {
+        "id": 730142,
+        "name": "UK-ESNET-IPV6",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 969,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "1/1/c1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | AMS-FRA | To  FRA01-GRV2- 1/3/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899521,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 690,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4090",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #Belnet-fgov-ExpressRoute-Vlan4090 $GS-01124 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739678,
+        "name": "BELNET-FGOV-EXPRESSROUTE-VLAN4090",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1674,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-4/1/4.1488",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER ESNET #lon-par-NCSA-LAAS-ESNET-RENATER-15057 $GS-00738 |",
+    "circuits": [
+      {
+        "id": 738739,
+        "name": "LON-PAR-NCSA-LAAS-ESNET-RENATER-15057",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1517,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 584,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "1/x1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02385 | COR-DUB",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-DUB",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-DUB",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae13",
+    "bundle": [
+      "et-4/0/4"
+    ],
+    "bundle-parents": [
+      "et-4/0/4"
+    ],
+    "description": "LAG RE_INTERCONNECT ESNET  $GA-01482 | ASN293 | Lon-ESNET-400G",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 941,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae33.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_INFRASTRUCTURE ACCESS | NEMO DDOS Mitigation Server 1 - DIRTY-IAS | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 815,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/16",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE17    | LON2-PRD-ESX11 NIC1 PORT2",
+    "circuits": [
+      {
+        "id": 658457,
+        "name": "LON2-PRD-ESX11-NIC1-PORT2",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 531,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "2/1/c19/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | AMS-AMS | to RT1.AMS et-7/1/4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162817,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 850,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae10.1930",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER FCCN #FCCN-AP1 $GS-00459 | ASN1930",
+    "circuits": [
+      {
+        "id": 661976,
+        "name": "FCCN-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 600,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/2/7.22",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-par-fr-owamp new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 722337,
+        "name": "PS-PAR-FR-OWAMP-NEW",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 921,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "ae2",
+    "bundle": [
+      "et-4/0/0"
+    ],
+    "bundle-parents": [
+      "et-4/0/0"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-50061 | BUC-BUC",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 630,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUC",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUC",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae26",
+    "bundle": [
+      "xe-11/2/7"
+    ],
+    "bundle-parents": [
+      "xe-11/2/7"
+    ],
+    "description": "LAG CUSTOMER MICROSOFT EXPRESSROUTE #1 FOR NORDUNET SRF19135 $GA-01946 | GEANT-FRA32-09XGMR-CIS-1-PRI-12062019",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1198,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-2/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 729,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae14",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01702 | LON2-SEC-ESX20 VM Traffic LAG - No LACP",
+    "circuits": [
+      {
+        "id": 658686,
+        "name": "LON2-SEC-ESX20-VM-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 602,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 $GA-01826 |mx1-sw2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 685,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae18.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/0/0",
+      "xe-0/0/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS | SPLUNK AMS PEER01 MGMT | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 969,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae4 | BIL-PAR | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 677,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "et-4/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE3 | LIS-POR | Infinera GRV1 1/1/4 Facing PORTO",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 683,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-POR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-POR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 518,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae10.3260",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-5/0/2",
+      "et-9/0/5",
+      "et-11/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC NEA3R #lon-lon-GEANTOpen-JISC-NEA3R $GS-02399 |",
+    "circuits": [
+      {
+        "id": 732707,
+        "name": "LON-LON-GEANTOPEN-JISC-NEA3R",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1166,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NEA3R",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "et-5/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE4 | LIS-MAD | 200G",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 773,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.5",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01151 $GS-01151",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 588,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-10/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE APPLE-2 P_AE45 | ASN714",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 662,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 751,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 560,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-0/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | 10G-LR | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 591,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae1.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/4",
+      "xe-3/0/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN_MANAGEMENT | ",
+    "circuits": [
+      {
+        "id": 734049,
+        "name": "DCN_MANAGEMENT_PRA2",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 947,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-21.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1",
+      "1/x1/1/c26/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER ULAKBIM #ULAKBIM-AP1 $GS-00517 | ASN8517 | ",
+    "circuits": [
+      {
+        "id": 745292,
+        "name": "ULAKBIM-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "10",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ULAKBIM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ULAKBIM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae30.3005",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/2",
+      "xe-5/0/3",
+      "xe-7/0/2",
+      "xe-7/0/3"
+    ],
+    "description": "SRV_VPLS INFRASTRUCTURE RARE P4 #RARE-Gateway $GS-00770 | pfSense Gateway for RARE P4 Box VPLS",
+    "circuits": [
+      {
+        "id": 733914,
+        "name": "RARE-GATEWAY",
+        "type": "L2SERVICES",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1133,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | VIE-VIE | to RT0.VIE 1/1/c12/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 914,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "VIE-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "VIE-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae13",
+    "bundle": [
+      "et-1/0/2",
+      "et-10/0/2"
+    ],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-10/0/2"
+    ],
+    "description": "LAG CUSTOMER SWITCH SRF9925393 $GA-01817 | SWITCH AP2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 684,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT GEANT #bud-fra-RARE-P4-9951387 $GS-00684 | RARE P4 TESTBED",
+    "circuits": [
+      {
+        "id": 708177,
+        "name": "BUD-FRA-RARE-P4-9951387",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1443,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.2705",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV-L2CIRCUIT CUSTOMER PIONIER KIFU #PSNC-KIFU-SLICES-SZTAKI $GS-02491|",
+    "circuits": [
+      {
+        "id": 738292,
+        "name": "PSNC-KIFU-SLICES-SZTAKI",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 627,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BIL-PAR-IPTRUNK $GS-00016 | BIL-PAR | BIL-PAR",
+    "circuits": [
+      {
+        "id": 739468,
+        "name": "BIL-PAR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae16",
+    "bundle": [
+      "et-11/3/0"
+    ],
+    "bundle-parents": [
+      "et-11/3/0"
+    ],
+    "description": "LAG PRIVATE FACEBOOK $GA-01863 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 696,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-5/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CERN LHCONE P_AE10 SRF22071 | B513-B513 link (FR4)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1212,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae18",
+    "bundle": [
+      "xe-0/0/0",
+      "xe-0/0/1"
+    ],
+    "bundle-parents": [
+      "xe-0/0/0",
+      "xe-0/0/1"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | splunk-ams-peer01-peer01.geant.org | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 962,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "et-4/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | 100G LR4 CFP INSTALLED",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1010,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34",
+    "bundle": [
+      "et-1/1/5"
+    ],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "LAG CUSTOMER NETHERLIGHT $GA-01593  |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1546,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 619,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM CenturyLink SRF19096 $GA-01651 |EAP AZSCIENCENET GWS | CL ID: 441303554 ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 904,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "CENTURYLINK - FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CENTURYLINK - FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "et-2/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CESNET P_AE11 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 896,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-2/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 632,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02190 |SCION server 2 external port",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1308,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.991",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-LON $GS-00119 |",
+    "circuits": [
+      {
+        "id": 745871,
+        "name": "DCN-MANAGEMENT-LON",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 775,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "xe-3/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 656,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COGENT P_AE19 | Cogent ID: 1-300398288",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 926,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COGENT - BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT - BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.7",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEIMEC-02092 $GS-02092",
+    "circuits": [
+      {
+        "id": 744142,
+        "name": "MSEIMEC-02092",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1391,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-3/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | 100GB LR4 CFP2 INSTALLED",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 689,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-ams-nl $GS-00147 | SW3-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 736107,
+        "name": "EX3400-MANAGEMENT-AMS-NL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1022,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "irb.999",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS INFINERA #infinera-gen-ch-mgmt-vrf-vlan999 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 678,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-20.111",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c18/2",
+      "1/x1/1/c24/1",
+      "1/x1/1/c24/2"
+    ],
+    "description": "SRV_L3VPN CUSTOMER ARNES #ARNES-AP2-LHCONE $GS-00808 | ASN2107 | ",
+    "circuits": [
+      {
+        "id": 747853,
+        "name": "ARNES-AP2-LHCONE",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "11",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/3/2.401",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER UBUNTUNET CANARIE #lon-lon-MISC-UBUNTUNET-CANARIE-170351 $GS-00727 |",
+    "circuits": [
+      {
+        "id": 709304,
+        "name": "LON-LON-MISC-UBUNTUNET-CANARIE-170351",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1565,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.buc.ro.geant.net",
+    "name": "lag-20.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_IAS CUSTOMER ROEDUNET #ROEDUNET-AP1-IAS IASPS $GS-00544 | ASN2614 | ",
+    "circuits": [
+      {
+        "id": 747922,
+        "name": "ROEDUNET-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "4",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ROEDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ROEDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae23.668",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_IAS PRIVATE EXOSCALE #CH-EXOSCALE-IAS $GS-00601 | ASN61098 |",
+    "circuits": [
+      {
+        "id": 717332,
+        "name": "CH-EXOSCALE-IAS",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 709,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "EXOSCALE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EXOSCALE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-7/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae3 | GEN-GEN | to RT0.GEN.CH 2/1/c19/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 836,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-GEN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-GEN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "et-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae2 | PRA-PRA | to RT0.PRA 2/1/C9/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 898,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | 10G-LR | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 590,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-par-fr $GS-00157 | SW1-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 733985,
+        "name": "EX3400-MANAGEMENT-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 739,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "2/x1/1/c6/1"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c6/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02422 | ATH2-THE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-THE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-THE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/4",
+      "1/x1/1/c4/1",
+      "1/x1/1/c4/2",
+      "1/x1/1/c4/3",
+      "1/x1/1/c4/4"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/4",
+      "1/x1/1/c4/1",
+      "1/x1/1/c4/2",
+      "1/x1/1/c4/3",
+      "1/x1/1/c4/4"
+    ],
+    "description": "LAG CUSTOMER GRNET | $GA-01794 | #GRNET-AP1 | GRNET-AP1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:3508",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET NORDUNET #BRU-HAM-02519 $GS-02519",
+    "circuits": [
+      {
+        "id": 747534,
+        "name": "BRU-HAM-02519",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-5/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE T-SYSTEMS 100G LL1 | CID: NL222534 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 986,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX1-CAM-TO-SWITCHCLUSTER-VME0 | - switch chassis 0 mgmt - primary",
+    "circuits": [
+      {
+        "id": 708237,
+        "name": "SRX1-CAM-TO-SWITCHCLUSTER-VME0",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 512,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-10/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PUBLIC DE-CIX P_AE14 | DXDB:PNI:11687 Equinix CID: 22321283 | p18 in odf3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1047,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-20:712",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER GRNET #SLCUTH-02489 $GS-02489|",
+    "circuits": [
+      {
+        "id": 745413,
+        "name": "SLCUTH-02489",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER MICROSOFT EXPRESSROUTE #2 SRF20047 | GEANT-EXR02-AMS21-SEC-06162020 | Digital Realty CID: NL144337-2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 563,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae22.2703",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-10/0/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION WACREN #fra-lon-SCION-WACREN $GS-02496 | ",
+    "circuits": [
+      {
+        "id": 737890,
+        "name": "FRA-LON-SCION-WACREN",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1482,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "et-7/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | NO QSFP OPTIC INSTALLED",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 895,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4064",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-MSER-ULB-ExpressRoute-VLAN4064 $GS-02364 | ",
+    "circuits": [
+      {
+        "id": 739666,
+        "name": "BELNET-MSER-ULB-EXPRESSROUTE-VLAN4064",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1658,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "2/x1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | COR-LON2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178498,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/3/6.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-bud-hu-owamp | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 724901,
+        "name": "PS-BUD-HU-OWAMP",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1177,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "xe-3/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE2 SRF0000001 | mx2-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 703,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.2015",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT REDCLARA #REDCLARA-PAR-LHCONE $GS-00847 | ASN27750",
+    "circuits": [
+      {
+        "id": 661556,
+        "name": "REDCLARA-PAR-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 624,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "2/x1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | KAU-RIG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178497,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-RIG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-RIG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.505",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #ASREN-EDGE-DEVICE-VLAN505|ASREN edge-device-SSH CONTACT: matthew.dunn@geant.org IMPLEMENTED: 20190807",
+    "circuits": [
+      {
+        "id": 740505,
+        "name": "ASREN-EDGE-DEVICE-VLAN505",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 888,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae10.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/1/4"
+    ],
+    "description": "SRV_L3VPN CUSTOMER CERN #CERN-GEN-LHCONE $GS-00811 | ASN513",
+    "circuits": [
+      {
+        "id": 663086,
+        "name": "CERN-GEN-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 798,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 531,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 562,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02195 |SCION server 1 internal port",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1267,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-3/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 693,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae17",
+    "bundle": [
+      "et-1/0/2",
+      "et-1/1/2"
+    ],
+    "bundle-parents": [
+      "et-1/0/2",
+      "et-1/1/2"
+    ],
+    "description": "LAG CUSTOMER CERN SRF991519 $GA-01882 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 707,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CERN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CERN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 557,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-8/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE1 | AMS-AMS |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1269,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE1     | LON2-PRD-ESX01 NIC2 PORT1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 655,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER BASNET SRF9921827 $GA-01370 | BASNET-AP-LL",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 558,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BASNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BASNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae2.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-chi-md $GS-00150 | SW1-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 713271,
+        "name": "EX3400-MANAGEMENT-CHI-MD",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 551,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-lhc-mgmt-gen.ch.geant.org  pS MGMT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1293,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-7/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUD-BUD-IPTRUNK $GS-02596| BUD-BUD | BUD-BUD-MGMT",
+    "circuits": [
+      {
+        "id": 742924,
+        "name": "BUD-BUD-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 709,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-BUD",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-BUD",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae16.111",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/0/4",
+      "xe-0/1/7",
+      "xe-0/3/1"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT KIAE #NL-KIAE-LHCONE $GS-00836 | ASN57484 |",
+    "circuits": [
+      {
+        "id": 734247,
+        "name": "NL-KIAE-LHCONE",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1054,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "KIAE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIAE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "xe-0/1/1",
+      "xe-0/1/2"
+    ],
+    "bundle-parents": [
+      "xe-0/1/1",
+      "xe-0/1/2"
+    ],
+    "description": "LAG CUSTOMER URAN SRF21-056 $GA-02046 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 588,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "lag-5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #PRA-VIE-IPTRUNK $GS-00059 | PRA-VIE | ",
+    "circuits": [
+      {
+        "id": 740751,
+        "name": "PRA-VIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 3,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-VIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-VIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "irb.3001",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN INFRASTRUCTURE TAAS GTS #TAAS-CONTROL-FRANKFURT-VRF-VLAN3001-LOGICAL-INTERFACE $GS-00861 | NAGIOS gateway for taas-control VRF",
+    "circuits": [
+      {
+        "id": 733003,
+        "name": "TAAS-CONTROL-FRANKFURT-VRF-VLAN3001",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1236,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "lag-1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c19/1",
+      "2/1/c19/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #GEN-GEN-IPTRUNK $GS-02464 | GEN-GEN | RT0.GEN to MX1.GEN",
+    "circuits": [
+      {
+        "id": 739713,
+        "name": "GEN-GEN-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-GEN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-GEN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/3.902",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GEANT INTERNET2 #lon-lon-MISC-GEANT-INTERNET2-9940169 $GS-00725 |",
+    "circuits": [
+      {
+        "id": 678922,
+        "name": "LON-LON-MISC-GEANT-INTERNET2-9940169",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1024,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/18",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE14    | LON2-PRD-ESX20 NIC2 PORT2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 533,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-AMS-IPTRUNK-2 $GS-00007 | AMS-AMS IP TRUNK",
+    "circuits": [
+      {
+        "id": 735976,
+        "name": "AMS-AMS-IPTRUNK-2",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1624,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS IP TRUNK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS IP TRUNK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "xe-0/0/2:0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 535,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-3/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER SURF P_AE15 | Connected to SURF Asd001b-jnx-06 et-1/5/2 (port id:22557387)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 727,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-20.33",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "SRV_IAS CUSTOMER LAT #LAT-AP2-IAS IASPS $GS-00578 | ASN5538 | ",
+    "circuits": [
+      {
+        "id": 746531,
+        "name": "LAT-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "5",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COLT | P_AE29 Interxion CID: DE201856 | COLT ID: 444032094",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 874,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COLT - FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COLT - FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae11.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-2/1/5"
+    ],
+    "description": "SRV_IAS CUSTOMER CESNET #CESNET-AP1-IAS IASPS $GS-00563 | ASN2852",
+    "circuits": [
+      {
+        "id": 661262,
+        "name": "CESNET-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 935,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "et-7/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 892,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.600",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS FLOWMON | FlowMon1 Collector Interface CONTACT: evangelos.spatharas@geant.org IMPLEMENTED 20160816",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 891,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "ae4.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-BRA2-SK | DCN MANAGEMENT ",
+    "circuits": [
+      {
+        "id": 731653,
+        "name": "DCN-MANAGEMENT-BRA2-SK",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 610,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #AMS-AMS-IPTRUNK-2 $GS-00007 | ams-ams trunk",
+    "circuits": [
+      {
+        "id": 735976,
+        "name": "AMS-AMS-IPTRUNK-2",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 583,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ams-ams trunk",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ams-ams trunk",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.23",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-par-fr-idrac |perfSONAR iDRAC",
+    "circuits": [
+      {
+        "id": 739105,
+        "name": "PS-PAR-FR-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1219,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-6 | COR-LON2 | TO RT2.COR.IE-et-0/0/0",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-LON2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-LON2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1344,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 $GA-02067|mx1-sw3 (ex3400)|",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 967,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE3 SRF0000001 | rt1-sw2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 663,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae13.989",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ESNET RENATER #gen-mar-ESNET-RENATER-24038 $GS-02504 |",
+    "circuits": [
+      {
+        "id": 738302,
+        "name": "GEN-MAR-ESNET-RENATER-24038",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1438,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | RARE EDGECORE WEDGE100BF-32X xe-2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1444,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 529,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/35",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik D Data Port 2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 736,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.11",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-NMO $GS-01085",
+    "circuits": [
+      {
+        "id": 732668,
+        "name": "GRE-MULTICAST-TUNNEL-NMO",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1214,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/47",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE31    | MX1.LON2.UK xe-4/0/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 687,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "2/x1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER BELNET P_lag-21",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611178114,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "ae1.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/8",
+      "xe-5/0/9"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-BUC-RO | ",
+    "circuits": [
+      {
+        "id": 729934,
+        "name": "DCN-MANAGEMENT-BUC-RO",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 893,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae25",
+    "bundle": [
+      "xe-0/3/0"
+    ],
+    "bundle-parents": [
+      "xe-0/3/0"
+    ],
+    "description": "LAG CUSTOMER NIKS $GA-02143 | #NL-NIKS-LAG |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1329,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "NIKS",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "NIKS",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "irb.3003",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-throughput-network-fra-de $GS-00299 | Perfsonar test VMs - throughput measurement VLAN",
+    "circuits": [
+      {
+        "id": 733021,
+        "name": "PS-THROUGHPUT-NETWORK-FRA-DE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1232,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENATER SRF9924903 $GA-01385 | RENATER Project Circuits ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1274,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-1/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER_GEO AARNET #AARNET-GEO-UK-1 $GA-01480 |  SRF20044|",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1055,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "AARNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AARNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/0/6.12",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER WP6T3 WP6T3 #LON2-PRA-WP6-GTS-20064 $GS-00718 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 794,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "1/x1/1/c8/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c8/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02384 | COR-DUB",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-DUB",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-DUB",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.360",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #RARE-BMS-Server-IDRAC",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1342,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/1/5.105",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ASNET-TW #NL-ASNET-TW $GS-00888 | ASN9264 |",
+    "circuits": [
+      {
+        "id": 742821,
+        "name": "NL-ASNET-TW",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1704,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ASNET-TW",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASNET-TW",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "et-1/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 941,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.par.fr.geant.net",
+    "name": "1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | COR-PAR | TO RT2.COR.IE - et-0/0/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900033,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.gen.ch.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1",
+      "2/1/c9/2"
+    ],
+    "bundle-parents": [
+      "2/1/c8/1",
+      "2/1/c8/2",
+      "2/1/c9/1",
+      "2/1/c9/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01878 | GEN-MAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_IAS CUSTOMER RENATER #RENATER-AP1-IAS IASPS $GS-00583 | ASN2200",
+    "circuits": [
+      {
+        "id": 661239,
+        "name": "RENATER-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 587,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.350",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #FLOWMON-PAR-FR-MANAGEMENT | FlowMon1 Management + FanOut CONTACT: evangelos.spatharas@geant.org",
+    "circuits": [
+      {
+        "id": 739100,
+        "name": "FLOWMON-PAR-FR-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1358,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "lag-8.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c9/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BRA-VIE-IPTRUNK $GS-00019 | BRA-VIE | ",
+    "circuits": [
+      {
+        "id": 740792,
+        "name": "BRA-VIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 6,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-VIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-VIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | NEW Uplink for ae1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1583,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ge-1/0/38",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | LON2-PRD-ESX12 IDRAC",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 692,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/2/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-poz-pl-owamp new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 727551,
+        "name": "PS-POZ-PL-OWAMP",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 830,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae10.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2"
+    ],
+    "description": "SRV_IAS CUSTOMER FCCN #FCCN-AP2-IAS IASGWS $GS-00528 | ASN1930",
+    "circuits": [
+      {
+        "id": 712361,
+        "name": "FCCN-AP2-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 607,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "1/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915971,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.1007",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT CSTNET #UK-CAE-1-CSTNET-SECONDARY $GS-02391 | ASN7497 | ",
+    "circuits": [
+      {
+        "id": 732232,
+        "name": "UK-CAE-1-CSTNET-SECONDARY",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1348,
+    "dashboards": [
+      "CAE1",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CSTNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CSTNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae27.4001",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/2"
+    ],
+    "description": "SRV_IAS PRIVATE T-SYSTEMS #NL-T-SYSTEMS-IAS $GS-02271 | ASN6878 |",
+    "circuits": [
+      {
+        "id": 734863,
+        "name": "NL-T-SYSTEMS-IAS",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1318,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "T-SYSTEMS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "T-SYSTEMS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | RARE EDGECORE WEDGE100BF-32X xe-1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1443,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.29",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #AMS-SPLUNK-SERVER2-iDRAC",
+    "circuits": [
+      {
+        "id": 736106,
+        "name": "AMS-SPLUNK-SERVER2-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1019,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae32",
+    "bundle": [
+      "xe-11/0/2",
+      "xe-11/2/3"
+    ],
+    "bundle-parents": [
+      "xe-11/0/2",
+      "xe-11/2/3"
+    ],
+    "description": "LAG UPSTREAM COGENT $GA-01939 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1027,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-20:714",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER GRNET REDIRIS #SLCUTH-02499 $GS-02499|",
+    "circuits": [
+      {
+        "id": 745434,
+        "name": "SLCUTH-02499",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c8/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #COR-DUB-IPTRUNK $GS-02383 | COR-DUB | ",
+    "circuits": [
+      {
+        "id": 747279,
+        "name": "COR-DUB-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 7,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-DUB",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-DUB",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.820",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT NKN #NL-NKN $GS-00899 | ASN9885 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1737,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "NKN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NKN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae22.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER IUCC #IUCC-AP2 $GS-00478 | ASN378 |",
+    "circuits": [
+      {
+        "id": 729999,
+        "name": "IUCC-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 986,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "IUCC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "IUCC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/41",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE30    | 10_GBS to MX1.LON2.UK xe-2/2/6",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 681,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 576,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 521,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE IT_INFRA | to QFX xe-1/0/0",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 676,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ge-0/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 613,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae24.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/2/4"
+    ],
+    "description": "SRV_IAS PRIVATE EXOSCALE #DE-EXOSCALE-IAS $GS-00604 | ASN61098 |",
+    "circuits": [
+      {
+        "id": 731914,
+        "name": "DE-EXOSCALE-IAS",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1038,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "EXOSCALE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EXOSCALE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 553,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.28",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEONDD-02389 $GS-02389",
+    "circuits": [
+      {
+        "id": 744236,
+        "name": "MSEONDD-02389",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1410,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/0/0.200",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT CNGI-6IX #UK-CNGI-6IX-CERNET $GS-00925 | ASN23911 |",
+    "circuits": [
+      {
+        "id": 661591,
+        "name": "UK-CNGI-6IX-CERNET",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1066,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CNGI-6IX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CNGI-6IX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Was IUCC:  GNT-E10-004",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 550,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae20.3020",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-5/1/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER SINET SINET #AMS-LON-SINET-SD-WAN-SINET-SINET-17084 $GS-00648 |",
+    "circuits": [
+      {
+        "id": 740717,
+        "name": "AMS-LON-SINET-SD-WAN-SINET-SINET-17084",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1291,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.19",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS Customer BELNET MICROSOFT #BELNET-STAD-EXPRESSROUTE-VLAN4061 $GS-02246  | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739667,
+        "name": "BELNET-STAD-EXPRESSROUTE-VLAN4060",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 665,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.250",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #VM-AMS-NL-IDRACS-250 | NEW VM IDRACS",
+    "circuits": [
+      {
+        "id": 736097,
+        "name": "VM-AMS-NL-IDRACS-250",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1517,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-1/0/17",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE                         | SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 649,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/7.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-par-fr-owamp new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 734060,
+        "name": "PS-PAR-FR-OWAMP",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 819,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-5/0/8",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_ae1 SRF0000001 | rt1-sw2 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 682,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.240",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET TENET #lon-lon-GEANTOPEN-NORDUNET-TENET-18075 $GS-00978 |",
+    "circuits": [
+      {
+        "id": 718107,
+        "name": "LON-LON-GEANTOPEN-NORDUNET-TENET-18075",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 943,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "et-1/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER BELNET SRF19118 P_AE28| BELNET AP2 |Connected to GRV5 1/1/3| ASN2611",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1567,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "et-1/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae7 | BUC-BUD",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 613,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "1/1/c11/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-7 | POZ-PRA | to RT0.POZ 2/1/c8/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900162,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/2/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | DDOS Mitigation Server link 2 Node 2 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1296,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1 | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915969,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae14.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/1/2"
+    ],
+    "description": "SRV_IAS PRIVATE FACEBOOK #FACEBOOK-32934-VIE-FC-203126784 $GS-00929 | ASN32934",
+    "circuits": [
+      {
+        "id": 738664,
+        "name": "FACEBOOK-32934-VIE-FC-203126784",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 853,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "FACEBOOK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FACEBOOK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/5.2110",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER INTERNET2 HBKU #lon-par-GEANTOPEN-INTERNET2-HBKU-190092 $GS-00985 |",
+    "circuits": [
+      {
+        "id": 709340,
+        "name": "LON-PAR-GEANTOPEN-INTERNET2-HBKU-190092",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1527,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "HBKU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-1/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENATER P_AE12 | RENATER-AP1-2 | DR Circuit ID: FR226645",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1151,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.the.gr.geant.net",
+    "name": "lag-5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c6/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MIL2-THE-IPTRUNK $GS-02609 | MIL2-THE | MIL2-THE",
+    "circuits": [
+      {
+        "id": 745270,
+        "name": "MIL2-THE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 5,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-THE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-THE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.1237",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER KREONET RARE #AMS-AMS-KREONET-RARE-22097 $GS-02218 | ",
+    "circuits": [
+      {
+        "id": 736100,
+        "name": "AMS-AMS-KREONET-RARE-22097",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1536,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "KREONET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "KREONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae17.100",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/6"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT UBUNTUNET #NL-UBUNTUNET $GS-00902 | ASN36944 |",
+    "circuits": [
+      {
+        "id": 735726,
+        "name": "NL-UBUNTUNET",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1344,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-20.83",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER LAT #LAT-AP2 $GS-00485 | ASN5538 | ",
+    "circuits": [
+      {
+        "id": 746529,
+        "name": "LAT-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "4",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae12.3242",
+    "bundle": [],
+    "bundle-parents": [
+      "et-4/1/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT HARNET #FR-HARNET $GS-02538 | ASN137207 |",
+    "circuits": [
+      {
+        "id": 742536,
+        "name": "FR-HARNET",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 857,
+    "dashboards": [
+      "IC1",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "HARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-11/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS DTN $GA-01465 | 100G testing",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1654,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER URAN SRF-21-059 P_AE10 | URAN Circuit ID: GEANT-KIV-IEV-2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 567,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "URAN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "URAN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-0/0/0"
+    ],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02048 | CHI-KIE |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 587,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-KIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-KIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.buc.ro.geant.net",
+    "name": "lag-20.111",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_L3VPN CUSTOMER ROEDUNET #ROEDUNET-AP1-LHCONE $GS-00857 | ASN2614 | ",
+    "circuits": [
+      {
+        "id": 747923,
+        "name": "ROEDUNET-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "5",
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "ROEDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ROEDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c13/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #LON2-PAR-ROLR-IPTRUNK $GS-50066 | LON2-PAR | ",
+    "circuits": [
+      {
+        "id": 746141,
+        "name": "LON2-PAR-ROLR-IPTRUNK$GS-50066",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 8,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "2/x1/1/c8/1",
+      "2/x1/1/c8/2"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c8/1",
+      "2/x1/1/c8/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01909 | BUD-ZAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUD-ZAG",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUD-ZAG",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.13",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEICT-01133 $GS-01133",
+    "circuits": [
+      {
+        "id": 744148,
+        "name": "MSEICT-01133",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1397,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.1103",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER SURF #SURF-AP1 $GS-00512 | ASN1103 |",
+    "circuits": [
+      {
+        "id": 734591,
+        "name": "SURF-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1118,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-1/0/17",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae13    | 10_GBS to RT1.FRA.DE xe-5/0/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 635,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01673 | FRA-PRD-ESX01 ESXI Traffic LAG",
+    "circuits": [
+      {
+        "id": 658529,
+        "name": "FRANKFURT 15-FRANKFURT 15-LAG-050(GEANT)",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 574,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae45.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/5"
+    ],
+    "description": "SRV_IAS PRIVATE APPLE #FR-APPLE-IAS $GS-02397 | ASN714 |",
+    "circuits": [
+      {
+        "id": 730369,
+        "name": "FR-APPLE-IAS",
+        "type": "IP PEERING - NON R&E (PRIVATE)",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 705,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PRIVATE"
+    ],
+    "dashboard_info": {
+      "name": "APPLE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "APPLE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae11",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01699 | LON2-PRD-ESX01 VM Traffic LAG",
+    "circuits": [
+      {
+        "id": 658519,
+        "name": "LON2-PRD-ESX01-VM-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 599,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.por.pt.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c9/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #POR-POR-IPTRUNK $GS-02587 | POR-POR | POR-POR",
+    "circuits": [
+      {
+        "id": 742668,
+        "name": "POR-POR-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POR-POR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POR-POR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 923,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae12.160",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2",
+      "et-1/1/5",
+      "et-3/1/0",
+      "et-3/1/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER RENATER #RENATER-AP1 $GS-00505 | ASN2200 |",
+    "circuits": [
+      {
+        "id": 661272,
+        "name": "RENATER-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 763,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT SINGAREN SRF9941158 $GA-01464 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1585,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINGAREN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINGAREN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | NEMO DDOS SERVER link 2 Node 1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1285,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/3/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #fra-ams-IT_INFRA-QFX-GEANT $GS-02555 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1679,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "1/x1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RESTENA P_lag-22",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916417,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RESTENA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.201",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE REDIRIS #fra-mad-RARE-REDIRIS-23017-VL201 $GS-02274",
+    "circuits": [
+      {
+        "id": 732759,
+        "name": "FRA-MAD-RARE-REDIRIS-23017-VL201",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 642,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "1/1/c2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899585,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.20",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEARTEV-01131 $GS-01131",
+    "circuits": [
+      {
+        "id": 744265,
+        "name": "MSEARTEV-01131",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1403,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ge-0/3/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 603,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.105",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #SPLUNK-FRA-DE | Splunk1 CONTACT: evangelos.spatharas@geant.org IMPLEMENTED 20160917",
+    "circuits": [
+      {
+        "id": 729099,
+        "name": "SPLUNK-FRA-DE",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 971,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-21:3911",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER MICROSOFT NORDUNET #AMS-HAM-MSE-01150 $GS-01150",
+    "circuits": [
+      {
+        "id": 747632,
+        "name": "AMS-HAM-MSE-01150",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "MICROSOFT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.3507",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT INFRASTRUCTURE RARE P4 #RARE-00774 $GS-00774 |",
+    "circuits": [
+      {
+        "id": 747031,
+        "name": "RARE-00774",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 601,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-3/0/0",
+      "xe-3/0/1"
+    ],
+    "bundle-parents": [
+      "xe-3/0/0",
+      "xe-3/0/1"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 $GA-02027 | rt1-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 576,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "xe-0/0/2:1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 533,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.kie.ua.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-0/0/0"
+    ],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02026 | KIE-POZ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 581,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-POZ",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-POZ",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/0/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | LON2-PAR-QFX | to QFX xe-0/0/42",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1568,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-uat-mgmt-fra.de.geant.org  pS MGMT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1297,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae1.24",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/1/7",
+      "xe-2/2/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #old-ps-gen-ch-management | OLD perfSONAR MGMT LHCONE",
+    "circuits": [
+      {
+        "id": 740082,
+        "name": "OLD-PS-GEN-CH-MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1475,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/0/7.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-lhc-gen-ch-bwctl LHC new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 723644,
+        "name": "PS-LHC-GEN-CH-BWCTL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1319,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae1.520",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/0",
+      "xe-1/2/4"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #snm-idrac-mgmt $GS-00151 | IT Refresh iDRAC MGMT",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 841,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:1175",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER BELNET SCION #FED4FIRE-00671 $GS-00671",
+    "circuits": [
+      {
+        "id": 745340,
+        "name": "FED4FIRE-00671",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 587,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE NON-OPERATIONAL",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 595,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/3.1620",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER SCION INTERNET2 #par-par-SCION-INTERNET2-SCION-1 $GS-02295 |",
+    "circuits": [
+      {
+        "id": 736658,
+        "name": "PAR-PAR-SCION-INTERNET2-SCION-1",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1253,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "SCION",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "SCION",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae1.500",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/1/7"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER CESNET #pra-vie-CESNET-AP1-CESNET-AP2 $GS-02344 |",
+    "circuits": [
+      {
+        "id": 728645,
+        "name": "PRA-VIE-CESNET-AP1-CESNET-AP2",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 678,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-10/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER SURF P_AE11 | 200GB AP2 2_2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 914,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-0/0/41",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE30    | 10_GBS to MX1.LON2.UK xe-2/0/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 541,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.13",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-ECMWF $GS-01076",
+    "circuits": [
+      {
+        "id": 732667,
+        "name": "GRE-MULTICAST-TUNNEL-ECMWF",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1216,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "lag-4.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c5/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #MIL2-VIE-IPTRUNK $GS-00057 | MIL2-VIE | ",
+    "circuits": [
+      {
+        "id": 740950,
+        "name": "MIL2-VIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MIL2-VIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MIL2-VIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-3/0/0",
+      "xe-3/0/1"
+    ],
+    "bundle-parents": [
+      "xe-3/0/0",
+      "xe-3/0/1"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 $GA-02070 |rt1-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 514,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/2/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1054,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-2/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SUPERPOP | LON2-FRA-QFX | to QFX-2 xe-1/0/41",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1586,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.34",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NETHERLIGHT SWITCH #AMS-GEN-SCION-NETHERLIGHT-SWITCH-20018 $GS-00639 |",
+    "circuits": [
+      {
+        "id": 734612,
+        "name": "AMS-GEN-SCION-NETHERLIGHT-SWITCH-20018",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1111,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NETHERLIGHT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-1",
+    "bundle": [
+      "1/x1/1/c2/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02617 | COR-COR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177281,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "COR-COR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "COR-COR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "et-0/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE2 | BIL-POR | Infinera POR01-GRV2 1/1/4 facing Bilbao",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 555,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BIL-POR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BIL-POR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-0/0/41",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE13    | 10_GBS to MX1.PAR.FR xe-4/1/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 543,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "xe-0/0/28",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae0     | RT1 xe-7/0/3",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 647,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae18.53",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER ACONET #ACONET-AP2 $GS-00423 | ASN1853 |",
+    "circuits": [
+      {
+        "id": 661508,
+        "name": "ACONET-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 805,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ACONET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ACONET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-0/0/5",
+      "et-0/1/2"
+    ],
+    "bundle-parents": [
+      "et-0/0/5",
+      "et-0/1/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02029 | LIS-POR |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 578,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-POR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-POR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.521",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #snm-switch-mgmt | IT Refresh QFX MGMT",
+    "circuits": [
+      {
+        "id": 736102,
+        "name": "SNM-SWITCH-MGMT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1613,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "xe-3/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P4",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 533,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | GEN-MIL2 | to RT0.GEN.CH 1/1/c9/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900033,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MIL2",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MIL2",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.chi.md.geant.net",
+    "name": "ae10.110",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/1"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENAM ARELION #bud-chi-EAP-RENAM-ARELION-24033 $GS-02110 | ",
+    "circuits": [
+      {
+        "id": 738245,
+        "name": "BUD-CHI-EAP-RENAM-ARELION-24033",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 564,
+    "dashboards": [
+      "EAP",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "et-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae6 | BRA-BUD",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 594,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.8",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #NORDUNET-AALTO-ExpressRoute-VLAN3906 $GS-01155 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 706994,
+        "name": "NORDUNET-AALTO-EXPRESSROUTE-VLAN3906",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1392,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/0/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER GEANT-IT #fra-lon2-SUPERPOP-QFX-2-GEANT $GS-00077 |",
+    "circuits": [
+      {
+        "id": 729418,
+        "name": "FRA-LON2-SUPERPOP-QFX-2-GEANT",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1072,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "GEANT-IT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT-IT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "gr-4/0/0.1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L3VPN INFRASTRUCTURE ACCESS #TUNNEL-FORTIGATE-AMSTERDAM $GS-01113| TUNNEL TO FORTIGATE AM",
+    "circuits": [
+      {
+        "id": 736088,
+        "name": "TUNNEL-FORTIGATE-AMSTERDAM",
+        "type": "L3-VPN",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1522,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.930",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDIRIS JISC #LON-MAD-GOTO-REDIRIS-JISC-16018 $GS-00734 |",
+    "circuits": [
+      {
+        "id": 719523,
+        "name": "LON-MAD-GOTO-REDIRIS-JISC-16018",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1083,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.350",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #RARE-BMS-Server-IDRAC",
+    "circuits": [
+      {
+        "id": 736781,
+        "name": "RARE-BMS-SERVER-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1649,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/12",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 528,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1341,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.666",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_L3VPN CUSTOMER SURF #SURF-AP1-LHCONE-2 $GS-00793 | ASN1103 |",
+    "circuits": [
+      {
+        "id": 734592,
+        "name": "SURF-AP1-LHCONE-2",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1115,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/2/0.100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS DTN-PROJECT #DTN-PAR-10G-DATA $GS-02375 | 10G Testing CONTACT: Richard.Hughes-Jones@geant.org",
+    "circuits": [
+      {
+        "id": 678071,
+        "name": "DTN-PAR-10G-DATA",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 983,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC BOD SRF9925119 $GA-01454 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1463,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-1/0/42",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE14    | 10_GBS to MX1.PAR.FR xe-11/2/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 657,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.54",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS GEANT IT #DataDomain-01-IDRAC PORT |",
+    "circuits": [
+      {
+        "id": 745867,
+        "name": "DATADOMAIN-01-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 700,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae35",
+    "bundle": [
+      "et-2/1/2"
+    ],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "LAG PRIVATE CLOUDFERRO SRF19094 $GA-01966 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1030,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae1 | MAD-MAD | to RT0.MAD 1/x1/1/c2/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 778,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "ae3",
+    "bundle": [
+      "et-0/0/5",
+      "et-0/1/5"
+    ],
+    "bundle-parents": [
+      "et-0/0/5",
+      "et-0/1/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01935 | BUC-SOF",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 670,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-SOF",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-SOF",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-20.33",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_IAS CUSTOMER LAT #LAT-AP1-IAS IASPS $GS-00577 | ASN5538 | ",
+    "circuits": [
+      {
+        "id": 745986,
+        "name": "LAT-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "7",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "LAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "et-5/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | No Optic",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 850,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-23",
+    "bundle": [
+      "2/x1/1/c2/3"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c2/3"
+    ],
+    "description": "LAG CUSTOMER CYNET | $GA-01640 | #CYNET-GRIX | CYNET-GRIX",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1342177303,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CYNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CYNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae18.854",
+    "bundle": [],
+    "bundle-parents": [
+      "et-8/0/2"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER RESTENA RENATER #fra-par-MISC-RESTENA-RENATER-20030 $GS-00704 |",
+    "circuits": [
+      {
+        "id": 733000,
+        "name": "FRA-PAR-MISC-RESTENA-RENATER-20030",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1161,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RESTENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RESTENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "et-4/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER REDIRIS P_AE15 SRF23023",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 878,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.43",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEHOGENT-02573 $GS-02573",
+    "circuits": [
+      {
+        "id": 744239,
+        "name": "MSEHOGENT-02573",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1702,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae22.1",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-10/0/0"
+    ],
+    "description": "PHY CUSTOMER_GEO WACREN #WACREN-GEO-UK-1 |  SRF43753 P_AE22 | ID: SN-20858588|",
+    "circuits": [
+      {
+        "id": 719823,
+        "name": "WACREN-GEO-UK-1",
+        "type": "GEANT OPEN PORT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1170,
+    "dashboards": [
+      "GEANTOPEN"
+    ],
+    "dashboard_info": {
+      "name": "WACREN",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "WACREN",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae24",
+    "bundle": [
+      "xe-11/2/4"
+    ],
+    "bundle-parents": [
+      "xe-11/2/4"
+    ],
+    "description": "LAG PRIVATE EXOSCALE SRF9934309 $GA-01948 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1037,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae15",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01687 | FRA-PRD-ESX05 ESXI Traffic LAG",
+    "circuits": [
+      {
+        "id": 658662,
+        "name": "FRANKFURT 15-FRANKFURT 15-LAG-053(GEANT)",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 584,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.26",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ddos-det1-par-fr-idrac | NEMO DDOS Detection 1 iDRAC",
+    "circuits": [
+      {
+        "id": 739103,
+        "name": "DDOS-DET1-PAR-FR-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1221,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae1.27",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/0/1",
+      "xe-4/0/2",
+      "xe-4/0/7",
+      "xe-4/1/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ddos-det2-par-fr-idrac | NEMO DDOS Detection 2 iDRAC",
+    "circuits": [
+      {
+        "id": 739094,
+        "name": "DDOS-DET2-PAR-FR-IDRAC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1222,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RARE EDGECORE WEDGE100BF-32X xe-0",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1260,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae15.668",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/1/5"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT REDCLARA #REDCLARA-MAD-COPERNICUS $GS-00850 | ASN27750",
+    "circuits": [
+      {
+        "id": 713845,
+        "name": "REDCLARA-MAD-COPERNICUS",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 821,
+    "dashboards": [
+      "COPERNICUS",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/3/2.801",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER UBUNTUNET INTERNET2 #lon-lon-MISC-UBUNTUNET-INTERNET2-170341 $GS-00729 |",
+    "circuits": [
+      {
+        "id": 709301,
+        "name": "LON-LON-MISC-UBUNTUNET-INTERNET2-170341",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1566,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "UBUNTUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CANARIE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "UBUNTUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ge-0/2/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 597,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-10/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 903,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21",
+    "bundle": [
+      "xe-0/1/3"
+    ],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "LAG CUSTOMER MICROSOFT EXPRESSROUTE #1 SRF20047 $GA-01911 |GEANT-EXR01-AMS21-PRI-06162020",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1385,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.3",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER REDIRIS MICROSOFT #REDIRIS-UCLM-ExpressRoute-VLAN412 $GS-01164 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707138,
+        "name": "REDIRIS-UCLM-EXPRESSROUTE-VLAN412",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 586,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-7/1/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 826,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1046,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 575,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "ae12",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01700 | LON2-PRD-ESX02 VM Traffic LAG",
+    "circuits": [
+      {
+        "id": 658523,
+        "name": "LON2-PRD-ESX02-VM-TRAFFIC",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 600,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "1/1/c13/1"
+    ],
+    "bundle-parents": [
+      "1/1/c13/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-50067 | LON2-PAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "et-0/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE3 | CHI-KIE | RETN CID: OC-904687-3.MD.CSN.TRB-UA.KIV.KPI-50GHZ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 617,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-KIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-KIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/0/5.3912",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER NORDUNET MICROSOFT #Nordunet-TUNI-ExpressRoute-Vlan3912 $GS-01162 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707047,
+        "name": "NORDUNET-TUNI-EXPRESSROUTE-VLAN3912",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1205,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-4/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 993,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11.142",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER REDCLARA #gen-lis-SCION-REDCLARA $GS-02436 |",
+    "circuits": [
+      {
+        "id": 732905,
+        "name": "GEN-LIS-SCION-REDCLARA",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 678,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/7.3004",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC NETHERLIGHT #AMS-LON-EXPRES-NETHERLIGHT-JISC-18009 $GS-00644 |",
+    "circuits": [
+      {
+        "id": 734615,
+        "name": "AMS-LON-EXPRES-NETHERLIGHT-JISC-18009",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1507,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "NETHERLIGHT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bra.sk.geant.net",
+    "name": "lag-2",
+    "bundle": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02601 | BRA-BRA",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177282,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae17",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01689 | FRA-PRD-ESX05 VM Traffic LAG",
+    "circuits": [
+      {
+        "id": 658654,
+        "name": "FRANKFURT 15-FRANKFURT 15-LAG-051(GEANT)",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 585,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "2/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-5 | PRA-VIE | to MX1.VIE et-1/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162177,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-VIE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-VIE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.10",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER FCCN MICROSOFT #FCCN_IPP_ExpressRoute_Vlan1947 $GS-01141 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707124,
+        "name": "FCCN-IPP-EXPRESSROUTE-VLAN1947",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 593,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "FCCN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FCCN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | LR optic connected",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1311,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae17.200",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/3/4"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER ASNET-AM #ASNET-AM-AP1 $GS-00430 | ASN47623 |",
+    "circuits": [
+      {
+        "id": 732136,
+        "name": "ASNET-AM-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1169,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ASNET-AM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASNET-AM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "xe-2/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | BUC-CHI | ROEDUNET CID: BUC-CHI-040-1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 551,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 763,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae34.1303",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KREONET SWITCH #ams-par-SCION-KREONET-SWITCH $GS-02291 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 1741,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-8/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | DDOS Mitigation Server link 2 Node 1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 987,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.3102",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT AARNET #AARNET-LON-LHCONE $GS-00805 | ASN7575",
+    "circuits": [
+      {
+        "id": 661897,
+        "name": "AARNET-LON-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 682,
+    "dashboards": [
+      "CAE1",
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "AARNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AARNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/0.10",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_CORPORATE CUSTOMER GEANT_INTERNAL #SRX2-AMS-Infrastructure-Management |",
+    "circuits": [
+      {
+        "id": 663187,
+        "name": "SRX2-AMS-INFRASTRUCTURE-MANAGEMENT",
+        "type": "CORPORATE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 556,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-101.103",
+    "bundle": [],
+    "bundle-parents": [
+      "2/x1/1/c2/1",
+      "2/x1/1/c2/3"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-BRU-BE-VRF-VLAN103 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "5",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae10.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-5/0/2",
+      "et-9/0/5",
+      "et-11/1/5"
+    ],
+    "description": "SRV_IAS CUSTOMER JISC #JISC-AP1-IAS IASPS $GS-00574 | ASN786",
+    "circuits": [
+      {
+        "id": 661497,
+        "name": "JISC-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 781,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bra.sk.geant.net",
+    "name": "1/x1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | BRA-BRA-MGMT | to RT1.BRA XE-0/1/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915970,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-BRA-MGMT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-BRA-MGMT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-20.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/4",
+      "1/x1/1/c4/1",
+      "1/x1/1/c4/2",
+      "1/x1/1/c4/3",
+      "1/x1/1/c4/4"
+    ],
+    "description": "SRV_IAS CUSTOMER GRNET #GRNET-AP1-IAS IASGWS $GS-00530 | ASN5408 | ",
+    "circuits": [
+      {
+        "id": 745494,
+        "name": "GRNET-AP1-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "5",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae27",
+    "bundle": [
+      "et-5/0/2"
+    ],
+    "bundle-parents": [
+      "et-5/0/2"
+    ],
+    "description": "LAG PRIVATE T-SYSTEMS $GA-02270 | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1317,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-22:3015",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC #JISC-13015 $GS-00690",
+    "circuits": [
+      {
+        "id": 747357,
+        "name": "JISC-13015",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae23",
+    "bundle": [
+      "et-3/1/4"
+    ],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "LAG CUSTOMER SWITCH AP1 SRF19136 $GA-01880 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 713,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae26.3260",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC NEA3R #lon-lon-GEANTOpen-JISC-NEA3R $GS-02399 |",
+    "circuits": [
+      {
+        "id": 732707,
+        "name": "LON-LON-GEANTOPEN-JISC-NEA3R",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1183,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NEA3R",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/2/3.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR # psmp-lhc-bw-par-fr new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 720347,
+        "name": "PSMP-LHC-BW-PAR-FR",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 818,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/0/2.702",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE RARE #LON-AMS-DTN-GENERATOR $GS-00722 | RARE P4 TESTBED",
+    "circuits": [
+      {
+        "id": 736105,
+        "name": "LON-AMS-DTN-GENERATOR",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 986,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-22",
+    "bundle": [
+      "1/1/c27/1"
+    ],
+    "bundle-parents": [
+      "1/1/c27/1"
+    ],
+    "description": "LAG CUSTOMER PIONIER | $GA-01892 | PIONIER LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177302,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae7",
+    "bundle": [
+      "et-9/0/2",
+      "et-9/0/5"
+    ],
+    "bundle-parents": [
+      "et-9/0/2",
+      "et-9/0/5"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01906 | BUC-BUD",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 847,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-BUD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-BUD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "1/x1/1/c2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915971,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.2709",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER GRNET #SLCUTH-02490 $GS-02490|",
+    "circuits": [
+      {
+        "id": 745409,
+        "name": "SLCUTH-02490",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 614,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 900,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "xe-1/2/2.3015",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #INFOBLOX-LON2-MGMT | Infoblox NS01 MGMT",
+    "circuits": [
+      {
+        "id": 729163,
+        "name": "INFOBLOX-LON2-MGMT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 600,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-4/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1066,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.3220",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER SINGAREN #lon-poz-GEANTOpen-SINGAREN-CAE1-19113-VL3220-PIONIER $GS-00986 |",
+    "circuits": [
+      {
+        "id": 707007,
+        "name": "LON-POZ-GEANTOPEN-SINGAREN-CAE1-19113-VL3220-PIONIER",
+        "type": "GEANT OPEN CROSS CONNECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 678,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae15.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/1/4"
+    ],
+    "description": "SRV_IAS CUSTOMER SURF #SURF-AP1-IAS IASPS $GS-00587 | ASN1103 |",
+    "circuits": [
+      {
+        "id": 734590,
+        "name": "SURF-AP1-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1114,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "SURF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SURF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-11/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER ROEDUNET P_AE21 SRF20069 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 864,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ROEDUNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ROEDUNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "xe-3/0/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Patched to GEANT ODF P7",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 660,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.mil2.it.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "2/1/c9/1",
+      "2/1/c11/1",
+      "2/1/c11/2"
+    ],
+    "bundle-parents": [
+      "2/1/c9/1",
+      "2/1/c11/1",
+      "2/1/c11/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01775 | LJU-MIL2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-MIL2",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-MIL2",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.mad.es.geant.net",
+    "name": "1/x1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-1 | MAD-MAD | to MX1.MAD xe-7/0/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610915970,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 795,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "1/1/c2/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_lag-101 | rt0-sw1-1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899586,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-0/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE SCION SRF22066 $GA-02197 |SCION server 2 internal port",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1283,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 827,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae10.2803",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER KIFU #PSNC-KIFU-SLICES-SZTAKI $GS-02491|",
+    "circuits": [
+      {
+        "id": 738292,
+        "name": "PSNC-KIFU-SLICES-SZTAKI",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 869,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRO-M/NIIF",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-4/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | psmp-gn-bw-par-fr-bwctl.geant.org pS BWCTL",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1284,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae17.220",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/3/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER ASNET-AM ASNET-AM #fra-fra-EAP-ASNET-AM-CL-190891 $GS-00696 |",
+    "circuits": [
+      {
+        "id": 732138,
+        "name": "FRA-FRA-EAP-ASNET-AM-CL-190891",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1170,
+    "dashboards": [
+      "EAP",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "ASNET-AM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ASNET-AM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 639,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-101",
+    "bundle": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN | rt0-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177381,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.212",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT ESNET #FR-ESNET $GS-00878 | ASN293 | MANLAN ID: 212",
+    "circuits": [
+      {
+        "id": 661489,
+        "name": "FR-ESNET",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 871,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "ESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 666,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae1.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/1/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE Access  #DCN-MANAGEMENT-VIE-AT |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 715,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "et-5/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_ae6 | LIS-PAR | LIS-PAR 100G | COLT CID: 446504605 ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 800,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | HAM-POZ | to RT0.HAM.DE 2/1/c9/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610900033,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "Reserved for New EX | 10G-LR |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 589,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "irb.520",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #IDRAC-MGMT-LON2-UK-VRF-VLAN520 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 829,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae1.25",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/1/1",
+      "xe-5/1/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #psmp-gw-drac-bud-hu| perfSONAR iDRAC",
+    "circuits": [
+      {
+        "id": 739310,
+        "name": "PSMP-GW-DRAC-BUD-HU",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 894,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.408",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER RedIRIS Microsoft $GS-01165 | #RedIRIS-USC-ExpressRoute-Vlan408 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707129,
+        "name": "REDIRIS-USC-EXPRESSROUTE-VLAN408",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 832,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae20.420",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/0/3",
+      "xe-2/1/1"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER DFN NKN SRF22079 #FRA-GEN-DFN-NKN-22079 $GS-02210 |",
+    "circuits": [
+      {
+        "id": 724886,
+        "name": "FRA-GEN-DFN-NKN-22079",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 659,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "DFN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NKN",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "DFN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae33",
+    "bundle": [
+      "xe-4/2/6",
+      "xe-4/3/2"
+    ],
+    "bundle-parents": [
+      "xe-4/2/6",
+      "xe-4/3/2"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | NEMO DDOS Detection 1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 977,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-21.1",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c9/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER AMRES #AMRES-AP2 $GS-02240 | ASN13092 | ",
+    "circuits": [
+      {
+        "id": 744955,
+        "name": "AMRES-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "6",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "AMRES",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMRES",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae14",
+    "bundle": [
+      "et-5/1/5"
+    ],
+    "bundle-parents": [
+      "et-5/1/5"
+    ],
+    "description": "LAG CUSTOMER SWITCH $GA-01912 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1038,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SWITCH",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SWITCH",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "1/1/c8/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-6 | FRA-PRA | to RT0.FRA 1/1/C8/1",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899969,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ae11",
+    "bundle": [
+      "et-3/3/0"
+    ],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "LAG RE_INTERCONNECT BELLA SRF21059 $GA-02075 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 571,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "BELLA",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELLA",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/3/9",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | Was PSMP Server",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 652,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-7/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 825,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.am.office.geant.net",
+    "name": "ge-0/0/14",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 530,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae1.30",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-4/1/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ddos-mit1-vie-at-idrac | NEMO DDOS Mitigation 1 iDRAC | Primay.nemo",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 666,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "et-1/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | 100GB LR4 CFP2 INSTALLED",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 681,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #CHI-KIE-IPTRUNK $GS-00029 | CHI-KIE IP TRUNK",
+    "circuits": [
+      {
+        "id": 713101,
+        "name": "CHI-KIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 607,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "CHI-KIE IP TRUNK",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CHI-KIE IP TRUNK",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.bra.sk.geant.net",
+    "name": "ae13.420",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/0"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER SANET #SANET-AP1 $GS-00511 | ASN2607 |",
+    "circuits": [
+      {
+        "id": 719686,
+        "name": "SANET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 615,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "SANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae7.10",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #AMS-AMS-AMT-RELAYLINK $GS-02305 | ",
+    "circuits": [
+      {
+        "id": 744359,
+        "name": "AMS-AMS-AMT-RELAYLINK",
+        "type": "SERVER LINK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1709,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1338,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae1.106",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/2/3",
+      "xe-11/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS SUPERPOP #QFX-Management-Fra| QFX MANAGEMENT",
+    "circuits": [
+      {
+        "id": 729097,
+        "name": "QFX-MANAGEMENT-FRA",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 972,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-9/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE FACEBOOK P_AE14 | Digital Reality CID: AT227158 | FB ID: FC-203126784",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 570,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx2.ch.office.geant.net",
+    "name": "ge-0/0/13",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 529,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "irb.999",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS INFINERA #infinera-par-fr-mgmt-vrf-vlan999|",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 738,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4089",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-MOBILIT-ExpressRoute-VLAN4089 $GS-02170 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 739664,
+        "name": "BELNET-MOBILIT-EXPRESSROUTE-VLAN4089",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1673,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.102",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT INTERNET2 #FR-INTERNET2-2 $GS-00920 | ASN11537 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 576,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-2/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE GTS SRF0000001 | GTS link to Server 2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 579,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/2/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | New Leased Span Poznan-Vienna",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 567,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae1.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/0",
+      "xe-3/0/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN-MANAGEMENT-BIL-ES $GS-00116| ",
+    "circuits": [
+      {
+        "id": 709868,
+        "name": "DCN-MANAGEMENT-BIL-ES",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 521,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.111",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L3VPN CUSTOMER REDIRIS #REDIRIS-AP1-LHCONE $GS-00852 | ASN766",
+    "circuits": [
+      {
+        "id": 719492,
+        "name": "REDIRIS-AP1-LHCONE",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1060,
+    "dashboards": [
+      "LHCONE",
+      "LHCONE_CUST",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.24",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL RE_INTERCONNECT KANREN #GRE-MULTICAST-TUNNEL-KANREN $GS-02377 | ASN2495",
+    "circuits": [
+      {
+        "id": 732676,
+        "name": "GRE-MULTICAST-TUNNEL-KANREN",
+        "type": "IP PEERING - R&E",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1227,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "KANREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KANREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "ae5.103",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/0",
+      "xe-0/3/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE  Access  #DCN_MANAGEMENT | ",
+    "circuits": [
+      {
+        "id": 726154,
+        "name": "DCN_MANAGEMENT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 677,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28.4063",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #BELNET-JUST-ExpressRoute-VLAN4063 $GS-02319 | ",
+    "circuits": [
+      {
+        "id": 739662,
+        "name": "BELNET-JUST-EXPRESSROUTE-VLAN4063",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1657,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.fra.de.geant.net",
+    "name": "lag-5.0",
+    "bundle": [],
+    "bundle-parents": [
+      "2/1/c1/1",
+      "2/1/c5/1",
+      "2/1/c7/1",
+      "2/1/c10/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #FRA-GEN-IPTRUNK $GS-00034 | FRA-GEN | ",
+    "circuits": [
+      {
+        "id": 739737,
+        "name": "FRA-GEN-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 4,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "FRA-GEN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "FRA-GEN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae10.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2",
+      "et-2/1/5"
+    ],
+    "description": "SRV_IAS PUBLIC VIX #IX-Peerings-in-VIX $GS-00954 |",
+    "circuits": [
+      {
+        "id": 708175,
+        "name": "IX-PEERINGS-IN-VIX",
+        "type": "IP PEERING - NON R&E (PUBLIC)",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 661,
+    "dashboards": [
+      "IAS_PEERS",
+      "IAS_PUBLIC"
+    ],
+    "dashboard_info": {
+      "name": "VIX",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "VIX",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ge-0/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 608,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae47",
+    "bundle": [
+      "et-2/0/2"
+    ],
+    "bundle-parents": [
+      "et-2/0/2"
+    ],
+    "description": "LAG PRIVATE FACEBOOK $GA-02482 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1607,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-3/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | RARE EDGECORE WEDGE100BF-32X xe-0",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 749,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM ARELION SRF24033 $GA-02111 | EAP RENAM GWS | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 912,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "ARELION - BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARELION - BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "2/x1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02021 | KAU-RIG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-RIG",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-RIG",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.bil.es.geant.net",
+    "name": "ae15.3005",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/2",
+      "et-1/0/2",
+      "et-2/0/5",
+      "et-4/1/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER RARE #RARE-02644 $GS-02644 |",
+    "circuits": [
+      {
+        "id": 726619,
+        "name": "RARE-BIL-REDIRIS",
+        "type": "L2SERVICES",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 830,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae19.700",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/0/4"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER JISC INTERNET2 #LON-PAR-SYNGENTA-JISC-INTERNET2-17052 $GS-00730 |",
+    "circuits": [
+      {
+        "id": 736674,
+        "name": "LON-PAR-SYNGENTA-JISC-INTERNET2-17052",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1139,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae16.300",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-1/2/1",
+      "xe-1/2/3",
+      "xe-2/0/7",
+      "xe-2/1/2"
+    ],
+    "description": "SRV_CORPORATE CUSTOMER GEANT-IT #LONDON2-CORPORATE-NETWORK-SERVICES $GS-00824 | Firewall Access for Internal",
+    "circuits": [
+      {
+        "id": 661549,
+        "name": "LONDON2-CORPORATE-NETWORK-SERVICES",
+        "type": "CORPORATE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1161,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.519",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #snm-server-mgmt | IT Refresh SERVER MGMT",
+    "circuits": [
+      {
+        "id": 736090,
+        "name": "SNM-SERVER-MGMT",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1602,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ge-0/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 524,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae20.200",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-11/2/3"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER GRENA #GRENA-AP1 $GS-01178 | ASN20545 |",
+    "circuits": [
+      {
+        "id": 718130,
+        "name": "GRENA-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 965,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRENA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRENA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.tar.ee.geant.net",
+    "name": "lag-20.100",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER EENET #EENET-AP1 $GS-00454 | ASN3221 | ",
+    "circuits": [
+      {
+        "id": 746455,
+        "name": "EENET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "4",
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "EENET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EENET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "lag-24",
+    "bundle": [
+      "1/x1/1/c26/1"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c26/1"
+    ],
+    "description": "LAG CUSTOMER RASH | $GA-01768 | #RASH-AP2-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177304,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RASH",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "RASH",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11",
+    "bundle": [
+      "et-3/3/0"
+    ],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "LAG CUSTOMER PIONIER SRF9927597 $GA-01811 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 616,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #KAU-KAU-MGMT-IPTRUNK $GS-50063 | KAU-KAU | KAU-KAU-MGMT",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 2,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KAU-KAU",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KAU-KAU",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "et-5/1/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RESERVED | NORDUNET AP UPGRADE | LR4 INSTALLED",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1265,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae16",
+    "bundle": [
+      "xe-1/2/1",
+      "xe-1/2/3",
+      "xe-2/0/7",
+      "xe-2/1/2"
+    ],
+    "bundle-parents": [
+      "xe-1/2/1",
+      "xe-1/2/3",
+      "xe-2/0/7",
+      "xe-2/1/2"
+    ],
+    "description": "LAG CUSTOMER GEANT SRF0000000 $GA-01759 | GEANT-IT",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 633,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GEANT",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEANT",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae14.161",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5",
+      "et-8/0/2",
+      "et-8/1/2",
+      "et-8/1/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER RENATER #RENATER-RTBH-GENEVA $GS-00504 | ASN2200 | RTBH",
+    "circuits": [
+      {
+        "id": 662958,
+        "name": "RENATER-RTBH-GENEVA",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 916,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ae11.3506",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER RARE #RARE-02643 $GS-02643 |",
+    "circuits": [
+      {
+        "id": 745530,
+        "name": "RARE-02643",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 901,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae14.333",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/0/2"
+    ],
+    "description": "SRV_IAS CUSTOMER CYNET #CYNET-AP1-IAS IASGWS $GS-02442 | ASN3268",
+    "circuits": [
+      {
+        "id": 733815,
+        "name": "CYNET-AP1-IAS",
+        "type": "GWS - INDIRECT",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 721,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "CYNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CYNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "lag-3",
+    "bundle": [
+      "1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01922 | AMS-BRU",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177283,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-BRU",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-BRU",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 569,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-8/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 995,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/3.2200",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENATER GEANT #AMS-PAR-RENATER-RARE-20070 $GS-00657 |",
+    "circuits": [
+      {
+        "id": 736080,
+        "name": "AMS-PAR-RENATER-RARE-20070",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1538,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae4",
+    "bundle": [
+      "et-2/1/5",
+      "et-4/0/2",
+      "et-4/0/5",
+      "et-4/1/2"
+    ],
+    "bundle-parents": [
+      "et-2/1/5",
+      "et-4/0/2",
+      "et-4/0/5",
+      "et-4/1/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02207 | GEN-MAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 617,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "GEN-MAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "GEN-MAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "xe-0/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS P_AE2 SRF0000001 | rt2-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 563,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae2.108",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/3/5",
+      "xe-0/3/7",
+      "xe-9/0/0",
+      "xe-9/2/0"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT EUMETSAT #AMS-EUMETSAT-SERVER-DATA-TRAFFIC $GS-02312 | AMS-EUMETSAT-1G",
+    "circuits": [
+      {
+        "id": 736093,
+        "name": "AMS-EUMETSAT-SERVER-DATA-TRAFFIC",
+        "type": "IP PEERING - R&E",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1021,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "EUMETSAT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "EUMETSAT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/3/7.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-bud-hu-bwctl | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 724902,
+        "name": "PS-BUD-HU-BWCTL",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1178,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.ams.nl.geant.net",
+    "name": "ae10.22",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/0"
+    ],
+    "description": "SRV_GCS CUSTOMER GARR MICROSOFT #GARR_ROMA_ExpressRoute_Vlan4089 $GS-01145 | UNIT CONFIGURATION HAS BEEN SYSTEM GENERATED",
+    "circuits": [
+      {
+        "id": 707342,
+        "name": "GARR-ROMA-EXPRESSROUTE-VLAN4089",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 603,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ge-0/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 608,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "ge-0/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 592,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "ae28",
+    "bundle": [
+      "et-1/1/2"
+    ],
+    "bundle-parents": [
+      "et-1/1/2"
+    ],
+    "description": "LAG CUSTOMER BELNET SRF9927563 $GA-01842 | BELNET AP2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1653,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.242",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #LON-SINET-HOST-DEVICE-IDRAC | SINET HOST-IDRAC",
+    "circuits": [
+      {
+        "id": 740703,
+        "name": "LON-SINET-HOST-DEVICE-IDRAC",
+        "type": "SERVER LINK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 652,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae12.112",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT CSTNET #CSTNET-LON-LHCONE-SECONDARY $GS-02380 | ASN7497 ",
+    "circuits": [
+      {
+        "id": 730081,
+        "name": "CSTNET-LON-LHCONE-SECONDARY",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 653,
+    "dashboards": [
+      "CAE1",
+      "LHCONE",
+      "LHCONE_PEER",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "CSTNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CSTNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE | SPLUNK AMS PEER02 link 1 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 632,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.por.pt.geant.net",
+    "name": "et-1/1/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "Reserved for FCCN | QSFP SR4 optic installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 559,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.vie.at.geant.net",
+    "name": "lag-8",
+    "bundle": [
+      "2/1/c9/2"
+    ],
+    "bundle-parents": [
+      "2/1/c9/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-01868 | BRA-VIE",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177288,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BRA-VIE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "BRA-VIE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.dub.ie.geant.net",
+    "name": "lag-101.991",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/1",
+      "1/x1/1/c2/2"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #OPTICAL-MGMT-DUB-IE-VRF-VLAN991 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "2",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae22",
+    "bundle": [
+      "et-2/1/2"
+    ],
+    "bundle-parents": [
+      "et-2/1/2"
+    ],
+    "description": "LAG PUBLIC DE-CIX $GA-02205 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 735,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 635,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "xe-8/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 989,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "et-3/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "Reserved for FCCN | CFP2 LR4 optic installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 699,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "xe-3/0/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 660,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/0/0.100",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL CUSTOMER BASNET #BASNET-AP1 $GS-00434 | ASN21274 | ",
+    "circuits": [
+      {
+        "id": 661600,
+        "name": "BASNET-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 624,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "BASNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BASNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.lon2.uk.geant.net",
+    "name": "2/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | LON2-PAR | TO GRV2.LON2 - 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162049,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LON2-PAR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LON2-PAR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae10.2801",
+    "bundle": [],
+    "bundle-parents": [
+      "et-3/3/0"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER KIFU BELNET #SLCIMEC-02511 $GS-02511",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 871,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "ae21.0",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-5/0/5",
+      "xe-5/0/6"
+    ],
+    "description": "SRV_IAS UPSTREAM COLT #COLT-GWS-BUD $GS-00068 | ASN3356 ",
+    "circuits": [
+      {
+        "id": 728441,
+        "name": "COLT-GWS-BUD",
+        "type": "GWS - UPSTREAM",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 826,
+    "dashboards": [
+      "IAS_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COLT",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COLT",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-21:3504",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER PIONIER BELNET #SLCIMEC-02487 $GS-02487",
+    "circuits": [
+      {
+        "id": 745329,
+        "name": "SLCIMEC-02487",
+        "type": "GEANT PLUS",
+        "status": "installed"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae2.3021",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-3/3/4",
+      "xe-3/3/6"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #LON-SINET-INTERNET-ACCESS | SINET Internet access",
+    "circuits": [
+      {
+        "id": 740701,
+        "name": "LON-SINET-INTERNET-ACCESS",
+        "type": "SERVER LINK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 675,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 813,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.poz.pl.geant.net",
+    "name": "2/1/c11/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-3 | POZ-POZ | to MX1.POZ.PL et-7/1/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162306,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "POZ-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "POZ-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "et-5/0/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE | LR4 installed",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 814,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae24",
+    "bundle": [
+      "et-2/1/5"
+    ],
+    "bundle-parents": [
+      "et-2/1/5"
+    ],
+    "description": "LAG RE_INTERCONNECT TENET SRF21084 $GA-02142 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 970,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "TENET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "TENET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.bra.sk.geant.net",
+    "name": "xe-0/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 566,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "srx1.am.office.geant.net",
+    "name": "ge-0/0/11",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 527,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.mar.fr.geant.net",
+    "name": "ae21.100",
+    "bundle": [],
+    "bundle-parents": [
+      "et-2/0/2"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER IUCC #IUCC-AP1 $GS-00477 | ASN378 |",
+    "circuits": [
+      {
+        "id": 730578,
+        "name": "IUCC-AP1",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 710,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "IUCC",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "IUCC",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.kau.lt.geant.net",
+    "name": "lag-101.998",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c2/3",
+      "1/x1/1/c2/4"
+    ],
+    "description": "SNM_MGMT INFRASTRUCTURE ACCESS #SWITCH-MGMT-KAU-LT-VRF-VLAN998 |",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "10",
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-7/0/0",
+      "xe-7/0/1"
+    ],
+    "bundle-parents": [
+      "xe-7/0/0",
+      "xe-7/0/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02591 | MAD-MAD",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 981,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "MAD-MAD",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "MAD-MAD",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "xe-3/0/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_10GGBS CUSTOMER AMS #ams-pra-IX-CESNET-AMS-12016 $GS-00786 |",
+    "circuits": [
+      {
+        "id": 720237,
+        "name": "AMS-PRA-IX-CESNET-AMS-12016",
+        "type": "GEANT - GBS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 929,
+    "dashboards": [
+      "GBS_10G"
+    ],
+    "dashboard_info": {
+      "name": "AMS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.rig.lv.geant.net",
+    "name": "lag-4",
+    "bundle": [
+      "2/x1/1/c8/1"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c8/1"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02346 | RIG-TAR",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177284,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "RIG-TAR",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "RIG-TAR",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "et-9/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER CESNET P_AE23 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 565,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae20",
+    "bundle": [
+      "et-2/1/2",
+      "et-5/1/2"
+    ],
+    "bundle-parents": [
+      "et-2/1/2",
+      "et-5/1/2"
+    ],
+    "description": "LAG RE_INTERCONNECT SINET $GA-01916 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1281,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "SINET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "SINET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae19",
+    "bundle": [
+      "xe-2/2/4",
+      "xe-2/3/3"
+    ],
+    "bundle-parents": [
+      "xe-2/2/4",
+      "xe-2/3/3"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS | splunk-lon2-peer02.geant.org | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 636,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/0/0.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RENAM ARELION #bud-chi-EAP-RENAM-ARELION-24033 $GS-02110 | ",
+    "circuits": [
+      {
+        "id": 738245,
+        "name": "BUD-CHI-EAP-RENAM-ARELION-24033",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 866,
+    "dashboards": [
+      "EAP",
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.bru.be.geant.net",
+    "name": "lag-20:4087",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSEICT-01133 $GS-01133",
+    "circuits": [
+      {
+        "id": 744148,
+        "name": "MSEICT-01133",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/3/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 600,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.buc.ro.geant.net",
+    "name": "ae3.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/5",
+      "et-0/1/5"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #BUC-SOF-IPTRUNK $GS-00024| BUC-SOF | ",
+    "circuits": [
+      {
+        "id": 744991,
+        "name": "BUC-SOF-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 671,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "BUC-SOF",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BUC-SOF",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "et-8/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_AE4 | LIS-MAD | 200G",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1140,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LIS-MAD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LIS-MAD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/2/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER JISC SRF9925217 $GA-01457 | GEANT+ 1",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1467,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "JISC",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "JISC",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.mil2.it.geant.net",
+    "name": "xe-0/1/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 570,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "ae16.947",
+    "bundle": [],
+    "bundle-parents": [
+      "et-5/0/5",
+      "et-8/1/2",
+      "et-8/1/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_L2CIRCUIT CUSTOMER NORDUNET REDIRIS #HAM-MAD-02183 $GS-02183",
+    "circuits": [
+      {
+        "id": 747550,
+        "name": "HAM-MAD-02183",
+        "type": "GEANT PLUS",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1121,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "NORDUNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NORDUNET",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-1/0/41",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_AE13    | 10_GBS to MX1.PAR.FR xe-4/3/6",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 656,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-21",
+    "bundle": [
+      "2/x1/1/c2/2"
+    ],
+    "bundle-parents": [
+      "2/x1/1/c2/2"
+    ],
+    "description": "LAG CUSTOMER CYNET | $GA-01928 | CYNET-AP2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177301,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CYNET",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "CYNET",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "xe-11/2/1.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ps-par-fr-management-new| perfSONAR MGMT",
+    "circuits": [
+      {
+        "id": 721158,
+        "name": "PS-PAR-FR-MANAGEMENT-NEW",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 815,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "xe-2/1/7",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS LAN P_AE1  | mx1-sw1 (ex3400)",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1303,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.pra.cz.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "xe-3/0/4",
+      "xe-3/0/5"
+    ],
+    "bundle-parents": [
+      "xe-3/0/4",
+      "xe-3/0/5"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS LAN SRF0000001 | rt1-sw2 (ex3400) | ",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 946,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/3/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 851,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.poz.pl.geant.net",
+    "name": "xe-1/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 573,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1460,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae1.998",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-2/1/7",
+      "xe-2/2/7"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS #ex3400-management-gen-ch| SW1-EX3400 MANAGEMENT",
+    "circuits": [
+      {
+        "id": 740011,
+        "name": "EX3400-MANAGEMENT-GEN-CH",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1466,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.42",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER REDIRIS MICROSOFT #REDIRIS-ICN2-ExpressRoute-VLAN691 $GS-02559 | ",
+    "circuits": [
+      {
+        "id": 740766,
+        "name": "REDIRIS-ICN2-EXPRESSROUTE-VLAN691",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1690,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "REDIRIS",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDIRIS",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "ae14.333",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/1/5",
+      "et-8/0/2",
+      "et-8/1/2",
+      "et-8/1/5"
+    ],
+    "description": "SRV_IAS CUSTOMER RENATER #RENATER-AP2-IAS IASPS $GS-00584 | ASN2200",
+    "circuits": [
+      {
+        "id": 678048,
+        "name": "RENATER-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 895,
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "lag-2.0",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c6/1"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #ATH2-MIL2-IPTRUNK $GS-00014 | ATH2-MIL2 | ",
+    "circuits": [
+      {
+        "id": 745507,
+        "name": "ATH2-MIL2-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 9,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "ATH2-MIL2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "ATH2-MIL2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "gr-3/0/0.25",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_TUN CUSTOMER EUMETSAT #GRE-Multicast-Tunnel-UNI-OF-CHILE $GS-02447",
+    "circuits": [
+      {
+        "id": 733837,
+        "name": "GRE-MULTICAST-TUNNEL-UNI-OF-CHILE",
+        "type": "EUMETSAT GRE",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1584,
+    "dashboards": [],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae28.2063",
+    "bundle": [],
+    "bundle-parents": [
+      "et-11/0/5"
+    ],
+    "description": "SRV_L3VPN RE_INTERCONNECT REDCLARA #REDCLARA-TENET-LON-COPERNICUS $GS-02168| ASN27750",
+    "circuits": [
+      {
+        "id": 720026,
+        "name": "REDCLARA-TENET-LON-COPERNICUS",
+        "type": "L3-VPN",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1244,
+    "dashboards": [
+      "COPERNICUS",
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "REDCLARA",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "REDCLARA",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.sof.bg.geant.net",
+    "name": "1/x1/1/c9/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | SOF-THE | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916417,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "SOF-THE",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "SOF-THE",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ath2.gr.geant.net",
+    "name": "1/x1/1/c4/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GRNET P_lag-20 | GRNET-AP1-IP5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916100,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GRNET",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GRNET",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-3/1/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1461,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/2/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 829,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt2.kie.ua.geant.net",
+    "name": "ae1.0",
+    "bundle": [],
+    "bundle-parents": [
+      "et-0/0/3"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE BACKBONE #KIE-KIE-IPTRUNK $GS-00045 | KIE-KIE |",
+    "circuits": [
+      {
+        "id": 713325,
+        "name": "KIE-KIE-IPTRUNK",
+        "type": "IP TRUNK",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 606,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "KIE-KIE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIE-KIE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-11/3/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER MICROSOFT EXPRESSROUTE #1 FOR NORDUNET  P_AE26 | Interxion CID:  DE133662-1 | GEANT-FRA32-09XGMR-CIS-1-PRI-12062019",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 897,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "MICROSOFT",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MICROSOFT",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae5",
+    "bundle": [
+      "xe-0/0/18",
+      "xe-1/0/18"
+    ],
+    "bundle-parents": [
+      "xe-0/0/18",
+      "xe-1/0/18"
+    ],
+    "description": "LAG INFRASTRUCTURE LAN | qfx1.ams.nl AE5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 712,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx2.lis.pt.geant.net",
+    "name": "ge-0/2/6",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 552,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ge-0/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 645,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.lon2.uk.geant.net",
+    "name": "xe-1/0/31",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_--      | Brik B Data Port 2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 679,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.fra.de.geant.net",
+    "name": "ae2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "LAG INFRASTRUCTURE LAN $GA-01678 | FRA-PRD-ESX02 ESXI Traffic LAG",
+    "circuits": [
+      {
+        "id": 658663,
+        "name": "FRANKFURT 15-FRANKFURT 15-LAG-054(GEANT)",
+        "type": "POP LAN LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": 575,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "1/x1/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | LJU-ZAG | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610916354,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "LJU-ZAG",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "LJU-ZAG",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae23.600",
+    "bundle": [],
+    "bundle-parents": [
+      "et-9/0/5",
+      "et-10/1/5"
+    ],
+    "description": "SRV_GLOBAL CUSTOMER CESNET #CESNET-AP2 $GS-00445 | ASN2852 |",
+    "circuits": [
+      {
+        "id": 731676,
+        "name": "CESNET-AP2",
+        "type": "GEANT IP",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1100,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "CESNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "CESNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "ae15.102",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/5"
+    ],
+    "description": "SRV_GLOBAL RE_INTERCONNECT INTERNET2 #FR-INTERNET2 $GS-00884 | ASN11537 | MANLAN ID: 102",
+    "circuits": [
+      {
+        "id": 661992,
+        "name": "FR-INTERNET2",
+        "type": "IP PEERING - R&E",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 875,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "INTERNET2",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "INTERNET2",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "srx1.ch.office.geant.net",
+    "name": "ge-0/0/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY #SRX1-SRX2-CH-OFFICE |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 514,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.cor.ie.geant.net",
+    "name": "lag-20:1214",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER HEANET RARE #ams-cor-00633 $GS-00633",
+    "circuits": [
+      {
+        "id": 747413,
+        "name": "AMS-COR-00633",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "ACCESS",
+    "snmp-index": -1,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "HEANET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      },
+      {
+        "name": "HEANET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "mx1.bud.hu.geant.net",
+    "name": "xe-5/3/4",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY UPSTREAM COGENT P_AE19 | Cogent ID: 1-300398286",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 940,
+    "dashboards": [
+      "GWS_PHY_UPSTREAM"
+    ],
+    "dashboard_info": {
+      "name": "COGENT - BUD",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "COGENT - BUD",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.lju.si.geant.net",
+    "name": "lag-20",
+    "bundle": [
+      "1/x1/1/c26/1",
+      "1/x1/1/c26/2"
+    ],
+    "bundle-parents": [
+      "1/x1/1/c26/1",
+      "1/x1/1/c26/2"
+    ],
+    "description": "LAG CUSTOMER ARNES | $GA-01742 | #ARNES-AP1-LAG",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1342177300,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "ARNES",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "ARNES",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt2.chi.md.geant.net",
+    "name": "ae10",
+    "bundle": [
+      "xe-0/1/6",
+      "xe-0/1/7"
+    ],
+    "bundle-parents": [
+      "xe-0/1/6",
+      "xe-0/1/7"
+    ],
+    "description": "LAG CUSTOMER RENAM SRF21066 $GA-02038 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 588,
+    "dashboards": [
+      "EAP",
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENAM",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENAM",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/0/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE ACCESS SUPERPOP P_AE30 | QFX xe-1/0/28",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 542,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.mad.es.geant.net",
+    "name": "xe-7/1/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 809,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.fra.de.geant.net",
+    "name": "xe-7/2/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS PERFSONAR #ps-fra-de-owamp LHC new | BWCTL CONTACT: ivan.garnizov@fau.de",
+    "circuits": [
+      {
+        "id": 729061,
+        "name": "PS-FRA-DE-OWAMP-LHC",
+        "type": "SERVER LINK",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 548,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon2.uk.geant.net",
+    "name": "ae32.303",
+    "bundle": [],
+    "bundle-parents": [
+      "et-1/0/0",
+      "et-5/0/0"
+    ],
+    "description": "SRV_GLOBAL INFRASTRUCTURE ACCESS IT REFRESH | T0 EXTERNAL PEERINGS",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": 857,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.ams.nl.geant.net",
+    "name": "1/1/c7/1",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-8 | AMS-FRA | to AMS01-GRV1 1/1/8",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1610899905,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-FRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-FRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/0/2.0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE RARE #AMS-POZ-RARE-P4-9951379 $GS-00661 | RARE P4 TESTBED",
+    "circuits": [
+      {
+        "id": 736091,
+        "name": "AMS-POZ-RARE-P4-9951379",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1527,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-9/1/3.101",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "SRV_L2CIRCUIT CUSTOMER RARE GEANT #AMS-AMS-WP7TSF-RARE-200105-AMS",
+    "circuits": [
+      {
+        "id": 736083,
+        "name": "AMS-AMS-WP7TSF-RARE-200105-AMS",
+        "type": "GEANT PLUS",
+        "status": "non-monitored"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1568,
+    "dashboards": [
+      "L2_CIRCUIT"
+    ],
+    "dashboard_info": {
+      "name": "RARE",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RARE",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.vie.at.geant.net",
+    "name": "ae22",
+    "bundle": [
+      "xe-4/2/1",
+      "xe-4/2/2"
+    ],
+    "bundle-parents": [
+      "xe-4/2/1",
+      "xe-4/2/2"
+    ],
+    "description": "LAG INFRASTRUCTURE ACCESS $GA-01859| NEMO DDOS Detection 2",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 702,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae21.19",
+    "bundle": [],
+    "bundle-parents": [
+      "xe-0/1/3"
+    ],
+    "description": "SRV_GCS CUSTOMER BELNET MICROSOFT #MSESTAD-02245 $GS-02245",
+    "circuits": [
+      {
+        "id": 744266,
+        "name": "MSESTAD-02245",
+        "type": "EXPRESS ROUTE",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": 1402,
+    "dashboards": [
+      "GCS"
+    ],
+    "dashboard_info": {
+      "name": "BELNET",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "BELNET",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "2/1/c8/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-4 | HAM-POZ | to MX1.POZ et-7/1/2",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162114,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "HAM-POZ",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "HAM-POZ",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.gen.ch.geant.net",
+    "name": "et-4/0/5",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER GARR P_AE12 |",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1436,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "GARR",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "GARR",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "ae17",
+    "bundle": [
+      "et-9/1/5"
+    ],
+    "bundle-parents": [
+      "et-9/1/5"
+    ],
+    "description": "LAG PRIVATE FACEBOOK SRF9935089 $GA-01841 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 713,
+    "dashboards": [],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae16",
+    "bundle": [
+      "xe-0/0/4",
+      "xe-0/1/7",
+      "xe-0/3/1"
+    ],
+    "bundle-parents": [
+      "xe-0/0/4",
+      "xe-0/1/7",
+      "xe-0/3/1"
+    ],
+    "description": "LAG CUSTOMER KIAE $GA-01918 |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1052,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "KIAE",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "KIAE",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "rt0.zag.hr.geant.net",
+    "name": "lag-24.333",
+    "bundle": [],
+    "bundle-parents": [
+      "1/x1/1/c4/2"
+    ],
+    "description": "SRV_IAS CUSTOMER MREN #MREN-AP1-IAS IASPS $GS-00538 | ASN40981 | ",
+    "circuits": [],
+    "vlan_type": "VLAN",
+    "snmp-index": "21",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "MREN",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "MREN",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt0.ham.de.geant.net",
+    "name": "lag-22.334",
+    "bundle": [],
+    "bundle-parents": [
+      "1/1/c27/1"
+    ],
+    "description": "SRV_IAS CUSTOMER PIONIER #PIONIER-AP2-IAS IASPS $GS-00580 | ASN8501 | ",
+    "circuits": [
+      {
+        "id": 747602,
+        "name": "PIONIER-AP2-IAS",
+        "type": "GEANT PEERING",
+        "status": "operational"
+      }
+    ],
+    "vlan_type": "VLAN",
+    "snmp-index": "11",
+    "dashboards": [
+      "IAS_CUSTOMER",
+      "NREN"
+    ],
+    "dashboard_info": {
+      "name": "PIONIER",
+      "interface_type": "LOGICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PIONIER",
+        "interface_type": "LOGICAL"
+      }
+    ],
+    "port_type": "SERVICE"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/3/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY RE_INTERCONNECT NIKS P_AE25 | Digital Realty CID: NL189891 | ",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 666,
+    "dashboards": [
+      "RE_PEER"
+    ],
+    "dashboard_info": {
+      "name": "NIKS",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "NIKS",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "ae1",
+    "bundle": [
+      "et-8/0/2"
+    ],
+    "bundle-parents": [
+      "et-8/0/2"
+    ],
+    "description": "LAG INFRASTRUCTURE BACKBONE $GA-02013 | AMS-AMS |",
+    "circuits": [],
+    "vlan_type": "TRUNK",
+    "snmp-index": 1622,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "AMS-AMS",
+      "interface_type": "AGGREGATE"
+    },
+    "dashboards_info": [
+      {
+        "name": "AMS-AMS",
+        "interface_type": "AGGREGATE"
+      }
+    ],
+    "port_type": "ACCESS"
+  },
+  {
+    "router": "mx1.par.fr.geant.net",
+    "name": "et-3/1/0",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY CUSTOMER RENATER P_AE12 | RENATER-AP1-3 | DR Circuit ID: FR112754",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 842,
+    "dashboards": [
+      "NREN",
+      "RE_CUST"
+    ],
+    "dashboard_info": {
+      "name": "RENATER",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "RENATER",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "mx1.lon.uk.geant.net",
+    "name": "xe-1/0/3",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY SPARE",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 850,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt0.pra.cz.geant.net",
+    "name": "2/1/c9/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE BACKBONE P_lag-2 | PRA-PRA | to RT1.PRA et-0/1/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 1611162178,
+    "dashboards": [
+      "INFRASTRUCTURE_BACKBONE"
+    ],
+    "dashboard_info": {
+      "name": "PRA-PRA",
+      "interface_type": "PHYSICAL"
+    },
+    "dashboards_info": [
+      {
+        "name": "PRA-PRA",
+        "interface_type": "PHYSICAL"
+      }
+    ],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "qfx.par.fr.geant.net",
+    "name": "xe-1/0/18",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY INFRASTRUCTURE LAN P_ae0      | MX xe-4/0/5",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 650,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  },
+  {
+    "router": "rt1.ams.nl.geant.net",
+    "name": "xe-0/3/2",
+    "bundle": [],
+    "bundle-parents": [],
+    "description": "PHY PRIVATE GOOGLE P_AE11 | Digital Reality CID: NL246373",
+    "circuits": [],
+    "vlan_type": "ACCESS",
+    "snmp-index": 668,
+    "dashboards": [],
+    "port_type": "UNKNOWN"
+  }
+]
diff --git a/test/data/scid-current.json b/test/data/scid-current.json
new file mode 100644
index 0000000000000000000000000000000000000000..5970934cd1dc1f102cdc514f2c612ff1dbf8236e
--- /dev/null
+++ b/test/data/scid-current.json
@@ -0,0 +1,47507 @@
+[
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661896,
+    "monitored": false,
+    "name": "SCION-PAR-FR",
+    "scid": "001e4416-86e4-4d97-9aad-8e9445e808d7",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00140",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT-IT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae13"
+      }
+    ],
+    "imsid": 679044,
+    "monitored": true,
+    "name": "FRA-PAR-BRIDGE-LAG",
+    "scid": "001fd553-67ff-48b4-846f-66a4826da403",
+    "service_type": "ETHERNET",
+    "sid": "GA-01685",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 713272,
+    "monitored": true,
+    "name": "CHI-CHI-LAG",
+    "scid": "0033b1af-565c-407d-8ef0-02731e4db3db",
+    "service_type": "ETHERNET",
+    "sid": "GA-02015",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "FRA-VIE-PXM-TRUNK",
+    "scid": "003c519f-bed4-4cd9-8c7c-d1525b90e727",
+    "service_type": null,
+    "sid": "DS-36197",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.15.253/24"
+        ],
+        "hostname": "rt1.kie.ua.geant.net",
+        "interface": "ae2.103"
+      }
+    ],
+    "imsid": 713312,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-KIE1-UA",
+    "scid": "004ae718-4713-482a-8acb-320baca30538",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00131",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679042,
+    "monitored": true,
+    "name": "FRA-HAM-LAG",
+    "scid": "0060ea2f-f686-4183-831e-2423da187299",
+    "service_type": "ETHERNET",
+    "sid": "GA-01959",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [],
+    "imsid": 712395,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-PSNC-PL",
+    "scid": "006214fb-6d56-45e1-ae50-5cdfb07b5cfa",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01028",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 717108,
+    "monitored": false,
+    "name": "BUD-PRA-RARE-BMS8",
+    "scid": "006ce926-eb53-47ca-a535-f2d0bddc5d0f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00686",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [],
+    "imsid": 709747,
+    "monitored": true,
+    "name": "GEANT EUMETCAST AP1",
+    "scid": "009b6a12-2cd8-41df-8471-93a751939bc6",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01105",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662178,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-004(ETH)",
+    "scid": "009e6ec5-f9a0-4c7a-a6ee-7a08ff157783",
+    "service_type": "ETHERNET",
+    "sid": "GA-01605",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "VIX"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/5"
+      }
+    ],
+    "imsid": 669236,
+    "monitored": true,
+    "name": "UBUNTUNET LON GN+ LL",
+    "scid": "00d1ac99-ffaa-4aad-9d0b-ceb23131a804",
+    "service_type": "ETHERNET",
+    "sid": "GA-01452",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [],
+    "imsid": 709756,
+    "monitored": true,
+    "name": "KIFU EUMETCAST AP1",
+    "scid": "00d886bb-bd6f-4d1b-aa68-ea10cc5e2260",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01111",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [],
+    "imsid": 712397,
+    "monitored": true,
+    "name": "MD-VPN-VRR-PARIS-FCT-2-PT",
+    "scid": "00d8dc0a-6db3-470b-ac4a-34fc3a1bb127",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01039",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679317,
+    "monitored": false,
+    "name": "NE-ESXI-DRAC-PAR-FR",
+    "scid": "01189262-fce3-40a0-8724-d19700bf4c48",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00252",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708228,
+    "monitored": false,
+    "name": "PS-MIL2-IT-OWAMP",
+    "scid": "015d8096-4a82-4ad2-bfbb-e3909befc93f",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00337",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.14/31",
+          "2001:798::19/126"
+        ],
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "ae10.667"
+      }
+    ],
+    "imsid": 661915,
+    "monitored": false,
+    "name": "GARR-AP1-CLS",
+    "scid": "0165a4c7-ec11-4e4b-b3ea-1689a5d0a15f",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00606",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae14"
+      }
+    ],
+    "imsid": 659373,
+    "monitored": true,
+    "name": "MAD-DE-CIX-LAG",
+    "scid": "01a59152-95f8-4c63-bf50-55a6efb86716",
+    "service_type": "ETHERNET",
+    "sid": "GA-01779",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/7"
+      }
+    ],
+    "imsid": 732325,
+    "monitored": true,
+    "name": "SCION1ILO.FRA.DE-INTERNAL-LL",
+    "scid": "01aaf261-0b82-4007-b69c-b7f247643dc8",
+    "service_type": "ETHERNET",
+    "sid": "GA-02195",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "DUB-LON-LAG",
+    "scid": "01f3a3cc-fa2b-4ad9-9c61-e8c3372bca13",
+    "service_type": null,
+    "sid": "DA-23835",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 730601,
+    "monitored": true,
+    "name": "COR-COR-LAG",
+    "scid": "01fbdb3a-e746-4625-953e-387585d930ec",
+    "service_type": "ETHERNET",
+    "sid": "GA-02404",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.241/30",
+          "2001:798:111:1::d/126"
+        ],
+        "hostname": "rt0.lju.si.geant.net",
+        "interface": "lag-21.111"
+      }
+    ],
+    "imsid": 747535,
+    "monitored": true,
+    "name": "ARNES-AP1-LHCONE",
+    "scid": "0204ee59-4ec9-4eb4-b8e3-910f5d8a8aa4",
+    "service_type": "L3-VPN",
+    "sid": "GS-00807",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.PRA.CZ.GEANT2.NET",
+        "port": "ETH-45"
+      },
+      {
+        "hostname": "mx1.pra.cz.geant.net",
+        "interface": "ge-0/3/9.1023"
+      },
+      {
+        "hostname": "mx1.pra.cz.geant.net",
+        "interface": "xe-2/0/2.1023"
+      }
+    ],
+    "imsid": 661779,
+    "monitored": false,
+    "name": "BOD-SDN-PILOT-HOST-ETH2-PRAGUE",
+    "scid": "0230de60-6bd3-4798-99b9-714b895ee7cc",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00103",
+    "speed": 11811160064,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 744731,
+    "monitored": true,
+    "name": "BUCHAREST 2-CHISINAU-LAG-001(GEANT)",
+    "scid": "023e9e14-3e38-4521-8a49-d37b5a3cb792",
+    "service_type": "ETHERNET",
+    "sid": "GA-50053",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae20.990"
+      },
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae15.990"
+      }
+    ],
+    "imsid": 738726,
+    "monitored": true,
+    "name": "AMS-MAR-ITER-IFERC-SINET-RENATER-24039",
+    "scid": "025e686e-7979-48cb-9d23-5f77e704f357",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00637",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NISN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "192.84.8.14/30",
+          "2001:798:99:1::1/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.204"
+      }
+    ],
+    "imsid": 661526,
+    "monitored": true,
+    "name": "UK-NISN-NEA3R-204",
+    "scid": "026371d6-05e3-48e6-81ec-0a44004996d4",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00922",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.PRA.CZ.GEANT2.NET",
+        "port": "ETH-45"
+      },
+      {
+        "hostname": "mx1.pra.cz.geant.net",
+        "interface": "ge-0/3/9.1024"
+      },
+      {
+        "hostname": "mx1.pra.cz.geant.net",
+        "interface": "xe-2/0/2.1024"
+      }
+    ],
+    "imsid": 661914,
+    "monitored": false,
+    "name": "BOD-SDN-PILOT-HOST-ETH3-PRAGUE",
+    "scid": "02707601-7991-48d7-9784-88bf1c420136",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00104",
+    "speed": 11811160064,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/0/6"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/0/6.2"
+      }
+    ],
+    "imsid": 661742,
+    "monitored": true,
+    "name": "SDX-L2-HOSTD-TO-BR51",
+    "scid": "0282748b-4022-403d-9163-bb0492a4e1d8",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00764",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663106,
+    "monitored": false,
+    "name": "PS-GEN-CH-IDRAC",
+    "scid": "02bec5d5-4388-4ab6-88c2-22c9c1479ed8",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00308",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 669290,
+    "monitored": true,
+    "name": "BELNET 1GB GN+ LL1",
+    "scid": "02de13c8-2126-4521-959b-913e83e0de37",
+    "service_type": "ETHERNET",
+    "sid": "GA-01362",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.217/30"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/6.961"
+      }
+    ],
+    "imsid": 709655,
+    "monitored": false,
+    "name": "JANET-GN-PRACE-1-VPN-PROXY-LONDON-L3VPN",
+    "scid": "02e3f795-fb70-491b-a98f-25097089ea5b",
+    "service_type": "MD-VPN (PROXY)",
+    "sid": "GS-01065",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663236,
+    "monitored": false,
+    "name": "ASNET-TEST-VLAN-E2E",
+    "scid": "02eed6ed-1a37-483f-b117-9700458eba40",
+    "service_type": "GEANT IP",
+    "sid": "GS-00429",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/2"
+      }
+    ],
+    "imsid": 733209,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-028(GEANT)",
+    "scid": "02fe0dda-4e19-44fa-be82-ea14b607a917",
+    "service_type": "ETHERNET",
+    "sid": "GA-01325",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRENA"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae20"
+      }
+    ],
+    "imsid": 718128,
+    "monitored": true,
+    "name": "GRENA-AP1-LAG",
+    "scid": "0309a79c-b66b-457a-a49a-9e016bfca27a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01860",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "IUCC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.93/30",
+          "2001:798:1::71/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae21.333"
+      }
+    ],
+    "imsid": 730581,
+    "monitored": true,
+    "name": "IUCC-AP1-IAS",
+    "scid": "03166d35-404a-4121-83cf-fe4844d98116",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00532",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662396,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-10GBE-092(GEANT)",
+    "scid": "03291fae-4bcc-4976-bbde-c9d56a04f5c5",
+    "service_type": "ETHERNET",
+    "sid": "GA-02130",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 738841,
+    "monitored": true,
+    "name": "LON2-LON2-800G-LAG",
+    "scid": "03344604-d6ce-49aa-af06-cfb3a8acc083",
+    "service_type": "ETHERNET",
+    "sid": "GA-02469",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae6"
+      }
+    ],
+    "imsid": 729435,
+    "monitored": true,
+    "name": "BRA-BUD LAG 100G",
+    "scid": "0336ce95-0865-4e10-8297-1852351b5cb3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01910",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.buc.ro - Traffic - ae12 - LAG CUSTOMER RENAM SRF18037 | *** CLS Peering Only ***",
+    "scid": "033906d9-9479-46bc-98bd-bed8fedebab0",
+    "service_type": null,
+    "sid": "GA-01933",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.3140"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3140"
+      }
+    ],
+    "imsid": 705918,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-NORDUNET-SINGAREN-CAE1-19074-VL3140",
+    "scid": "0352e3a7-96df-40e6-b67a-a0c8a97ef10a",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00975",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/1/2"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-4/1/4"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-4/1/4.1"
+      }
+    ],
+    "imsid": 659120,
+    "monitored": true,
+    "name": "LONDON-LONDON-100GBE-013(ETH)",
+    "scid": "035f3ea4-e9f7-4fab-ae02-1da086b3066f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01449",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 724613,
+    "monitored": true,
+    "name": "GEN-LON-400G-LAG",
+    "scid": "0365cdfb-6cf0-4011-99ba-d0d3845ba691",
+    "service_type": "ETHERNET",
+    "sid": "GA-02227",
+    "speed": 429496729600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "bud-pra",
+    "scid": "0368b49c-2f07-49e6-83da-1edffbfe5e03",
+    "service_type": null,
+    "sid": "DS-29949",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [],
+    "imsid": 732598,
+    "monitored": true,
+    "name": "PIONIER-BGP-LU-COC-AP2",
+    "scid": "036cbd31-a314-40d5-a76b-2d68d568e6cb",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01056",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "74.125.146.213/31",
+          "2001:4860:1:1::2ea7/127"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae13.0"
+      }
+    ],
+    "imsid": 731196,
+    "monitored": false,
+    "name": "GOOGLE-FRA15-15169-DE-TO-BE-DELETED",
+    "scid": "037d5ea2-86d1-475c-a866-a5c8a5178fc2",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "TS-00934",
+    "speed": 32212254720,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae13"
+      }
+    ],
+    "imsid": 733500,
+    "monitored": true,
+    "name": "GOOGLE-AMS-PNI-1-LAG",
+    "scid": "037dff5d-fbde-4c1a-9a7b-efd817e4aeb6",
+    "service_type": "ETHERNET",
+    "sid": "GA-02450",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-1/0/7"
+      }
+    ],
+    "imsid": 658561,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-022(ETH)",
+    "scid": "03b28ad6-8d84-4f39-90cd-4c5318c54d4a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01269",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661355,
+    "monitored": false,
+    "name": "LON-GROOVE-3-MANAGEMENT",
+    "scid": "03b75af6-6c90-4889-8b40-cc54649cfe55",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00233",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.53/31",
+          "2001:798:cc::82/126"
+        ],
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae2.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.52/31",
+          "2001:798:cc::81/126"
+        ],
+        "hostname": "rt0.pra.cz.geant.net",
+        "interface": "lag-2.0"
+      }
+    ],
+    "imsid": 739239,
+    "monitored": true,
+    "name": "PRA-PRA-IPTRUNK",
+    "scid": "03bff316-d89d-49db-9fba-8b4eae6dd764",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02545",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae15"
+      }
+    ],
+    "imsid": 658690,
+    "monitored": false,
+    "name": "LON2-SEC-ESX21-VM-TRAFFIC",
+    "scid": "03d2213d-0c6b-4952-98d4-68b2f329a989",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01703",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 745506,
+    "monitored": true,
+    "name": "ATH2-MIL2-LAG",
+    "scid": "0412f0c0-6563-4c55-a8c4-042165afd59f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01795",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/3.1338"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.1338"
+      }
+    ],
+    "imsid": 726377,
+    "monitored": false,
+    "name": "AMS-PAR-SCION-SURF-SCION-23013",
+    "scid": "041394e0-28f1-4a19-972d-34d0f91d699d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02264",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "MICROSOFT-LL4 DE133662-1"
+      }
+    ],
+    "imsid": 732177,
+    "monitored": true,
+    "name": "MICROSOFT-EXPRESSROUTE-FRA-LL4",
+    "scid": "044594e9-ef4b-49f1-99e5-51544d06dc93",
+    "service_type": "ETHERNET",
+    "sid": "DE133662-1",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 735877,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10GBE-070(GEANT)",
+    "scid": "044b1c19-bffd-4375-9b25-d7fb0cab2111",
+    "service_type": "ETHERNET",
+    "sid": "GA-01569",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662252,
+    "monitored": true,
+    "name": "SOFIA-SOFIA-1GBE-006(ETH)",
+    "scid": "046c2c42-74bc-45a1-aaa9-dcbac9da7733",
+    "service_type": "ETHERNET",
+    "sid": "GA-01249",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RESTENA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.205/30",
+          "2001:798:1::ed/126"
+        ],
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-22.333"
+      }
+    ],
+    "imsid": 744074,
+    "monitored": true,
+    "name": "RESTENA-AP2-IAS",
+    "scid": "046c358c-9230-4322-a876-838482ae63db",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00586",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.123.233/29"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae1.300"
+      }
+    ],
+    "imsid": 739093,
+    "monitored": false,
+    "name": "DTN-PROJECT-PAR-FR",
+    "scid": "04843eec-b9c5-4dd1-8a43-7f874ee05891",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00145",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661609,
+    "monitored": false,
+    "name": "INBAND-MANAGEMENT-SW4.LON.UK",
+    "scid": "049f0338-ab2a-48a0-bbc8-fe2be51fbac9",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00199",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae15.989"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae13.989"
+      }
+    ],
+    "imsid": 738302,
+    "monitored": true,
+    "name": "GEN-MAR-ESNET-RENATER-24038",
+    "scid": "04a96079-f89a-43a4-a32b-2c5881bd86d4",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02504",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "DE-CIX"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae22"
+      }
+    ],
+    "imsid": 740861,
+    "monitored": true,
+    "name": "DE-CIX-MAR-LAG",
+    "scid": "04e60051-4466-4f09-9cec-208be27aa98e",
+    "service_type": "ETHERNET",
+    "sid": "GA-02205",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 724613,
+    "monitored": true,
+    "name": "GEN-LON-400G-LAG",
+    "scid": "04e72c1a-3b59-46be-9b1e-d26dacde3e61",
+    "service_type": "ETHERNET",
+    "sid": "GA-02228",
+    "speed": 429496729600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [],
+    "imsid": 709001,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-KMA-KOREA",
+    "scid": "04fa89fa-ec63-44d4-8aa7-c8b02abae4a1",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01082",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-1/0/1"
+      }
+    ],
+    "imsid": 658360,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-005(ETH)",
+    "scid": "05272c5b-bdf3-4cea-a258-2422c55c1b62",
+    "service_type": "ETHERNET",
+    "sid": "GA-01270",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3.1034"
+      }
+    ],
+    "imsid": 661646,
+    "monitored": true,
+    "name": "SDN-BOD-BR53-OF-10-HOST-H-ETH3",
+    "scid": "054016c2-0c6c-451e-868c-20104fcfd58d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00754",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "xe-0/0/40"
+      }
+    ],
+    "imsid": 716018,
+    "monitored": false,
+    "name": "PS-THROUGHTPUT-TESTER-INTERFACE-10GBE-2",
+    "scid": "056e1335-1735-4b11-88e5-c714ec34e475",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01667",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae11.400"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.31"
+      }
+    ],
+    "imsid": 725107,
+    "monitored": true,
+    "name": "CESNET-NACIT-EXPRESSROUTE-VLAN400",
+    "scid": "059389c8-1202-4993-8d9a-2f4b975e86a1",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02174",
+    "speed": 225485783040,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINGAREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.3925"
+      }
+    ],
+    "imsid": 734582,
+    "monitored": true,
+    "name": "NL-SINGAREN",
+    "scid": "05a882a2-31b9-43a2-81c6-56ab6403a31e",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02202",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae12.4089"
+      },
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.22"
+      }
+    ],
+    "imsid": 707342,
+    "monitored": true,
+    "name": "GARR-ROMA-EXPRESSROUTE-VLAN4089",
+    "scid": "05ae0cfa-d9ee-45ae-b40f-fb8904386e66",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01145",
+    "speed": 332859965440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CANARIE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.145/30",
+          "2001:410:101:fa2::2/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.4040"
+      }
+    ],
+    "imsid": 736735,
+    "monitored": true,
+    "name": "CANARIE-PAR-LHCONE-2",
+    "scid": "05ce1635-9ed0-418a-b891-0db007aea3d9",
+    "service_type": "L3-VPN",
+    "sid": "GS-00810",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 719669,
+    "monitored": false,
+    "name": "UAT-TEST-MS-EXPRESS-ROUTE",
+    "scid": "05eb95db-007d-40f8-94cd-0ce2f5613bd1",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-11113",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663127,
+    "monitored": false,
+    "name": "FRA-GROOVE-1-MANAGEMENT",
+    "scid": "05fc74b0-2c17-4365-9c00-b98b14c1e0fc",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00173",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.63/31",
+          "2001:798:cc::6a/126"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.62/31",
+          "2001:798:cc::69/126"
+        ],
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-1.0"
+      }
+    ],
+    "imsid": 738843,
+    "monitored": true,
+    "name": "LON2-LON2-IPTRUNK",
+    "scid": "060cda59-53cc-4806-a968-9f7022021451",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02470",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 737234,
+    "monitored": false,
+    "name": "PRA-POZ-RARE-BMS9",
+    "scid": "060e09a5-1cd5-4626-8255-bd19a6cbd91a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02628",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae10.2804"
+      },
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.977"
+      }
+    ],
+    "imsid": 738341,
+    "monitored": false,
+    "name": "SZTAKI-KIFU-REDIRIS-SLICES-UC3M",
+    "scid": "064ae81a-8cd6-4e63-8167-b5def121b587",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02512",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae15"
+      }
+    ],
+    "imsid": 733052,
+    "monitored": true,
+    "name": "GOOGLE-2-15169-IT-LAG",
+    "scid": "065dd9a7-36b2-460f-a52c-5707c9753976",
+    "service_type": "ETHERNET",
+    "sid": "GA-02247",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 744126,
+    "monitored": true,
+    "name": "AMS-BRU-LAG",
+    "scid": "066c31c1-d773-48ce-8d6c-adac7c0b06c0",
+    "service_type": "ETHERNET",
+    "sid": "A-01792",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "MAD01-GRV5",
+        "port": "1/1/8"
+      },
+      {
+        "equipment": "MAD01-GRV5",
+        "port": "1/3/8"
+      },
+      {
+        "equipment": "GEN01-GRV9",
+        "port": "1/1/8"
+      },
+      {
+        "equipment": "BOD01-GRV2",
+        "port": "1/1/8"
+      }
+    ],
+    "imsid": 734130,
+    "monitored": true,
+    "name": "BOD-GEN1-ESNET-23093-400G",
+    "scid": "06a8a362-4da9-4384-b8e7-875e626fc12d",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02337",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 724084,
+    "monitored": true,
+    "name": "LJUBLJANA 2-LJUBLJANA 2-100MB-001(GEANT)",
+    "scid": "06da926a-3b46-4da7-acbb-3e1e1593bf96",
+    "service_type": "ETHERNET",
+    "sid": "GA-01669",
+    "speed": 104857600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SUNET"
+    ],
+    "endpoints": [],
+    "imsid": 712356,
+    "monitored": true,
+    "name": "MD-VPN-VRR-PARIS-SUNET-1-SE",
+    "scid": "06ec43f6-6536-4ee1-a74f-bc9045dc41ac",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01052",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 709379,
+    "monitored": true,
+    "name": "LAG-SW1.POR.PT_AE1",
+    "scid": "0707e883-dac3-46e4-9d34-6308d31cc154",
+    "service_type": "ETHERNET",
+    "sid": "GA-02027",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae10.1946"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.10"
+      }
+    ],
+    "imsid": 706996,
+    "monitored": true,
+    "name": "FCCN-IPP-EXPRESSROUTE-VLAN1946",
+    "scid": "072afc6c-9f97-4878-b322-9d032a04673c",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01143",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae11.3061"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.3061"
+      }
+    ],
+    "imsid": 744387,
+    "monitored": true,
+    "name": "OFCFODMOB-02631",
+    "scid": "076d42e0-f4f2-4610-b3f6-bc953f92a87f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02631",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.24"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240590"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4084"
+      }
+    ],
+    "imsid": 744150,
+    "monitored": true,
+    "name": "MSESTADKORTRIJK-01138",
+    "scid": "078af96b-c99b-4204-8859-592dd3979164",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01138",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 677543,
+    "monitored": false,
+    "name": "ATH2 OOB LINK",
+    "scid": "07b34c57-55d0-421b-b3d6-363a7f19d46e",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00391",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663242,
+    "monitored": false,
+    "name": "OLD-PS-GEN-CH-MANAGEMENT",
+    "scid": "07bdc8f1-4a1d-4ac9-b57c-2f80beb8ac86",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00309",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-23"
+      }
+    ],
+    "imsid": 744128,
+    "monitored": true,
+    "name": "BELNET-GRID5K-LAG",
+    "scid": "07d2ccf5-ace6-49d1-8358-40c3b28125de",
+    "service_type": "ETHERNET",
+    "sid": "GA-01791",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.22/31",
+          "2001:798:cc::25/126"
+        ],
+        "hostname": "rt0.ams.nl.geant.net",
+        "interface": "lag-4.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.23/31",
+          "2001:798:cc::26/126"
+        ],
+        "hostname": "rt0.lon.uk.geant.net",
+        "interface": "lag-4.0"
+      }
+    ],
+    "imsid": 738598,
+    "monitored": true,
+    "name": "AMS-LON-IPTRUNK",
+    "scid": "07d95826-c41f-4834-b98b-cfe3e996fca4",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02269",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.2128"
+      }
+    ],
+    "imsid": 661730,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-NORDUNET-INTERNET2-17022",
+    "scid": "083bf08b-ccd1-4567-b29d-58136a2b4e32",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00974",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.248/31",
+          "2001:798:111:1::19/126"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae10.111"
+      }
+    ],
+    "imsid": 661882,
+    "monitored": true,
+    "name": "GARR-AP1-LHCONE",
+    "scid": "0845570c-10fa-4473-838f-cd1041a44fef",
+    "service_type": "L3-VPN",
+    "sid": "GS-00825",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [],
+    "imsid": 668936,
+    "monitored": true,
+    "name": "CARNET-AP1-5",
+    "scid": "08507b54-1322-4019-9bc1-43efbd204337",
+    "service_type": "ETHERNET",
+    "sid": "GS-00803",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae19"
+      }
+    ],
+    "imsid": 731898,
+    "monitored": true,
+    "name": "ORACLE FASTCONNECT LAG",
+    "scid": "086a309f-d3ad-4d91-9cdc-81424ab9a16a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01941",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ASREN"
+    ],
+    "endpoints": [],
+    "imsid": 658904,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-059(ETH)",
+    "scid": "0872b1e7-2c7e-4367-963d-a870116b8f72",
+    "service_type": "ETHERNET",
+    "sid": "GA-01316",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "FRA-PRA-PXM-IPTRUNK",
+    "scid": "08a2616b-c3f4-4674-bc1f-fe10e12dde64",
+    "service_type": null,
+    "sid": "DS-36199",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SURFNET"
+    ],
+    "endpoints": [],
+    "imsid": 720480,
+    "monitored": true,
+    "name": "SURFNET-TEMP-EXPRESSROUTE-VLAN3750",
+    "scid": "08ae0a78-729f-4a4f-8ea2-4bd36daadd5e",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02200",
+    "speed": 225485783040,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 734463,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-003(GEANT)",
+    "scid": "08bd7a4f-0a1a-4ac5-99ee-01e682a18db3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01585",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NEA3R"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae22.1200"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.1200"
+      }
+    ],
+    "imsid": 709339,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-NEA3R-WACREN-190131",
+    "scid": "08c2695e-a949-4a15-b261-b11344b46fa1",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00982",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae15"
+      }
+    ],
+    "imsid": 713843,
+    "monitored": true,
+    "name": "REDCLARA-MAD-COPERNICUS-LAG",
+    "scid": "0978e56e-fd3d-46bf-a550-cb078488c6e2",
+    "service_type": "ETHERNET",
+    "sid": "GA-02004",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658620,
+    "monitored": false,
+    "name": "LON2-PRD-ESX10-NIC1-PORT1",
+    "scid": "0991b3d1-0afa-4803-88d1-8fe7ef244cd6",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01239",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 742614,
+    "monitored": true,
+    "name": "MAD-MAD-MGMT-LAG",
+    "scid": "09e9c51a-af11-42d9-8298-541cd470c9c3",
+    "service_type": "ETHERNET",
+    "sid": "GA-02591",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [],
+    "imsid": 734565,
+    "monitored": false,
+    "name": "AMS-GEN-LHC-CERN-ASGC-07014",
+    "scid": "0a06d926-e7c1-422b-8ff3-43025293cb06",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00780",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663158,
+    "monitored": false,
+    "name": "KVMOIP-SOF-BG",
+    "scid": "0a2e9db4-a601-4e6e-9314-f4b9f08e574b",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00223",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RASH"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.36/31",
+          "2001:798:99:1::41/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-24.100"
+      }
+    ],
+    "imsid": 745010,
+    "monitored": true,
+    "name": "RASH-AP2",
+    "scid": "0a835922-ccb5-47af-b79a-e952d2e6fc91",
+    "service_type": "GEANT IP",
+    "sid": "GS-00497",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RESTENA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.58/31",
+          "2001:798::71/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae18.667"
+      }
+    ],
+    "imsid": 677403,
+    "monitored": true,
+    "name": "RESTENA-AP2-CLS",
+    "scid": "0a96f11c-2b5f-4206-ba7a-cf5ba8b0b5f0",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00621",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae20"
+      }
+    ],
+    "imsid": 678046,
+    "monitored": true,
+    "name": "CH-NKN LAG",
+    "scid": "0abd37fe-8ae5-416a-9523-3cc2f747c55c",
+    "service_type": "ETHERNET",
+    "sid": "GA-02088",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 734095,
+    "monitored": true,
+    "name": "ATH2-ATH2-LAG",
+    "scid": "0ac1bb11-1730-4796-ad33-c54db14ca771",
+    "service_type": "ETHERNET",
+    "sid": "DA-00097",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658948,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-10GBE-009(ETH)",
+    "scid": "0ac82e82-3c6d-4745-be95-31362d25096f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01423",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae20"
+      }
+    ],
+    "imsid": 734781,
+    "monitored": true,
+    "name": "NL-SINET-LAG",
+    "scid": "0ad41ef3-e2de-4fb6-8bd7-eed2c38f4f13",
+    "service_type": "ETHERNET",
+    "sid": "GA-01916",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30.3008"
+      }
+    ],
+    "imsid": 712155,
+    "monitored": false,
+    "name": "INFOBLOX-TEST-PAR-FR",
+    "scid": "0ae14b97-3e47-431a-9f69-76b7a99a42b6",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00203",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662194,
+    "monitored": true,
+    "name": "DUBLIN 2 - PARKWEST-DUBLIN 2 - PARKWEST-1GBE-004(ETH)",
+    "scid": "0af73ca7-f2c2-41d8-bbdb-278a1b2e5e76",
+    "service_type": "ETHERNET",
+    "sid": "GA-01625",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [],
+    "imsid": 736652,
+    "monitored": false,
+    "name": "CYNET-AP3",
+    "scid": "0b0f4bad-3ac1-4db8-93e0-20b2adaf5632",
+    "service_type": "GEANT IP",
+    "sid": "GS-00451",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.cor.ie.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 747266,
+    "monitored": true,
+    "name": "COR-DUB-LAG",
+    "scid": "0b35c480-c57e-4d3f-bb2e-9ce8321fdd2b",
+    "service_type": "ETHERNET",
+    "sid": "GA-02384",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.fra.de.geant.net",
+        "interface": "lag-8"
+      }
+    ],
+    "imsid": 739043,
+    "monitored": true,
+    "name": "AMS-FRA-1.6T-LAG",
+    "scid": "0b6389ef-91b8-408a-ae72-21f3a10293f4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01945",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.214/31",
+          "2001:798:111:1::8d/126"
+        ],
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.111"
+      }
+    ],
+    "imsid": 661518,
+    "monitored": true,
+    "name": "PIONIER-AP1-LHCONE",
+    "scid": "0b6cfc81-e15b-4a6c-aa8a-16c5b9a03621",
+    "service_type": "L3-VPN",
+    "sid": "GS-00844",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 747825,
+    "monitored": true,
+    "name": "ARNES-AP2-LAG",
+    "scid": "0ba9ab91-4c40-4e8a-81f7-464f3335ffb1",
+    "service_type": "ETHERNET",
+    "sid": "GA-01866",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [],
+    "imsid": 715227,
+    "monitored": false,
+    "name": "GEN-MAD-LHC-CERN-REDIRIS-07003",
+    "scid": "0bae6286-b92d-416a-96a8-51cd4166d3cc",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00804",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662195,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-008(ETH)",
+    "scid": "0bd06811-2c7f-4b56-8899-e28a60f153d0",
+    "service_type": "ETHERNET",
+    "sid": "GA-01615",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.200/31",
+          "2001:798:cc::51/126"
+        ],
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae1.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.201/31",
+          "2001:798:cc::52/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae1.0"
+      }
+    ],
+    "imsid": 735976,
+    "monitored": true,
+    "name": "AMS-AMS-IPTRUNK-2",
+    "scid": "0c00639c-30bd-4ee1-85af-b6c5cc212472",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00007",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae11.1700"
+      }
+    ],
+    "imsid": 725157,
+    "monitored": true,
+    "name": "CESNET-NSI-GCS",
+    "scid": "0c442386-a6c5-4bb8-bd2d-4eaa4d70f051",
+    "service_type": "GEANT IP",
+    "sid": "GS-00446",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.176/31",
+          "2001:798:111:1::ad/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.2511"
+      }
+    ],
+    "imsid": 660633,
+    "monitored": true,
+    "name": "SINET-PAR-LHCONE",
+    "scid": "0c504e16-fe46-438c-ba18-c93eaf5864b5",
+    "service_type": "L3-VPN",
+    "sid": "GS-00859",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/4"
+      }
+    ],
+    "imsid": 662519,
+    "monitored": true,
+    "name": "PHY TO VIRGIN MEDIA NTU",
+    "scid": "0c58a836-4077-4bbb-8cb4-8ff972e60b5f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01280",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.21.2.1/24"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae1.998"
+      }
+    ],
+    "imsid": 733985,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-PAR-FR",
+    "scid": "0c87d6c5-6658-46c5-84e0-450c44f06a81",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00157",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae10.2802"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-20:711"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-224047"
+      }
+    ],
+    "imsid": 745594,
+    "monitored": true,
+    "name": "SLCUTH-02497",
+    "scid": "0cb5d4c0-5bde-45c0-8ee6-dab43ccbea45",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02497",
+    "speed": 171798691840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [],
+    "imsid": 719255,
+    "monitored": true,
+    "name": "DE-ORACLE-IAS-LAG",
+    "scid": "0cc7dc65-b87e-49ec-a9e7-26c2805b5287",
+    "service_type": "ETHERNET",
+    "sid": "GA-02090",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/5"
+      }
+    ],
+    "imsid": 678561,
+    "monitored": true,
+    "name": "LONDON-LONDON-10GBE-032(GEANT)",
+    "scid": "0ccbc0ba-a7d2-4380-b3cb-14276291e603",
+    "service_type": "ETHERNET",
+    "sid": "GA-01659",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-6"
+      }
+    ],
+    "imsid": 744976,
+    "monitored": true,
+    "name": "LIS-PAR-LAG",
+    "scid": "0ccfae31-02dc-4fed-85f3-b53f84d32c6e",
+    "service_type": "ETHERNET",
+    "sid": "GA-02635",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659271,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-1GBE-016(ETH)",
+    "scid": "0cf29462-97e8-467c-bde0-9a780170afcb",
+    "service_type": "ETHERNET",
+    "sid": "GA-01443",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [],
+    "imsid": 661229,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-INTERNET2-NETHERLIGHT-18073",
+    "scid": "0cf388db-ebd6-4b36-b984-601df07fdeb0",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00969",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743997,
+    "monitored": false,
+    "name": "RIG-RIG-MGMT-IPTRUNK",
+    "scid": "0d00b9b2-5c24-426d-a9ee-04bf1872c5b8",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02612",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3.1023"
+      }
+    ],
+    "imsid": 661191,
+    "monitored": true,
+    "name": "SDN-BOD-BR53-OF-6-HOST-G-ETH2",
+    "scid": "0d218243-c529-4544-a429-9c71cd0cf426",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00757",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658705,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-004(ETH)",
+    "scid": "0d291140-25b9-4345-87cb-f6e7e1077cf0",
+    "service_type": "ETHERNET",
+    "sid": "GA-01498",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae18"
+      }
+    ],
+    "imsid": 659355,
+    "monitored": true,
+    "name": "FACEBOOK-FC26603-LAG",
+    "scid": "0d3ffc14-a905-4975-b5c2-b51fb90d4f3f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01840",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707065,
+    "monitored": false,
+    "name": "TAAS-GTS-GATE-LON2-UK",
+    "scid": "0d44500a-d887-4d05-b2ba-8dc2d7a9850a",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00371",
+    "speed": 2147483648,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 727431,
+    "monitored": false,
+    "name": "NORDUNET-GEO-EXPRESSROUTE-VLAN3916",
+    "scid": "0d49ff8c-ba86-4a24-a1b9-ccdfeed40b3f",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02307",
+    "speed": 118111600640,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708186,
+    "monitored": false,
+    "name": "FLOWMON-PAR-FR-MANAGEMENT",
+    "scid": "0d915349-a30e-4881-ab5d-9f034efe9a5c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00168",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ASNET-AM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.41/30",
+          "2001:798:99:1::e1/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae17.400"
+      }
+    ],
+    "imsid": 746552,
+    "monitored": false,
+    "name": "ASNET-AM-AP2",
+    "scid": "0db63f8a-6652-4840-a825-06efe07b6159",
+    "service_type": "GEANT IP",
+    "sid": "GS-02650",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.17"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4080"
+      }
+    ],
+    "imsid": 739674,
+    "monitored": true,
+    "name": "BELNET-ARPGAN-EXPRESSROUTE-VLAN4080",
+    "scid": "0db7ac4f-761f-4b46-839a-68c5c2bbfb2a",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01122",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658738,
+    "monitored": true,
+    "name": "PARIS-POP-LAN-1GBE-001(ETH)",
+    "scid": "0dc5b8ca-0609-410e-8231-0c86affc212a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01403",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [],
+    "imsid": 718312,
+    "monitored": true,
+    "name": "CESNET-PRITEST-EXPRESSROUTE-VLAN408",
+    "scid": "0dd4c135-c51e-4398-90c3-d577f6c342d8",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02093",
+    "speed": 118111600640,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663084,
+    "monitored": true,
+    "name": "RARE-P4-MANAGEMENT-VLAN3005",
+    "scid": "0ddeb66b-94ef-4097-a03f-853b91c3a943",
+    "service_type": "L2SERVICES",
+    "sid": "GS-00773",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [],
+    "imsid": 709837,
+    "monitored": true,
+    "name": "SWITCH EUMETCAST AP2",
+    "scid": "0df9e223-38bf-4cfc-9076-8ceb05687e21",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01121",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "MREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.209/30",
+          "2001:798:1b:10aa::9/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-24.100"
+      }
+    ],
+    "imsid": 747907,
+    "monitored": true,
+    "name": "MREN-AP1",
+    "scid": "0e27c49e-a0be-4ef6-a475-71c577f55699",
+    "service_type": "GEANT IP",
+    "sid": "GS-00491",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662181,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-006(ETH)",
+    "scid": "0e2f1da9-1a73-42b0-9c21-41a3abbd552d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01612",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AZSCIENCENET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.25/30",
+          "2001:798:99:1::bd/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae37.300"
+      }
+    ],
+    "imsid": 743174,
+    "monitored": true,
+    "name": "AZSCIENCENET-AP1",
+    "scid": "0e97e70c-3353-4ef0-b05f-6c1e21052088",
+    "service_type": "GEANT IP",
+    "sid": "GS-00433",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.165/30",
+          "2001:798:28:10aa::5/126"
+        ],
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-21.100"
+      }
+    ],
+    "imsid": 745492,
+    "monitored": true,
+    "name": "CYNET-AP2",
+    "scid": "0ea95cc4-55c2-4e50-a405-c1b993755b3e",
+    "service_type": "GEANT IP",
+    "sid": "GS-00450",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 719095,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-1GBE-001(GEANT)",
+    "scid": "0ec30407-bb41-43d1-9d34-e7539ab1005a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01544",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 710811,
+    "monitored": true,
+    "name": "BUC-FRA-LAG",
+    "scid": "0edad487-ae52-4be0-9bcd-336f39549faa",
+    "service_type": "ETHERNET",
+    "sid": "GA-01994",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ASNET-AM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.169/30",
+          "2001:798:1::20d/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae17.333"
+      }
+    ],
+    "imsid": 732137,
+    "monitored": true,
+    "name": "ASNET-AM-AP1-IAS",
+    "scid": "0ee19262-9795-47c6-b7ac-1a2f3c894857",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00555",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "2001:798:99:1::11/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae13.106"
+      }
+    ],
+    "imsid": 730142,
+    "monitored": true,
+    "name": "UK-ESNET-IPV6",
+    "scid": "0f093fc1-e929-41e9-b8eb-fa2d70ac2b41",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00916",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.3005"
+      }
+    ],
+    "imsid": 712562,
+    "monitored": false,
+    "name": "RARE-POZ-PIONIER",
+    "scid": "0f136d4a-0241-4fe8-8a46-4f1bed094ae9",
+    "service_type": "L2SERVICES",
+    "sid": "GS-00777",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.168/31",
+          "2001:798:99:1::9d/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.610"
+      }
+    ],
+    "imsid": 660557,
+    "monitored": true,
+    "name": "FR-CLARA",
+    "scid": "0fc19f48-bb6c-4c4d-b436-c3dc3a48a540",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00883",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae10.2803"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.2705"
+      }
+    ],
+    "imsid": 738292,
+    "monitored": true,
+    "name": "PSNC-KIFU-SLICES-SZTAKI",
+    "scid": "0fdae68c-6cc3-43bb-815e-eaf867d1e0fa",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02491",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 712377,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-FUNET-1-FI",
+    "scid": "104f1e3d-930f-4660-9283-30644ccaf6b4",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01019",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 744013,
+    "monitored": true,
+    "name": "BRU-PAR-LAG",
+    "scid": "10751c15-60e4-4d6c-b68d-c679dd2e0e46",
+    "service_type": "ETHERNET",
+    "sid": "GA-02279",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662948,
+    "monitored": false,
+    "name": "FRA-GROOVE-3-MANAGEMENT",
+    "scid": "1077f9ee-b368-40f2-9e23-0d051e0140c3",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00177",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.28/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.19"
+      }
+    ],
+    "imsid": 732660,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-UWSSEC",
+    "scid": "108e3f34-cbb9-400f-943a-c2c33c988be9",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01090",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [],
+    "imsid": 730101,
+    "monitored": false,
+    "name": "CARNET-BGP-LU-COC-AP2",
+    "scid": "1091466c-e8c8-490c-aeb3-c8d7db6baf2c",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01000",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.20/31",
+          "2001:798:cc::21/126"
+        ],
+        "hostname": "rt0.ams.nl.geant.net",
+        "interface": "lag-8.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.21/31",
+          "2001:798:cc::22/126"
+        ],
+        "hostname": "rt0.fra.de.geant.net",
+        "interface": "lag-8.0"
+      }
+    ],
+    "imsid": 739045,
+    "monitored": true,
+    "name": "AMS-FRA-IPTRUNK",
+    "scid": "109a7ad9-69cd-4d29-abee-b4af6e73088a",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00009",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 717027,
+    "monitored": true,
+    "name": "DCN-LJU-SI-MGT-GRV1",
+    "scid": "109f280f-9b0d-47e1-97d3-dca3784764f9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01670",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658693,
+    "monitored": false,
+    "name": "730XD-4-VM-TRAFFIC-LAG-PAR",
+    "scid": "10a3a561-cc3f-4329-a154-67f8b8917b09",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01726",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "WIX"
+    ],
+    "endpoints": [],
+    "imsid": 736740,
+    "monitored": false,
+    "name": "WIX-TO-NETHERLIGHT-TEST",
+    "scid": "10a5b5f8-caca-4c0b-8365-58b8878dc536",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00766",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/1/5"
+      }
+    ],
+    "imsid": 658954,
+    "monitored": true,
+    "name": "100G TESTING FROM JODRELL BANK DTN SERVERS",
+    "scid": "10b9013d-7a86-4f9d-b80e-8e7501d8cf0f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01448",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FACEBOOK"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "157.240.84.29/31",
+          "2620:0:1cff:dead:beee::10ff/127"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae46.0"
+      }
+    ],
+    "imsid": 737794,
+    "monitored": true,
+    "name": "FACEBOOK-32934-FRA-PCDE-90606624",
+    "scid": "10c61e08-bc5f-48a8-9872-53dfffeaf984",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-02483",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/1/6"
+      }
+    ],
+    "imsid": 659284,
+    "monitored": true,
+    "name": "LONDON-LONDON-10GBE-038(ETH)",
+    "scid": "10c8a3ba-1aea-4a22-abdb-bdb13860061f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01454",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.104.249/29",
+          "2001:798:bb:4d::1/64"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/2.3007"
+      }
+    ],
+    "imsid": 679409,
+    "monitored": false,
+    "name": "INFOBLOX-TRINZIC805-LON2-VLAN3007",
+    "scid": "10d47d94-39d8-4984-8430-300f642e8488",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00204",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "addresses": [
+          "10.0.0.3/28"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "irb.3006"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30.3006"
+      }
+    ],
+    "imsid": 712153,
+    "monitored": false,
+    "name": "TAAS-CONTROL-IMS-MEDIATION-LOGICAL-INTERFACE-PAR-FR",
+    "scid": "10d82154-1a1c-420d-9198-9980c7edc9d7",
+    "service_type": "L3-VPN",
+    "sid": "GS-00863",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ge-0/3/2.26"
+      }
+    ],
+    "imsid": 718926,
+    "monitored": false,
+    "name": "DDOS-DET2-VIE-AT-IDRAC",
+    "scid": "10ef9e9f-18f3-4bb5-acd9-2eefe1fe8947",
+    "service_type": "SERVER LINK",
+    "sid": "GS-01175",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661951,
+    "monitored": false,
+    "name": "TAAS-GTS-CONTROL-1",
+    "scid": "10f1969a-26f2-4d9d-9a8a-854a54287201",
+    "service_type": "GTS",
+    "sid": "GS-01189",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 719100,
+    "monitored": true,
+    "name": "KAUNAS-KAUNAS-LAG-001(GEANT)",
+    "scid": "113f0c13-600a-410b-a33e-652e7d73caa1",
+    "service_type": "ETHERNET",
+    "sid": "GA-02022",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [],
+    "imsid": 662965,
+    "monitored": true,
+    "name": "HEANET-BGP-LU-COC-AP1",
+    "scid": "11673041-e2ea-4d93-b42c-2093c020dbe3",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01008",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [],
+    "imsid": 662488,
+    "monitored": true,
+    "name": "RENATER-AP2-LAG",
+    "scid": "116d56e5-ff31-4b49-8e19-423ddb28252f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01884",
+    "speed": 429496729600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [],
+    "imsid": 712389,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-HEANET-IE-(RR1-CWT.HEA.NET)",
+    "scid": "11878b25-2feb-4dc1-8f6e-23684539c8ba",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01024",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RESTENA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.117/30",
+          "2001:798:18:10aa::19/126"
+        ],
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-22.2603"
+      }
+    ],
+    "imsid": 744073,
+    "monitored": true,
+    "name": "RESTENA-AP2",
+    "scid": "1195ba87-e0a8-4c03-845e-0bc0f7d58b85",
+    "service_type": "GEANT IP",
+    "sid": "GS-00508",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-25"
+      }
+    ],
+    "imsid": 747896,
+    "monitored": true,
+    "name": "KREN-AP1-LAG",
+    "scid": "119f7bbd-04ad-44cd-8d75-0293adc8dd8a",
+    "service_type": "ETHERNET",
+    "sid": "GA-02154",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 740750,
+    "monitored": true,
+    "name": "VIE-VIE-LAG",
+    "scid": "11b6f82c-1b42-440c-bf6f-0378acbf2088",
+    "service_type": "ETHERNET",
+    "sid": "GA-02561",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/1/4.1630"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-123079"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-22:1630"
+      }
+    ],
+    "imsid": 745435,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-ETHS-002(GRNET)",
+    "scid": "1229a60e-761c-4004-b2a8-bd68903e764f",
+    "service_type": "ETHERNET",
+    "sid": "GS-02381",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.22/31",
+          "2001:798:111:1::b1/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae20.200"
+      }
+    ],
+    "imsid": 734869,
+    "monitored": true,
+    "name": "NL-SINET-LHCONE",
+    "scid": "123790a1-ef34-4cb0-b9af-e19bbe8aa9eb",
+    "service_type": "L3-VPN",
+    "sid": "GS-00840",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707412,
+    "monitored": true,
+    "name": "KAU-KAU-LAG",
+    "scid": "123c47a1-01a1-4148-8340-e431b44f4da2",
+    "service_type": "ETHERNET",
+    "sid": "GA-02020",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661177,
+    "monitored": false,
+    "name": "PS-MAD-ES-IDRAC",
+    "scid": "12916de8-dc3e-49e2-96aa-62a3ca5c28d2",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00328",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "64.57.30.228/28",
+          "2001:468:ef00:4000::3/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.2001"
+      }
+    ],
+    "imsid": 660639,
+    "monitored": true,
+    "name": "INTERNET2-PAR-LHCONE",
+    "scid": "12c941e1-5224-453d-a807-40646b215c44",
+    "service_type": "L3-VPN",
+    "sid": "GS-00831",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.38/31",
+          "2001:798:111:1::d1/126"
+        ],
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae11.2018"
+      }
+    ],
+    "imsid": 713840,
+    "monitored": true,
+    "name": "REDCLARA-LIS-LHCONE",
+    "scid": "1300b831-c1bd-49cb-92a8-f93241c20a31",
+    "service_type": "L3-VPN",
+    "sid": "GS-00848",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "LON01-GRV4",
+        "port": "1/3/8"
+      },
+      {
+        "equipment": "GEN02-GRV-2",
+        "port": "1/3/8"
+      }
+    ],
+    "imsid": 730122,
+    "monitored": true,
+    "name": "GEN2-LON1-EEX-ESNET-2373-2-400G",
+    "scid": "1322b791-7bef-4d5a-a8c8-0ee9185cbeef",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02335",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660554,
+    "monitored": false,
+    "name": "PRA-GROOVE-2-MANAGEMENT",
+    "scid": "132e2a10-8c8d-42d3-a663-188b23d9fc40",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00282",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "LITNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.kau.lt.geant.net",
+        "interface": "lag-21"
+      }
+    ],
+    "imsid": 746519,
+    "monitored": true,
+    "name": "LITNET-AP1-LAG",
+    "scid": "134acb33-59e6-4661-9677-fbbebab12a47",
+    "service_type": "ETHERNET",
+    "sid": "GA-02042",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [],
+    "imsid": 669120,
+    "monitored": false,
+    "name": "AMS-LON1-EEX-ESNET-1424",
+    "scid": "136087f3-00f6-4e3c-ae61-343625d9a597",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-00781",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 724091,
+    "monitored": true,
+    "name": "ETHS-MX1.PAR.FR_GE-0/2/0.24",
+    "scid": "13739414-948e-4434-96ae-e23eca7b7446",
+    "service_type": "ETHERNET",
+    "sid": "GS-00341",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CANARIE"
+    ],
+    "endpoints": [],
+    "imsid": 660632,
+    "monitored": false,
+    "name": "FR-CANARIE-VLAN205",
+    "scid": "13a94119-3b3c-46ae-8977-0813a60c55f1",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00882",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 730602,
+    "monitored": true,
+    "name": "COR-COR-IPTRUNK",
+    "scid": "13cf9ebd-a070-4fa4-9b02-8f15874dbe49",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02403",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658824,
+    "monitored": true,
+    "name": "VIENNA-VIENNA-1GBE-004(ETH)",
+    "scid": "13ef6c2d-ec68-4d74-a9a3-c104560d7a25",
+    "service_type": "ETHERNET",
+    "sid": "GA-01484",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661236,
+    "monitored": false,
+    "name": "PS-POZ-PL-IDRAC",
+    "scid": "13ef8f22-624b-4e80-86f2-9079eecc46bc",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00344",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "MARNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-22"
+      }
+    ],
+    "imsid": 744884,
+    "monitored": true,
+    "name": "MARNET-AP1-LAG",
+    "scid": "1409a504-c174-4e78-8ed3-aaa28584bb3b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01732",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "UBUNTUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.253/30",
+          "2001:798:28:10aa::d/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/3/2.100"
+      }
+    ],
+    "imsid": 661682,
+    "monitored": true,
+    "name": "UK-UBUNTUNET",
+    "scid": "14199cf2-5738-4ccc-abf3-4916baacaf21",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00909",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/2"
+      }
+    ],
+    "imsid": 659071,
+    "monitored": true,
+    "name": "MX1.LON2-EX1.LON2-10GBE-001(GEANT)",
+    "scid": "141d138b-5203-4e54-9cac-b4d66add1a62",
+    "service_type": "ETHERNET",
+    "sid": "GA-01317",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.181/30",
+          "2001:798:1e:10aa::15/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae12.1000"
+      }
+    ],
+    "imsid": 663180,
+    "monitored": true,
+    "name": "GARR-AP2",
+    "scid": "14555551-3ce4-4e4d-bfbf-56de8205284e",
+    "service_type": "GEANT IP",
+    "sid": "GS-00463",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 719798,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-020(GEANT)",
+    "scid": "146c803c-128c-4aa8-bd90-ffef012b22c4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01390",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "T-SYSTEMS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "80.158.74.243/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae21.4003"
+      }
+    ],
+    "imsid": 727979,
+    "monitored": true,
+    "name": "DE-T-SYSTEMS-COPERNICUS",
+    "scid": "14b798af-d52a-4ebc-a06b-175210a878bc",
+    "service_type": "L3-VPN",
+    "sid": "GS-02332",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.5/30"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.6"
+      }
+    ],
+    "imsid": 732674,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-ECMWF2",
+    "scid": "14d6c05d-4621-47d0-9705-2b50a5ba2607",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01077",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/5"
+      }
+    ],
+    "imsid": 726765,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-016(GEANT)",
+    "scid": "1501ff8b-841c-436a-91be-37b2d88552a5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01464",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ULAKBIM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.165/30",
+          "2001:798:1::c9/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-23.333"
+      }
+    ],
+    "imsid": 745011,
+    "monitored": true,
+    "name": "ULAKBIM-AP2-IAS",
+    "scid": "1510f7a6-b938-4e27-823c-24e2867c1f5b",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00592",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.6"
+      },
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.408"
+      }
+    ],
+    "imsid": 707129,
+    "monitored": true,
+    "name": "REDIRIS-USC-EXPRESSROUTE-VLAN408",
+    "scid": "1518a76a-101a-4910-a4a2-330c40eee2bd",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01165",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662213,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-046(ETH)",
+    "scid": "152c064c-7da2-4f61-b240-e83a8ea47a11",
+    "service_type": "ETHERNET",
+    "sid": "GA-01628",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 736810,
+    "monitored": true,
+    "name": "AMS2-LON-AMT-LAG",
+    "scid": "1531ae5c-19ba-4361-b673-b61598c7edc6",
+    "service_type": "ETHERNET",
+    "sid": "GA-02036",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 707340,
+    "monitored": true,
+    "name": "LIS-POR-LAG",
+    "scid": "15376a6e-7742-4bdd-83ad-dea544b6fc4f",
+    "service_type": "ETHERNET",
+    "sid": "GA-02029",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "T-SYSTEMS"
+    ],
+    "endpoints": [],
+    "imsid": 708765,
+    "monitored": false,
+    "name": "NL-T-SYSTEMS-IAS-2",
+    "scid": "15401883-0c9b-4993-a48b-5795393cef1f",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00941",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.vie.at.geant.net",
+        "interface": "lag-5"
+      }
+    ],
+    "imsid": 740749,
+    "monitored": true,
+    "name": "PRA-VIE-LAG",
+    "scid": "15597b53-1a55-43ff-a666-fb4e11eeaee8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01858",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [],
+    "imsid": 705461,
+    "monitored": false,
+    "name": "GEN-LON-SYNGENTA-SWITCH-JISC-17041",
+    "scid": "156b6a44-9b3c-41d5-beef-8d159cbd8424",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00712",
+    "speed": 858993459200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663119,
+    "monitored": false,
+    "name": "HADES-GEN-CH-DRAC",
+    "scid": "157d11e1-1469-4f98-8dd4-5c68b91601e3",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00194",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "xe-3/0/0"
+      }
+    ],
+    "imsid": 662292,
+    "monitored": true,
+    "name": "BUDAPEST-BUDAPEST-10GBE-009(GEANT)",
+    "scid": "15aa7807-f05c-4854-9150-acb496c3159e",
+    "service_type": "ETHERNET",
+    "sid": "GA-02126",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.60/31",
+          "2001:798:cc::65/126"
+        ],
+        "hostname": "rt0.lon.uk.geant.net",
+        "interface": "lag-1.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.61/31",
+          "2001:798:cc::66/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae3.0"
+      }
+    ],
+    "imsid": 738586,
+    "monitored": true,
+    "name": "LON-LON-IPTRUNK",
+    "scid": "15bfb61a-861f-426d-be13-45eb31eb3ec5",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02467",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "SWITCH-AMS-IX 1GE",
+    "scid": "15c78ea0-2891-403b-b98c-70bd358280c3",
+    "service_type": null,
+    "sid": "DS-09100",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ge-0/3/2.22"
+      }
+    ],
+    "imsid": 661652,
+    "monitored": false,
+    "name": "OWAMP-VIE-AT",
+    "scid": "15d0517d-c473-46e6-9aeb-3439f95ef572",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00271",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.13"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4091"
+      }
+    ],
+    "imsid": 739679,
+    "monitored": true,
+    "name": "BELNET-ICT-EXPRESSROUTE-VLAN4091",
+    "scid": "15dd84bd-3042-4734-8d9b-d110596e9875",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01125",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.81/30",
+          "2001:798:18:10aa::d/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae13.100"
+      }
+    ],
+    "imsid": 661602,
+    "monitored": true,
+    "name": "SWITCH-AP2",
+    "scid": "15e11dd8-fa00-4e14-8bfd-2604b83f3791",
+    "service_type": "GEANT IP",
+    "sid": "GS-00515",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURFNET"
+    ],
+    "endpoints": [],
+    "imsid": 709832,
+    "monitored": true,
+    "name": "SURFNET EUMETCAST AP2",
+    "scid": "1603dac6-4682-44a9-8962-66a270bffc81",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01119",
+    "speed": 53687091200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae20.3019"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae2.3019"
+      }
+    ],
+    "imsid": 740719,
+    "monitored": false,
+    "name": "AMS-LON-SINET-SD-WAN-SINET-SINET-17088",
+    "scid": "16476b10-e427-481f-b082-4a21bd54bc67",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00649",
+    "speed": 236223201280,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658862,
+    "monitored": true,
+    "name": "PARIS-PSMP-LHC-OWAMP-1GBE-003(ETH)",
+    "scid": "1648a6ad-ed35-4bd0-9d6c-6a15b95c301f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01404",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.980"
+      },
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:2104"
+      }
+    ],
+    "imsid": 747543,
+    "monitored": true,
+    "name": "HAM-MAD-02516",
+    "scid": "16644def-bcc6-4588-ad2f-e5c179d676d9",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02516",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.4/31",
+          "2001:798:1::129/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae18.0"
+      }
+    ],
+    "imsid": 708242,
+    "monitored": true,
+    "name": "FACEBOOK-32934-LON-FC-26603",
+    "scid": "166d1c29-be89-44fb-82ae-4e57beb948aa",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00931",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.81/30",
+          "2001:798:1::65/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae10.333"
+      }
+    ],
+    "imsid": 663070,
+    "monitored": true,
+    "name": "KIFU-AP1-IAS",
+    "scid": "167e7247-a2ff-42dc-973d-da88fce9b5dd",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00575",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.gen.ch - Traffic - et-1/0/5 - PHY CUSTOMER SWITCH SRF19136 $GA-02133 |",
+    "scid": "16a3f2f6-98bf-4443-a958-4c813d7a103f",
+    "service_type": null,
+    "sid": "GA-02133",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.123.225/29",
+          "2001:798:bb:47::1/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-11/2/0.100"
+      }
+    ],
+    "imsid": 678071,
+    "monitored": false,
+    "name": "DTN-PAR-10G-DATA",
+    "scid": "16b8d896-9d4a-403f-9cc5-f087a3137a68",
+    "service_type": "SERVER LINK",
+    "sid": "GS-02375",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661192,
+    "monitored": false,
+    "name": "PS-MIL2-IT-IDRAC",
+    "scid": "16bea68d-5640-4400-b22d-2b9932f7ceb0",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00335",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "URAN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "xe-0/1/3"
+      },
+      {
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "xe-0/1/2.0"
+      },
+      {
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "xe-0/1/3.0"
+      }
+    ],
+    "imsid": 723461,
+    "monitored": false,
+    "name": "CHI-KIE-EAP-RENAM-URAN-22087",
+    "scid": "16c14584-c205-4c28-85da-ed53bfed4f0e",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-02212",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ge-0/2/7"
+      }
+    ],
+    "imsid": 669119,
+    "monitored": true,
+    "name": "ESNET OOB IP 1G LINK LL",
+    "scid": "16cabefa-bd92-43cc-b619-64fdb71e0efe",
+    "service_type": "ETHERNET",
+    "sid": "GA-01474",
+    "speed": 0,
+    "status": "terminated"
+  },
+  {
+    "customers": [
+      "AZSCIENCENET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-11/3/2.0"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae37.220"
+      }
+    ],
+    "imsid": 723801,
+    "monitored": true,
+    "name": "FRA-FRA-EAP-AZSCIENCENET-CL-190961",
+    "scid": "16db554a-970f-450c-8a43-82ba1f91b0e6",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00694",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.pra.cz.geant.net",
+        "interface": "lag-7"
+      }
+    ],
+    "imsid": 740493,
+    "monitored": true,
+    "name": "POZ-PRA-LAG",
+    "scid": "16e502b0-920a-4640-9ef1-2a8096549750",
+    "service_type": "ETHERNET",
+    "sid": "GA-02409",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.37/30"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.0"
+      }
+    ],
+    "imsid": 732670,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-NOAA",
+    "scid": "172d87f3-530c-4232-ba67-6f52e5f96274",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01086",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "2001:798:111:1::3d/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.4005"
+      }
+    ],
+    "imsid": 661712,
+    "monitored": true,
+    "name": "NORDUNET-LON-IPV6-LHCONE",
+    "scid": "17380d2a-e6f5-4ed9-abb1-b8663ead67a0",
+    "service_type": "L3-VPN",
+    "sid": "GS-00842",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ASGC"
+    ],
+    "endpoints": [],
+    "imsid": 662982,
+    "monitored": false,
+    "name": "NL-ASGC-LHCONE",
+    "scid": "175bc5ea-613b-43f4-be27-d3b21b31527d",
+    "service_type": "L3-VPN",
+    "sid": "GS-00834",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/0/2"
+      }
+    ],
+    "imsid": 658710,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-049(ETH)",
+    "scid": "176feff7-9335-4f01-a527-da9957f620f3",
+    "service_type": "ETHERNET",
+    "sid": "GA-02284",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ACONET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae15"
+      }
+    ],
+    "imsid": 659350,
+    "monitored": true,
+    "name": "ACONET-AP1-LAG",
+    "scid": "1777015a-4a61-4db2-ab7b-3d51c51b72c8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01864",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-724045"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:3503"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.2701"
+      }
+    ],
+    "imsid": 745318,
+    "monitored": true,
+    "name": "GEANT_EPIPE_724045",
+    "scid": "1791eae3-5f75-43d0-996a-e2e149477442",
+    "service_type": "ETHERNET",
+    "sid": "GS-02486",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 677550,
+    "monitored": true,
+    "name": "BRU OOB LINK",
+    "scid": "17933f8d-c4ce-4c64-acd6-5bcc84ef7179",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00393",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [],
+    "imsid": 734868,
+    "monitored": true,
+    "name": "FR-INTERNET2-2",
+    "scid": "17db22a1-1769-4221-8e63-c877ad253d5e",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00920",
+    "speed": 429496729600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.POR.PT",
+        "port": "AE1"
+      }
+    ],
+    "imsid": 709379,
+    "monitored": true,
+    "name": "LAG-SW1.POR.PT_AE1",
+    "scid": "1847e585-c68a-4d7d-8973-44388e22a6e3",
+    "service_type": "ETHERNET",
+    "sid": "GA-02060",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.221/31",
+          "2001:798:cc:1::72/126"
+        ],
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae2.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.220/31",
+          "2001:798:cc:1::71/126"
+        ],
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae2.0"
+      }
+    ],
+    "imsid": 709122,
+    "monitored": true,
+    "name": "BIL-POR-IPTRUNK",
+    "scid": "187ba847-387a-4e22-9264-3cf431bce396",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00017",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "TENET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.164/31",
+          "2001:798:99:1::105/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae24.100"
+      }
+    ],
+    "imsid": 732999,
+    "monitored": true,
+    "name": "NL-TENET",
+    "scid": "1899bd82-2345-4f25-b429-64871446c65b",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-01182",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.168/31",
+          "2001:798:0:1::1a/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae28.2063"
+      }
+    ],
+    "imsid": 720026,
+    "monitored": true,
+    "name": "REDCLARA-TENET-LON-COPERNICUS",
+    "scid": "18aab95f-bcf9-4ed4-934f-129083d5823a",
+    "service_type": "L3-VPN",
+    "sid": "GS-02168",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [],
+    "imsid": 719538,
+    "monitored": true,
+    "name": "FRA-MAD-ORACLE-REDIRIS-21051-VL682",
+    "scid": "18c313d3-ecd2-416c-ab3d-9f136cd3667b",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00702",
+    "speed": 343597383680,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.201/30",
+          "2001:798:28:10aa::9/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.0"
+      }
+    ],
+    "imsid": 739643,
+    "monitored": true,
+    "name": "BELNET-AP2",
+    "scid": "18d4726a-65ef-42a5-ac74-503469d02b14",
+    "service_type": "GEANT IP",
+    "sid": "GS-00436",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ACONET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.52/31",
+          "2001:798::65/126"
+        ],
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "ae18.667"
+      }
+    ],
+    "imsid": 661319,
+    "monitored": true,
+    "name": "ACONET-AP2-CLS",
+    "scid": "18d81cab-a8c6-4c9e-ac5e-9935ad11c2c4",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00596",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [],
+    "imsid": 733113,
+    "monitored": false,
+    "name": "FRA-GEN-CERN-DFN-1",
+    "scid": "18f6ce8e-9d5e-457a-9c14-d24fc04bd593",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02443",
+    "speed": 536870912000,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.206/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.22"
+      }
+    ],
+    "imsid": 732672,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-DMI",
+    "scid": "1906b294-314f-4feb-84f2-a75af3a64a75",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-02172",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662936,
+    "monitored": false,
+    "name": "RHPS02-DUB-IE-VLAN120",
+    "scid": "1910c904-4385-4018-b7be-3b392cf31554",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00370",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.3.1/24"
+        ],
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae1.103"
+      }
+    ],
+    "imsid": 709868,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-BIL-ES",
+    "scid": "192b2225-8d32-4244-a9ba-e19e9d4273b5",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00116",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ASNET-AM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.29/30",
+          "2001:798:99:1::5d/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae17.200"
+      }
+    ],
+    "imsid": 732136,
+    "monitored": true,
+    "name": "ASNET-AM-AP1",
+    "scid": "19411b00-b039-4b1a-8c37-7bbfed9c31ef",
+    "service_type": "GEANT IP",
+    "sid": "GS-00430",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663085,
+    "monitored": false,
+    "name": "IPCAMERA-AMS-NL-VLAN170",
+    "scid": "19585925-3ae5-40cc-8cdf-f1983a511ee2",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00207",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "BUD-FRA-TRUNK",
+    "scid": "19613b5d-2023-48a7-83ed-28ed29bee664",
+    "service_type": null,
+    "sid": "DS-29947",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 713094,
+    "monitored": true,
+    "name": "CHI-KIE-LAG",
+    "scid": "196accbc-ea01-42d8-9b12-137606d287f2",
+    "service_type": "ETHERNET",
+    "sid": "GA-02048",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.39"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-124004"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4066"
+      }
+    ],
+    "imsid": 744145,
+    "monitored": true,
+    "name": "MSERVAONEM-02431",
+    "scid": "19929b39-8a7b-4f4a-9194-4dfbdc9d897a",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02431",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [],
+    "imsid": 712561,
+    "monitored": true,
+    "name": "FCCN-BGP-LU-COC-AP2",
+    "scid": "19952156-52cb-496f-9dd1-64916a1acdfc",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01004",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "RedIRIS-SUNET-SST-VPN-Proxy-Marseille-L2VPN",
+    "scid": "19c80ab1-8e8a-45af-a978-f1420c6e6f74",
+    "service_type": null,
+    "sid": "DS-43001",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.28"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-230861"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4065"
+      }
+    ],
+    "imsid": 744236,
+    "monitored": true,
+    "name": "MSEONDD-02389",
+    "scid": "19d57a2e-2063-4b30-b5ee-d5c8a3e4ef54",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02389",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 702111,
+    "monitored": true,
+    "name": "BRU-LON-LAG",
+    "scid": "19dea4a9-3bee-47ae-bb81-a75290e98ec7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01793",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679316,
+    "monitored": false,
+    "name": "NE-ESXI-VMNETWORK-PAR-FR",
+    "scid": "19f33c06-68af-4049-8432-8f5e5e201784",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00255",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [],
+    "imsid": 709761,
+    "monitored": true,
+    "name": "PIONIER EUMETCAST AP2",
+    "scid": "1a076782-98c0-4e14-af20-81e284d83f82",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01115",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663181,
+    "monitored": false,
+    "name": "PS-HAM-DE-MANAGEMENT",
+    "scid": "1a204237-7ccd-4ed1-b093-cdd77e72c38a",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00311",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "XE-0/2/0"
+      }
+    ],
+    "imsid": 658390,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-10GBE-001(ETH)",
+    "scid": "1a260c62-3f79-416c-881f-bdb6063929ad",
+    "service_type": "ETHERNET",
+    "sid": "GA-01278",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SANET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae13.422"
+      },
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae15.422"
+      }
+    ],
+    "imsid": 729694,
+    "monitored": true,
+    "name": "BRA-VIE-ACONET-SANET",
+    "scid": "1a41ae31-c0ed-4056-9127-f7f2570d53a1",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02379",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 721146,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-003(GEANT)",
+    "scid": "1a4f834f-517d-40bd-b8fa-0bef20c65d81",
+    "service_type": "ETHERNET",
+    "sid": "GA-01396",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "REDIRIS-AP1-LHCONE",
+    "scid": "1a58782b-8f0c-468d-9075-c48bd04525ba",
+    "service_type": null,
+    "sid": "GS-00851",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.37"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-123071"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4064"
+      }
+    ],
+    "imsid": 744141,
+    "monitored": true,
+    "name": "MSENCCN-02370",
+    "scid": "1a6b5d97-f769-43cd-b75f-ba5346b13fc0",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02370",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "fra-par_MPVPN_DFN-RENATER_13003",
+    "scid": "1a80f395-8678-4004-a3b7-a84c2180d138",
+    "service_type": null,
+    "sid": "DS-28708",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae12.0 - eumet"
+      }
+    ],
+    "imsid": 709758,
+    "monitored": true,
+    "name": "JISC EUMETCAST AP2",
+    "scid": "1ab4705c-1745-441c-91d6-6091a2ab8d93",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01110",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RARE"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-0"
+      },
+      {
+        "equipment": "PF1-RARE.FRA.DE.GEANT.NET",
+        "port": "XE-0"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/0.0"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/1.0"
+      }
+    ],
+    "imsid": 736076,
+    "monitored": false,
+    "name": "AMS-FRA-RARE-P4-9951375",
+    "scid": "1b022417-5e87-42e4-9f84-f2637a1e2d05",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00635",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707224,
+    "monitored": false,
+    "name": "LON2-GROOVE",
+    "scid": "1b1fcc38-f9b9-4e01-89b0-0f9df06cf5c3",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00237",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.buc.ro.geant.net",
+        "interface": "ae5"
+      }
+    ],
+    "imsid": 744731,
+    "monitored": true,
+    "name": "BUC2-CHI-LAG",
+    "scid": "1b3404b0-f271-4ab6-b084-d126f781adb3",
+    "service_type": "ETHERNET",
+    "sid": "GA-02003",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae13.3005"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.3507"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae13.3507"
+      }
+    ],
+    "imsid": 712157,
+    "monitored": false,
+    "name": "RARE-PAR-SWITCH",
+    "scid": "1b5480d9-80fa-4ce5-be46-a5ba2d343b39",
+    "service_type": "L2SERVICES",
+    "sid": "GS-00774",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.41/30",
+          "2001:798:111:1::c1/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae21.110"
+      }
+    ],
+    "imsid": 701612,
+    "monitored": true,
+    "name": "CERN-GEN-LHCONE-2",
+    "scid": "1b595534-bf95-4045-a5c3-3ed6c179ba0c",
+    "service_type": "L3-VPN",
+    "sid": "GS-00812",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.67.72.70/30",
+          "2001:1900:5:2:2:0:8:852e/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae29.0"
+      }
+    ],
+    "imsid": 732143,
+    "monitored": true,
+    "name": "COLT-GWS-FRA",
+    "scid": "1b5e2ca1-168b-4beb-a65f-3c46d8be4f66",
+    "service_type": "GWS - UPSTREAM",
+    "sid": "GS-00069",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-6"
+      }
+    ],
+    "imsid": 738857,
+    "monitored": true,
+    "name": "COR-LON2-LAG",
+    "scid": "1b5ed316-dd35-4c6b-9898-29bc24be3450",
+    "service_type": "ETHERNET",
+    "sid": "GA-02388",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 713324,
+    "monitored": true,
+    "name": "KIE-KIE-LAG",
+    "scid": "1b9cb927-8e22-4b7b-8525-f1350ed1886e",
+    "service_type": "ETHERNET",
+    "sid": "GA-02045",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662210,
+    "monitored": true,
+    "name": "SOFIA-SOFIA-1GBE-004(ETH)",
+    "scid": "1b9d776c-ea65-4af5-a776-8aa29ffa25f3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01248",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae8"
+      }
+    ],
+    "imsid": 736810,
+    "monitored": true,
+    "name": "AMS2-LON-AMT-LAG",
+    "scid": "1bd07732-d4af-4e17-94f3-b1f826937ab6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01834",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658950,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-1GBE-009(ETH)",
+    "scid": "1bd3ec14-d879-4941-86f2-d855935f4e56",
+    "service_type": "ETHERNET",
+    "sid": "GA-01437",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.252/31",
+          "2001:798:cc:1::10d/126"
+        ],
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae8.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.253/31",
+          "2001:798:cc:1::10e/126"
+        ],
+        "hostname": "rt0.vie.at.geant.net",
+        "interface": "lag-8.0"
+      }
+    ],
+    "imsid": 740792,
+    "monitored": true,
+    "name": "BRA-VIE-IPTRUNK",
+    "scid": "1be23e35-d3d5-4aff-b48b-5d491fb9dff2",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00019",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.253/30",
+          "2001:798:1::105/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae11.333"
+      }
+    ],
+    "imsid": 660399,
+    "monitored": true,
+    "name": "SURF-AP2-IAS",
+    "scid": "1bec2d3e-df91-4002-acd8-9ec061c1b85c",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00588",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 719629,
+    "monitored": false,
+    "name": "UAT-TEST-INFRASTRUCTURE",
+    "scid": "1c060413-855e-495d-b578-22b671721eec",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-11114",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/1/7"
+      }
+    ],
+    "imsid": 732315,
+    "monitored": true,
+    "name": "FRANKFURT 15-FRANKFURT 15-10GBE-052(GEANT)",
+    "scid": "1c1ff9c5-79ec-409c-9986-133ea9923853",
+    "service_type": "ETHERNET",
+    "sid": "GA-02197",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663199,
+    "monitored": false,
+    "name": "PS-HAM-DE-IDRAC",
+    "scid": "1c3bf704-37bb-47fc-aabb-c71f6a0ea2fa",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00310",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "TENET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-4/1/4.201"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae28.201"
+      }
+    ],
+    "imsid": 738644,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-ESNET-TENET-180871",
+    "scid": "1c3d5086-6663-42a8-9a0b-59ff278af1d4",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00966",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "URAN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.44/31",
+          "2001:798:111:1::d5/126"
+        ],
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "ae10.360"
+      }
+    ],
+    "imsid": 714003,
+    "monitored": true,
+    "name": "URAN-AP2-LHCONE",
+    "scid": "1c5bbd17-a4f2-4284-bb8b-ce0127edbd23",
+    "service_type": "L3-VPN",
+    "sid": "GS-00871",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/4"
+      }
+    ],
+    "imsid": 732982,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-022(GEANT)",
+    "scid": "1c8039f6-3f5e-4d28-b082-5a304bd02f8d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01333",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 739463,
+    "monitored": true,
+    "name": "BIL-PAR-LAG",
+    "scid": "1caee5e3-485a-4fe8-b0c1-2993bfe84943",
+    "service_type": "ETHERNET",
+    "sid": "GA-01969",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 717715,
+    "monitored": true,
+    "name": "NE-ESXI-PROD-FRA-1 VMNIC0",
+    "scid": "1cc6ce60-6064-4f03-9359-72291101eb67",
+    "service_type": "ETHERNET",
+    "sid": "GA-01619",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 727420,
+    "monitored": true,
+    "name": "V-LAN_1004_RT2.BRU.BE_XE-0/1/0_",
+    "scid": "1cdcadd8-99fb-4cf7-aea0-e409f5650b5a",
+    "service_type": "ETHERNET",
+    "sid": "GS-00677",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "URAN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 713996,
+    "monitored": true,
+    "name": "URAN-AP2-LAG",
+    "scid": "1d343d79-0dbf-4e8b-8e1e-f3e586fe6c0b",
+    "service_type": "ETHERNET",
+    "sid": "GA-02046",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 746301,
+    "monitored": true,
+    "name": "HAM-TAR-LAG",
+    "scid": "1d8c3a7d-c23f-4c26-87a1-7e7d880631a5",
+    "service_type": "ETHERNET",
+    "sid": "GA-02350",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658888,
+    "monitored": true,
+    "name": "LONDON-LONDON-10GBE-013(ETH)",
+    "scid": "1db5425e-be79-4e74-a0dd-4165f4b1087e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01533",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae21"
+      }
+    ],
+    "imsid": 728435,
+    "monitored": true,
+    "name": "COLT-GWS-BUD-LAG",
+    "scid": "1dd01503-0e23-46b7-b4c8-056ca91ca1a1",
+    "service_type": "ETHERNET",
+    "sid": "GA-02112",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae11.140"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae21.140"
+      }
+    ],
+    "imsid": 720101,
+    "monitored": true,
+    "name": "GEN-LIS-CERN-REDCLARA-22059",
+    "scid": "1dd2f3d5-4714-4201-9027-d0115be4a1da",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02176",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "WIX"
+    ],
+    "endpoints": [],
+    "imsid": 719123,
+    "monitored": false,
+    "name": "WIX-TO-NETHERLIGHT-TEST1",
+    "scid": "1de9ddba-809f-4c54-be37-eef09bb36802",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00767",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662251,
+    "monitored": true,
+    "name": "BUDAPEST-BUDAPEST-1GBE-009(ETH)",
+    "scid": "1df12657-16f8-4e6c-8221-490308e74554",
+    "service_type": "ETHERNET",
+    "sid": "GA-01564",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.4.1/24"
+        ],
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae1.103"
+      }
+    ],
+    "imsid": 712189,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-POR-PT",
+    "scid": "1dfeb152-3454-4f24-acc9-72fcd33d2063",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00125",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.18/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.16"
+      }
+    ],
+    "imsid": 732665,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-UKMO",
+    "scid": "1e02d94a-8cad-412a-86f0-8032dd9dc83f",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01089",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661601,
+    "monitored": false,
+    "name": "TAAS-GTS-CONTROL-PAR-FR-VLAN250",
+    "scid": "1e07851e-dcf8-4add-9e7c-424e27c83010",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00374",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NIKS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.186/31",
+          "2001:798:99:1::10d/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae25.100"
+      }
+    ],
+    "imsid": 734932,
+    "monitored": true,
+    "name": "NL-NIKS",
+    "scid": "1e22ab62-4cfe-4989-a814-9f4c97684f53",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-01183",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.121.138/31"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae1.32"
+      }
+    ],
+    "imsid": 708223,
+    "monitored": true,
+    "name": "ESNET-GEN-773-OOB",
+    "scid": "1e244e65-16d8-4d0f-ab8f-895ae6890721",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00877",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 738743,
+    "monitored": true,
+    "name": "POZ-POZ-10G-LINK1",
+    "scid": "1e61687e-3d3b-4c5c-acee-a3d6eb348807",
+    "service_type": "ETHERNET",
+    "sid": "GA-01371",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT-IT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/7"
+      },
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "xe-1/0/42"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/7.0"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-11/2/2.0"
+      }
+    ],
+    "imsid": 729417,
+    "monitored": true,
+    "name": "PAR-LON2-SUPERPOP-QFX-2-GEANT",
+    "scid": "1ea05a59-68b3-405e-b16d-25bf2ced49e9",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00081",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "et-5/1/0"
+      },
+      {
+        "addresses": [
+          "83.97.88.62/31",
+          "2001:798:1::30/127"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae44.0"
+      }
+    ],
+    "imsid": 746069,
+    "monitored": true,
+    "name": "GOOGLE-2-FRA-IP1",
+    "scid": "1eaffd5f-d60b-4d52-9be7-5ec5aa424e84",
+    "service_type": "ETHERNET",
+    "sid": "GS-02226",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658800,
+    "monitored": true,
+    "name": "MILAN 2 CALDERA-MILAN 2 CALDERA-1GBE-005(ETH)",
+    "scid": "1ec54337-4837-4e0f-bde2-f036875802e7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01520",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "T-SYSTEMS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "80.158.74.249/31"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae27.4003"
+      }
+    ],
+    "imsid": 734864,
+    "monitored": false,
+    "name": "NL-T-SYSTEMS-COPERNICUS",
+    "scid": "1eec53f9-ea26-45be-aaca-6d02d3eaa1ae",
+    "service_type": "L3-VPN",
+    "sid": "GS-02331",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 740194,
+    "monitored": true,
+    "name": "KAU-POZ-IP1",
+    "scid": "1f0d7347-6562-460f-9bc5-6dc100779727",
+    "service_type": "ETHERNET",
+    "sid": "GA-D0008",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CSTNET"
+    ],
+    "endpoints": [],
+    "imsid": 662986,
+    "monitored": true,
+    "name": "DE-CSTNET",
+    "scid": "1f3680cd-9a04-408b-9415-e552885f0f23",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00876",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708724,
+    "monitored": false,
+    "name": "AMS-LON-IPTRUNK-300G",
+    "scid": "1f55c8c6-ef7b-4809-baec-e4aa630a83c7",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00011",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/8"
+      },
+      {
+        "addresses": [
+          "62.40.106.193/30",
+          "2001:798:bb:1::15/126"
+        ],
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/8.0"
+      }
+    ],
+    "imsid": 727980,
+    "monitored": false,
+    "name": "DTN-PRA-10G-DATA",
+    "scid": "1f8e5e54-3ced-49c6-9bb6-0eb5f2d1d919",
+    "service_type": "SERVER LINK",
+    "sid": "GS-02354",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [
+      {
+        "equipment": "LJU02-GRV1",
+        "port": "1/3/3.1"
+      },
+      {
+        "equipment": "ZAG01-GRV1",
+        "port": "1/3/3.1"
+      }
+    ],
+    "imsid": 730786,
+    "monitored": true,
+    "name": "COLT-GWS-ARNES",
+    "scid": "1f918604-9319-4fef-a075-471362557297",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02098",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RESTENA"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-22"
+      }
+    ],
+    "imsid": 744017,
+    "monitored": true,
+    "name": "RESTENA-AP2-LAG",
+    "scid": "1fd474d6-a2e9-4a72-bd8d-157b625888c6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01818",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINGAREN"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.375"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.375"
+      }
+    ],
+    "imsid": 736108,
+    "monitored": false,
+    "name": "AMS-LON-SINGAREN-RARE-123034",
+    "scid": "1fe09db3-80af-4f2b-b1e2-26f60c401bbe",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02315",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658775,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-008(ETH)",
+    "scid": "1fe80353-f8b6-4433-8f43-3596251b9822",
+    "service_type": "ETHERNET",
+    "sid": "GA-01501",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 713232,
+    "monitored": true,
+    "name": "BUC-CHI-LAG",
+    "scid": "1ff55071-a418-4b7a-a9f4-ab82e71f12ae",
+    "service_type": "ETHERNET",
+    "sid": "TA-02003",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [],
+    "imsid": 733114,
+    "monitored": false,
+    "name": "FRA-GEN-CERN-DFN-2",
+    "scid": "1ff82a03-96c2-4443-b9fe-d59963b713f2",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02444",
+    "speed": 536870912000,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/3"
+      }
+    ],
+    "imsid": 721146,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-003(GEANT)",
+    "scid": "1ffac299-0dd2-4176-8ef8-4396c5e8c82d",
+    "service_type": "ETHERNET",
+    "sid": "GA-02192",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.135/31",
+          "2001:798:cc::ce/126"
+        ],
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae5.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.134/31",
+          "2001:798:cc::cd/126"
+        ],
+        "hostname": "rt1.buc.ro.geant.net",
+        "interface": "ae5.0"
+      }
+    ],
+    "imsid": 745144,
+    "monitored": true,
+    "name": "BUC-CHI-IPTRUNK",
+    "scid": "201a2e2e-e629-4f2a-8b58-8943f20bd3fc",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00022",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/4"
+      },
+      {
+        "addresses": [
+          "62.40.114.38/31",
+          "2001:798:bb:2::41/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/4.0"
+      }
+    ],
+    "imsid": 708184,
+    "monitored": false,
+    "name": "PSMP-LHC-MANAGEMENT-LON-UK-VLAN0",
+    "scid": "203bd8cd-b9a4-4670-85a9-66656b2a0a33",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00359",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 719588,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-001(GEANT)",
+    "scid": "2048f4b8-112d-49e5-accd-dabc8881d3f6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01579",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.22/31",
+          "2001:798::25/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae10.667"
+      }
+    ],
+    "imsid": 660392,
+    "monitored": false,
+    "name": "JISC-AP1-CLS",
+    "scid": "2054f883-c6b9-451d-9f75-08b056387afa",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00612",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/1/4"
+      }
+    ],
+    "imsid": 720006,
+    "monitored": true,
+    "name": "SCION1ILO.GEN.CH-INTERNAL-LL",
+    "scid": "207ab701-434f-4965-abe7-6fd9f318f0a3",
+    "service_type": "ETHERNET",
+    "sid": "GA-02188",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 708667,
+    "monitored": true,
+    "name": "LAG-RT2.AMS.NL_AE10",
+    "scid": "20a13559-cc78-425a-b4c7-b9be4a7535e7",
+    "service_type": "ETHERNET",
+    "sid": "GA-02034",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 729770,
+    "monitored": true,
+    "name": "TARTU-TARTU-LAG-005(GEANT)",
+    "scid": "20c82aaf-ae1b-43c5-a12b-dce60ea1210e",
+    "service_type": "ETHERNET",
+    "sid": "GA-02054",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.132/31",
+          "2001:798:99:1::cd/126"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/2.17"
+      }
+    ],
+    "imsid": 660718,
+    "monitored": true,
+    "name": "VIRGIN-MEDIA-EX1-LON2-TO-CAM-SRX-VLAN17",
+    "scid": "20cf47e9-1fcf-49e3-ae88-157e3d880cae",
+    "service_type": "CORPORATE",
+    "sid": "GS-00004",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [],
+    "imsid": 741019,
+    "monitored": false,
+    "name": "LIS-LON-REDCLARA-SINGREN-24065",
+    "scid": "20d7173c-c4bc-4374-a79a-005ecf8bea57",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02566",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [],
+    "imsid": 712383,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-GARR-1-IT",
+    "scid": "20e56992-62c4-466f-905c-ab827afa3ade",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01021",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.20"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4081"
+      }
+    ],
+    "imsid": 739675,
+    "monitored": true,
+    "name": "BELNET-ARTEV-EXPRESSROUTE-VLAN4081",
+    "scid": "210e27bc-ebc6-4022-87bf-7d68bbad573a",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01123",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679098,
+    "monitored": true,
+    "name": "FRA-POZ-LAG",
+    "scid": "21341350-efec-4d23-98da-3fcc41214fc2",
+    "service_type": "ETHERNET",
+    "sid": "GA-01960",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "195.169.24.11/28",
+          "2001:610:9d8::b/64"
+        ],
+        "hostname": "srx2.am.office.geant.net",
+        "interface": "ge-0/0/0.10"
+      }
+    ],
+    "imsid": 663187,
+    "monitored": false,
+    "name": "SRX2-AMS-INFRASTRUCTURE-MANAGEMENT",
+    "scid": "213c036b-26ce-444f-aceb-c14185c47521",
+    "service_type": "CORPORATE",
+    "sid": "GS-01747",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 713233,
+    "monitored": true,
+    "name": "BUC-CHI-IPTRUNK",
+    "scid": "2145b532-e3c0-4ac7-a08b-99db7ea7b464",
+    "service_type": "IP TRUNK",
+    "sid": "TA-00022|TS-00022",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663074,
+    "monitored": false,
+    "name": "PS-FRA-DE-PSMP2-OWAMP-ADDITIONAL-IF",
+    "scid": "217fe55c-1bd7-458d-86af-54e9cee59f81",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00304",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT-IT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae31.0"
+      },
+      {
+        "addresses": [
+          "10.100.66.8/31"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae16.300"
+      }
+    ],
+    "imsid": 661549,
+    "monitored": true,
+    "name": "LONDON2-CORPORATE-NETWORK-SERVICES",
+    "scid": "21a5e397-d6f2-463b-af4b-54c9eeac7449",
+    "service_type": "CORPORATE",
+    "sid": "GS-00824",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "TEIN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-1/0/0"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae28.1"
+      }
+    ],
+    "imsid": 668866,
+    "monitored": true,
+    "name": "LON-BEIJING-LEASEDSPAN",
+    "scid": "21aa2198-7a5c-4944-8646-c793e0bda5fa",
+    "service_type": "ETHERNET",
+    "sid": "GA-01479",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.165/31",
+          "2001:798:cc::6/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae8.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.164/31",
+          "2001:798:cc::5/126"
+        ],
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae2.0"
+      }
+    ],
+    "imsid": 736813,
+    "monitored": true,
+    "name": "AMS2-LON-AMT-IPTRUNK",
+    "scid": "21c3396e-cc9d-4601-80dc-d228cbc265ce",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00012",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "WACREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-10/0/0"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae22"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae22.1"
+      }
+    ],
+    "imsid": 669242,
+    "monitored": true,
+    "name": "WACREN-GEO-UK-1-LL",
+    "scid": "22075da7-b83a-4c5f-9a23-2697a68f9c69",
+    "service_type": "CBL1",
+    "sid": "GA-01838",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "equipment": "MIL02-GRV3",
+        "port": "1/2/3"
+      },
+      {
+        "equipment": "GEN01-GRV4",
+        "port": "1/2/3"
+      }
+    ],
+    "imsid": 734723,
+    "monitored": true,
+    "name": "GEN1-MIL2-ECMWF-SWITCH-GARR-23109-2",
+    "scid": "22096e5a-4b83-4dd5-b683-4449d800f299",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02420",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/4"
+      }
+    ],
+    "imsid": 734102,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-001(GEANT)",
+    "scid": "223ce175-d3b3-4aaa-8c2a-f4eb7db5d55c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01313",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.33/30",
+          "2001:798:1::25/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae17.333"
+      }
+    ],
+    "imsid": 663049,
+    "monitored": true,
+    "name": "CERN-AP1-IAS",
+    "scid": "225c1029-e685-424c-bc6d-4bb6fb8922ff",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00562",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NETHERLIGHT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae23.34"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.34"
+      }
+    ],
+    "imsid": 734612,
+    "monitored": false,
+    "name": "AMS-GEN-SCION-NETHERLIGHT-SWITCH-20018",
+    "scid": "225e173e-a434-48f0-8d45-788131e71ee2",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00639",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae30.3008"
+      }
+    ],
+    "imsid": 733008,
+    "monitored": false,
+    "name": "INFOBLOX-DNS-FRA-DE",
+    "scid": "2282cdd0-5dae-45c2-8678-a5c54ee6d33d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00200",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae14.1290"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-160231"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:cp-1290"
+      }
+    ],
+    "imsid": 744061,
+    "monitored": false,
+    "name": "IMINDS-00670",
+    "scid": "22e12fe0-8788-470e-9098-512487831eea",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00670",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 744882,
+    "monitored": true,
+    "name": "BREN-AP1-LAG",
+    "scid": "23558e1f-2bd8-4802-8062-6ff1d78cb8b3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01291",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 736730,
+    "monitored": false,
+    "name": "NORDU-TO-WIX-TEST",
+    "scid": "23866bb9-3897-498c-9057-74b1e3126df9",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00744",
+    "speed": 536870912000,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-6"
+      }
+    ],
+    "imsid": 745506,
+    "monitored": true,
+    "name": "ATH2-MIL2-LAG",
+    "scid": "23aa4fbe-15bc-4f69-98ce-695c23ec901b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01777",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/0/0.937"
+      },
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.937"
+      }
+    ],
+    "imsid": 726620,
+    "monitored": false,
+    "name": "BIL-GEN-REDIRIS-RARE",
+    "scid": "23ded7cb-8234-4030-b0ff-e34a2755d9a2",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02288",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 712095,
+    "monitored": false,
+    "name": "HAM-TAL-IPTRUNK",
+    "scid": "23f280a6-88cf-44ab-a20f-34d2571b2235",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00041",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.107.220/31",
+          "2001:798:bb:2::d9/126"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/3/2.22"
+      }
+    ],
+    "imsid": 677828,
+    "monitored": false,
+    "name": "PS-LON2-UK-OWAMP-FPC2",
+    "scid": "2401b1fb-4bda-4d11-ab4a-9fb64e746e8e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00327",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.10/31",
+          "2001:798:cc:1::a5/126"
+        ],
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae6.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.11/31",
+          "2001:798:cc:1::a6/126"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae6.0"
+      }
+    ],
+    "imsid": 719646,
+    "monitored": true,
+    "name": "BIL-MAD-IPTRUNK",
+    "scid": "2406e5d4-3c78-436a-81b7-62b8035e19c4",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02203",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658694,
+    "monitored": false,
+    "name": "730XD-4-VSAN-TRAFFIC-LAG",
+    "scid": "2410c8d7-52fc-41d4-93c6-e88ff83effcd",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01680",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ULAKBIM"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-23"
+      }
+    ],
+    "imsid": 744993,
+    "monitored": true,
+    "name": "ULAKBIM-AP2-LAG",
+    "scid": "244f1a0a-8a98-4b6d-83d5-41fd1284f564",
+    "service_type": "ETHERNET",
+    "sid": "GA-01962",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662198,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-009(ETH)",
+    "scid": "24bc000b-4935-46c6-8b19-e410c041f350",
+    "service_type": "ETHERNET",
+    "sid": "GA-01610",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661377,
+    "monitored": false,
+    "name": "TAAS-GTS-CONTROL-2",
+    "scid": "24c13d08-863d-4140-b317-62405e000083",
+    "service_type": "GTS",
+    "sid": "GS-01190",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.29/30",
+          "2001:798:1::21/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae12.333"
+      }
+    ],
+    "imsid": 730098,
+    "monitored": true,
+    "name": "CARNET-AP2-IAS",
+    "scid": "24d033d8-f66d-4a02-a81c-e5e4fb5fc895",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00560",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.140/31",
+          "2001:798:cc::d9/126"
+        ],
+        "hostname": "rt1.buc.ro.geant.net",
+        "interface": "ae2.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.141/31",
+          "2001:798:cc::da/126"
+        ],
+        "hostname": "rt0.buc.ro.geant.net",
+        "interface": "lag-2.0"
+      }
+    ],
+    "imsid": 745576,
+    "monitored": false,
+    "name": "BUC-BUC-IPTRUNK",
+    "scid": "251fabbc-0c95-4f48-a67b-61fa3a90923d",
+    "service_type": "IP TRUNK",
+    "sid": "GS-50060",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/2/3.370"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/2/4.370"
+      },
+      {
+        "addresses": [
+          "10.0.1.254/24"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "irb.370"
+      }
+    ],
+    "imsid": 723805,
+    "monitored": false,
+    "name": "SCION-SCION-PAR-INTERNAL-VPN-VL370",
+    "scid": "25263f65-b258-43a9-81aa-f81b8645cb4a",
+    "service_type": "L3-VPN",
+    "sid": "GS-02215",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 739734,
+    "monitored": true,
+    "name": "FRA-GEN-LAG",
+    "scid": "254687bf-3b3b-4233-bea4-c91ccbec7f92",
+    "service_type": "ETHERNET",
+    "sid": "GA-01961,",
+    "speed": 858993459200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 659346,
+    "monitored": true,
+    "name": "VIX-AT-LAG",
+    "scid": "2564019f-85c6-4bf1-af8e-a520a437f6cf",
+    "service_type": "ETHERNET",
+    "sid": "GA-01867",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.poz.pl.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 740198,
+    "monitored": true,
+    "name": "KIE-POZ-LAG",
+    "scid": "25726f75-9112-4125-a46f-9857eec8a21f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01996",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 709847,
+    "monitored": true,
+    "name": "BRUSSELS-BRUSSELS-1GBE-003(ETH)",
+    "scid": "25739c03-f123-4df7-b9a2-85f30f407806",
+    "service_type": "ETHERNET",
+    "sid": "GA-01359",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.27/31",
+          "2001:798:cc::2a/126"
+        ],
+        "hostname": "rt0.lon.uk.geant.net",
+        "interface": "lag-6.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.26/31",
+          "2001:798:cc::29/126"
+        ],
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-1.0"
+      }
+    ],
+    "imsid": 747278,
+    "monitored": true,
+    "name": "DUB-LON-IPTRUNK",
+    "scid": "2575bee7-a12c-43fa-95c6-f6c557f0f98a",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00031",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662231,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-051(ETH)",
+    "scid": "259c9445-6965-4a61-949c-2a163abcc204",
+    "service_type": "ETHERNET",
+    "sid": "GA-01578",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.vie.at - FRA-VIE Multicast Traffic",
+    "scid": "25a553ee-6c24-4c36-bcb6-b3d05b790b45",
+    "service_type": null,
+    "sid": "DS-04013",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 702111,
+    "monitored": true,
+    "name": "BRU-LON-LAG",
+    "scid": "2612879a-170c-43c6-957e-1b000b3890ee",
+    "service_type": "ETHERNET",
+    "sid": "GA-01848",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 678080,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-10GBE-099(GEANT)",
+    "scid": "261e6004-60a2-46c8-9d4a-f14e5b9dcb19",
+    "service_type": "ETHERNET",
+    "sid": "GA-02132",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/4"
+      }
+    ],
+    "imsid": 717185,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-004(GEANT)",
+    "scid": "26229f64-bab7-46fc-9f13-7cee0376e361",
+    "service_type": "ETHERNET",
+    "sid": "GA-01240",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae12.790"
+      },
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae15.790"
+      }
+    ],
+    "imsid": 746076,
+    "monitored": true,
+    "name": "MAR-MAR-02645",
+    "scid": "263f26fc-a1ae-4070-bf40-8691c7adea88",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02645",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662364,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-10GBE-077(GEANT)",
+    "scid": "264b202d-8ecc-482c-b9b4-98f68e0937e9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01602",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [],
+    "imsid": 719490,
+    "monitored": false,
+    "name": "REDIRIS-BGP-LU-COC-AP1",
+    "scid": "266236cd-e560-472d-8456-ed48190b71d2",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01057",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ROEDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 747888,
+    "monitored": true,
+    "name": "ROEDUNET-AP1-LAG",
+    "scid": "266abd95-a109-47f6-872b-7e35b3fd833e",
+    "service_type": "ETHERNET",
+    "sid": "GA-018934",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "195.169.24.25/29",
+          "2001:610:9d8:1::1/64"
+        ],
+        "hostname": "srx1.am.office.geant.net",
+        "interface": "ge-0/0/0.50"
+      }
+    ],
+    "imsid": 662969,
+    "monitored": false,
+    "name": "SRX1-AMS-TO-FW-WAN",
+    "scid": "267508c4-2dfb-423b-aa02-5bb3434d858e",
+    "service_type": "CORPORATE",
+    "sid": "GS-01194",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "WIX"
+    ],
+    "endpoints": [],
+    "imsid": 719128,
+    "monitored": false,
+    "name": "WIX-TO-NETHERLIGHT-TEST2",
+    "scid": "2685b7a0-102d-44f9-aac3-b5e5c7908544",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00768",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663203,
+    "monitored": false,
+    "name": "LHCOPN-MDMSERVER-VLAN72",
+    "scid": "26d521ae-714c-4602-81d1-51d91f9a9d71",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00226",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661633,
+    "monitored": false,
+    "name": "OCVM-LON-UK",
+    "scid": "26f27332-b058-4c23-bf53-274e51fe295b",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00137",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.55/31",
+          "2001:798:cc:1::122/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae6.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.54/31",
+          "2001:798:cc:1::121/126"
+        ],
+        "hostname": "rt2.bra.sk.geant.net",
+        "interface": "ae6.0"
+      }
+    ],
+    "imsid": 730086,
+    "monitored": true,
+    "name": "BRA-BUD-IPTRUNK",
+    "scid": "2737a2e5-d153-4323-8a65-5415e75af1c3",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00018",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CAREN"
+    ],
+    "endpoints": [],
+    "imsid": 663186,
+    "monitored": false,
+    "name": "DE-CAREN",
+    "scid": "274e0abd-6bbf-4f73-b118-dcd8a6cb6b24",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00875",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.61/30",
+          "2001:0798:0012:10aa::11/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae14.160"
+      }
+    ],
+    "imsid": 663060,
+    "monitored": true,
+    "name": "RENATER-AP2",
+    "scid": "275fc372-db9f-4589-9726-7626343efa46",
+    "service_type": "GEANT IP",
+    "sid": "GS-00506",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EENET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.57/30",
+          "2001:798:1::45/126"
+        ],
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-21.200"
+      }
+    ],
+    "imsid": 745985,
+    "monitored": true,
+    "name": "EENET-AP2-IAS",
+    "scid": "27662825-c993-4152-8cb2-84314522215f",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00569",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ASNET-TW"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "202.169.175.206/30",
+          "2001:0c08:aabb::1002/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/1/5.105"
+      }
+    ],
+    "imsid": 742821,
+    "monitored": true,
+    "name": "NL-ASNET-TW",
+    "scid": "276ea9a7-bbc0-48e8-bcb1-c7496fcf1afd",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00888",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BREN"
+    ],
+    "endpoints": [],
+    "imsid": 712403,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-BREN-BG",
+    "scid": "277cae1e-6d66-404d-b2e8-bfee809455b9",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01034",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "DUB2-LON2 LAG",
+    "scid": "27edbd42-08bb-4f54-bc60-3c2b8b98549b",
+    "service_type": null,
+    "sid": "GA-01763",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.226/31",
+          "2001:798:cc:1::95/126"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae5.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.227/31",
+          "2001:798:cc:1::96/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae2.0"
+      }
+    ],
+    "imsid": 717047,
+    "monitored": true,
+    "name": "MAD-MAR-IPTRUNK",
+    "scid": "282334ba-996c-40aa-b3b5-a74c9fa24269",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00054",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ASREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/5"
+      }
+    ],
+    "imsid": 659069,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-065(ETH)",
+    "scid": "28287f3b-485c-4dbc-898f-b9eccd41ee9d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01315",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.233/30",
+          "2001:798:1::b9/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.333"
+      }
+    ],
+    "imsid": 734590,
+    "monitored": true,
+    "name": "SURF-AP1-IAS",
+    "scid": "282e1bce-66dc-4965-b474-f26972b3a457",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00587",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.58/31",
+          "2001:798:111:1::dd/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae10.111"
+      }
+    ],
+    "imsid": 726626,
+    "monitored": true,
+    "name": "KIFU-AP1-LHCONE",
+    "scid": "285062ec-f192-4275-8e6d-b83c25ea5d8c",
+    "service_type": "L3-VPN",
+    "sid": "GS-02282",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662520,
+    "monitored": true,
+    "name": "SURFNET VLAN 100 - FOR LINK TO GEANT IT VRF VIA MX1.AMS - SURFNET SERVICE ID: 5836",
+    "scid": "285f956a-3d47-4ff4-a43a-2e497d2f374f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01263",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "MARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.101/30",
+          "2001:798:1::7d/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-22.333"
+      }
+    ],
+    "imsid": 744958,
+    "monitored": true,
+    "name": "MARNET-AP1-IAS",
+    "scid": "2886dc7d-1ced-4483-b406-afc81766c717",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00536",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663248,
+    "monitored": false,
+    "name": "OWAMP-SOF-BG",
+    "scid": "2896fe35-71a6-440a-a283-8bb7ed7bb8b8",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00270",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae27"
+      }
+    ],
+    "imsid": 659351,
+    "monitored": true,
+    "name": "AKAMAI-LAG",
+    "scid": "289e8149-9523-4df8-af9f-b3aec269f266",
+    "service_type": "ETHERNET",
+    "sid": "GA-01872",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "DE-CIX"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "185.1.47.34/24",
+          "2001:7f8:36::51e5:0:1/64"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae22.100"
+      }
+    ],
+    "imsid": 740868,
+    "monitored": false,
+    "name": "IX-PEERINGS-IN-DE-CIX-MAR",
+    "scid": "28a95768-49ec-4c84-ab68-90981cd7ee65",
+    "service_type": "IP PEERING - NON R&E (PUBLIC)",
+    "sid": "GS-00948",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "xe-7/0/1"
+      }
+    ],
+    "imsid": 742611,
+    "monitored": true,
+    "name": "MAD-MAD-MGMT-LINK-2",
+    "scid": "28b5f700-a84f-469c-a340-96023b772ba9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01660",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx2.ath.gr.geant.net",
+        "interface": "xe-2/0/0"
+      },
+      {
+        "hostname": "mx2.ath.gr.geant.net",
+        "interface": "xe-2/0/0.700"
+      }
+    ],
+    "imsid": 707137,
+    "monitored": true,
+    "name": "ATH-KOR-SMARTFIRE-GRNET-KOREN-15007",
+    "scid": "29299c5d-52b9-4701-ae0f-27eccd5ef444",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00664",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708721,
+    "monitored": false,
+    "name": "MAD-PAR-IPTRUNK",
+    "scid": "293e36a2-c231-456e-a467-e2df8a48e1d3",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00055",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.150/31",
+          "2001:798:99:1::ed/126"
+        ],
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae11.615"
+      }
+    ],
+    "imsid": 713837,
+    "monitored": true,
+    "name": "PT-REDCLARA",
+    "scid": "2941d1e3-998e-4c32-b31c-3c4f0fa252a8",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00903",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "UBUNTUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/3/2.801"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.801"
+      }
+    ],
+    "imsid": 709301,
+    "monitored": true,
+    "name": "LON-LON-MISC-UBUNTUNET-INTERNET2-170341",
+    "scid": "29642e9a-68aa-49ce-a061-7c97416c1fb3",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00729",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "LJU-ZAG TRUNK",
+    "scid": "2972bf86-150f-47a1-8365-01804aa4e57a",
+    "service_type": null,
+    "sid": "DS-19823",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ULAKBIM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.153/30",
+          "2001:798:2b:10aa::5/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-23.100"
+      }
+    ],
+    "imsid": 745009,
+    "monitored": true,
+    "name": "ULAKBIM-AP2",
+    "scid": "2a262c6d-666d-4c05-9d7b-8cfe7c584a76",
+    "service_type": "GEANT IP",
+    "sid": "GS-00518",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "CHRouter - Traffic - New CH - OC 1Gbps Virgin Media Circuit",
+    "scid": "2a9f61a9-55b7-4f9c-98e9-72397df23d7b",
+    "service_type": null,
+    "sid": "DS-27395",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.1003"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.1003"
+      }
+    ],
+    "imsid": 713695,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-NORDUNET-TEIN-21067",
+    "scid": "2ab8e105-efde-422b-bb2d-fbcc422dcad0",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00983",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "TEIN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "202.179.249.210/30",
+          "2001:254:8001:202::2/64"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3200"
+      }
+    ],
+    "imsid": 661919,
+    "monitored": true,
+    "name": "TEIN-LON-LHCONE",
+    "scid": "2abfb54b-7d83-44fb-b948-f192bb4c3edb",
+    "service_type": "L3-VPN",
+    "sid": "GS-00867",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.225/30"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae33.2013"
+      }
+    ],
+    "imsid": 740767,
+    "monitored": true,
+    "name": "NL-NORDUNET-LHCONE-IPV4",
+    "scid": "2adb96cb-4971-49ba-b7d4-79700e61c1ac",
+    "service_type": "L3-VPN",
+    "sid": "GS-00838",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "lon-lon2_GEANTopen_NORDUNET-SINET_16008",
+    "scid": "2b060060-439c-459c-9693-d549bb3261cd",
+    "service_type": null,
+    "sid": "DS-33233",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 659006,
+    "monitored": true,
+    "name": "PARIS-BMS-SRV7-10GBE-001",
+    "scid": "2b15c569-3d42-497c-a47b-4a97ad413804",
+    "service_type": "ETHERNET",
+    "sid": "GA-01378",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [],
+    "imsid": 709748,
+    "monitored": true,
+    "name": "GEANT EUMETCAST AP2",
+    "scid": "2b2529bd-ca3f-4c80-b8b6-760708190d66",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01106",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [],
+    "imsid": 678920,
+    "monitored": false,
+    "name": "SRV_CORPORATE",
+    "scid": "2b307a5d-2715-407a-82f0-b58567c3d6be",
+    "service_type": "CORPORATE",
+    "sid": "GS-00466",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMT1.LON2.UK",
+        "port": "AE1.20"
+      },
+      {
+        "addresses": [
+          "83.97.90.42/31"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae7.20"
+      }
+    ],
+    "imsid": 747034,
+    "monitored": false,
+    "name": "LON2-LON2-AMT-RELAYLINK-IAS",
+    "scid": "2b5b16c5-de74-45b3-b46e-08ac99e33acd",
+    "service_type": "SERVER LINK",
+    "sid": "GS-02638",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659111,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-1GBE-012(ETH)",
+    "scid": "2b70ed46-b4f4-4585-841a-b904010eea00",
+    "service_type": "ETHERNET",
+    "sid": "GA-01444",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RESTENA"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae18.551"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.551"
+      }
+    ],
+    "imsid": 737780,
+    "monitored": true,
+    "name": "FRA-PAR-SLICES-RESTENA-RENATER-VL551",
+    "scid": "2b7a77f9-c233-44b3-ba26-c5d3205dde6f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02485",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.157/30",
+          "2001:798:1::c1/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae13.333"
+      }
+    ],
+    "imsid": 661345,
+    "monitored": true,
+    "name": "SWITCH-AP2-IAS",
+    "scid": "2b8232fd-2b7c-4936-85ed-5486357aca05",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00590",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.13/30",
+          "2001:798:1b:10aa::19/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae23.600"
+      }
+    ],
+    "imsid": 731676,
+    "monitored": true,
+    "name": "CESNET-AP2",
+    "scid": "2b824aa6-1daf-438e-9f6f-6ae3e5a8ffa2",
+    "service_type": "GEANT IP",
+    "sid": "GS-00445",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [],
+    "imsid": 705479,
+    "monitored": false,
+    "name": "GEN-PAR-MISC-SWITCH-INTERNET2-18046",
+    "scid": "2bc26a0c-2c47-464f-82d4-590d60efbf28",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00714",
+    "speed": 536870912000,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 712119,
+    "monitored": true,
+    "name": "SW4.LON.UK-LAG",
+    "scid": "2bd450e6-93d3-4057-bb05-e6cbd9cb6fdb",
+    "service_type": "ETHERNET",
+    "sid": "GA-01837",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663240,
+    "monitored": false,
+    "name": "CITY-HOUSE-LAB-INFINERA-MGMT-NETWORK",
+    "scid": "2bf46eee-8514-4671-8408-e70e38e78ac6",
+    "service_type": "CORPORATE",
+    "sid": "GS-00449",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658564,
+    "monitored": false,
+    "name": "730XD-2-SLOT0-PORT1-VMNIC0-PAR",
+    "scid": "2bfc77b2-e154-4208-ae7e-ccb05ad4bea1",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01285",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3.1024"
+      }
+    ],
+    "imsid": 661294,
+    "monitored": true,
+    "name": "SDN-BOD-BR53-OF-7-HOST-G-ETH3",
+    "scid": "2c0feb30-6a22-4f23-858e-1d230cfdeea1",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00758",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-21"
+      }
+    ],
+    "imsid": 747270,
+    "monitored": true,
+    "name": "INEX-LAG",
+    "scid": "2c102103-9554-4f7e-9c0c-ae066ee731d5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01924",
+    "speed": 32212254720,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [],
+    "imsid": 732583,
+    "monitored": true,
+    "name": "DFN-BGP-LU-COC-AP2",
+    "scid": "2c129a08-b3fe-4caf-811d-e4973bc5e0d2",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01002",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [],
+    "imsid": 709735,
+    "monitored": true,
+    "name": "ARNES-EUMETCAST-AP1",
+    "scid": "2c3dc828-2c9d-4292-a842-181916356e09",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01096",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732256,
+    "monitored": true,
+    "name": "ZAGREB 1-ZAGREB 1-1GBE-025(GEANT)",
+    "scid": "2c438148-250a-405d-b8ea-a1a3bdf99263",
+    "service_type": "ETHERNET",
+    "sid": "GA-01494",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ASNET-AM"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-11/1/1"
+      }
+    ],
+    "imsid": 732090,
+    "monitored": true,
+    "name": "ASNET-AM-GWS-COLT-LL1",
+    "scid": "2c5d139a-a4a7-4b13-92bf-669bcba6d9d9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01600",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.100"
+      }
+    ],
+    "imsid": 663022,
+    "monitored": false,
+    "name": "CAM-OFFICE-TO-AMS-OFFICE-L2CIRCUIT",
+    "scid": "2c608dbc-da31-4cd1-87b4-5f221085e8e5",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00107",
+    "speed": 0,
+    "status": "terminated"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "64.57.30.210/28",
+          "2001:468:ef00:4001::3/64"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.2002"
+      }
+    ],
+    "imsid": 661750,
+    "monitored": true,
+    "name": "INTERNET2-LON-LHCONE",
+    "scid": "2cd18b7b-837d-4272-97ce-404073b07e1e",
+    "service_type": "L3-VPN",
+    "sid": "GS-00830",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732384,
+    "monitored": true,
+    "name": "BUDAPEST-BUDAPEST-1GBE-002(GEANT)",
+    "scid": "2cd614b5-134b-4be3-a581-17a16d38bd02",
+    "service_type": "ETHERNET",
+    "sid": "GA-01563",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28"
+      }
+    ],
+    "imsid": 739601,
+    "monitored": true,
+    "name": "BELNET-AP2-LAG",
+    "scid": "2cf06177-97ba-411a-a21d-4263757b0aef",
+    "service_type": "ETHERNET",
+    "sid": "GA-01842",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/5"
+      },
+      {
+        "addresses": [
+          "62.40.126.190/31",
+          "2001:798:111:1::69/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/5.0"
+      }
+    ],
+    "imsid": 708281,
+    "monitored": false,
+    "name": "PSMP-LHC-OWD-LON-UK-VLAN0",
+    "scid": "2d0afbf8-a198-496d-afc4-9bec35b8c056",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00360",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae16"
+      }
+    ],
+    "imsid": 659382,
+    "monitored": true,
+    "name": "LAG-MX1.LON2.UK_AE16",
+    "scid": "2d108a02-a649-482f-8d80-305623cc6005",
+    "service_type": "ETHERNET",
+    "sid": "GA-01759",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "xe-2/2/0"
+      }
+    ],
+    "imsid": 738655,
+    "monitored": true,
+    "name": "ES-MICROSOFT-EXPRESSROUTE-LL2",
+    "scid": "2d750c3d-f984-4d89-b015-496bdb1c549e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01347",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.3018"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae2.3018"
+      }
+    ],
+    "imsid": 736074,
+    "monitored": false,
+    "name": "AMS-PAR-SINET-SD-WAN-SINET-SINET-17091",
+    "scid": "2d78e5dd-a685-453f-88a0-d0f5ec855bd4",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00660",
+    "speed": 150323855360,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 731506,
+    "monitored": false,
+    "name": "NORDUNET-GEO-EXPRESSROUTE-VLAN3917",
+    "scid": "2da843aa-3011-46a7-9eb7-91099e3aeb69",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02308",
+    "speed": 118111600640,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.38/31",
+          "2001:798:99:1::71/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae33.100"
+      }
+    ],
+    "imsid": 739582,
+    "monitored": true,
+    "name": "NORDUNET-AP3",
+    "scid": "2de818d3-8e4a-4225-aa6d-9a345a311a4b",
+    "service_type": "GEANT IP",
+    "sid": "GS-02552",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 715164,
+    "monitored": true,
+    "name": "DUB2-LON-IPTRUNK",
+    "scid": "2e0c13f9-382a-4444-a97b-7ff7e3e76779",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00032",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/0/6"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/0/6.4"
+      }
+    ],
+    "imsid": 661479,
+    "monitored": true,
+    "name": "SDX-L2-HOSTD-TO-BR52",
+    "scid": "2e23d8dc-cedd-4a21-989f-6e0bb61f9aa2",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00765",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [],
+    "imsid": 661961,
+    "monitored": true,
+    "name": "PIONIER-BGP-LU-COC-AP1",
+    "scid": "2e30217c-7bc5-42e9-abed-542588bc2dbc",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01055",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.4"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4073"
+      }
+    ],
+    "imsid": 739673,
+    "monitored": true,
+    "name": "BELNET-SCIENSAN0-EXPRESSROUTE-VLAN4073",
+    "scid": "2e3e058d-5a01-4004-86a0-b0eb31658503",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02536",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/2"
+      }
+    ],
+    "imsid": 658586,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-033(ETH)",
+    "scid": "2e578d95-5890-40a1-835c-af02c1c2ea4f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01227",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-924045"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:3505"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.2703"
+      }
+    ],
+    "imsid": 745320,
+    "monitored": true,
+    "name": "GEANT_EPIPE_924045",
+    "scid": "2e6f5a62-ad50-4b8d-b77c-9fe2d5590b59",
+    "service_type": "ETHERNET",
+    "sid": "GS-02488",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURFNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-9/0/2"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae13"
+      }
+    ],
+    "imsid": 732092,
+    "monitored": true,
+    "name": "SURF-AP2-LL1",
+    "scid": "2e70c9ab-fb03-4687-ab1a-ca37e6e8abe1",
+    "service_type": "ETHERNET",
+    "sid": "GA-01482",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 740572,
+    "monitored": true,
+    "name": "LON-MX-SW-LAG",
+    "scid": "2e735d1b-89fc-488c-965d-cf10ca1d8a5d",
+    "service_type": "ETHERNET",
+    "sid": "GA-",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CSTNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.2300"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae10.2300"
+      }
+    ],
+    "imsid": 740995,
+    "monitored": true,
+    "name": "AMS-GEN-IHEP-CERN-CSTNET",
+    "scid": "2e89f7e5-46c7-468a-9435-4d10774ee4ca",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02415",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663046,
+    "monitored": false,
+    "name": "DNA-FR-DE",
+    "scid": "2ed3ee7e-4744-4f39-8a29-78c411401286",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00134",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.bud.hu - BUD-PRA Multicast Traffic",
+    "scid": "2effb62f-f8cd-4ae6-a591-eabe9093f6ad",
+    "service_type": null,
+    "sid": "DS-12657",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21"
+      }
+    ],
+    "imsid": 747580,
+    "monitored": true,
+    "name": "NORDUNET-AP2-LAG",
+    "scid": "2f01d25c-6c99-41ee-bbb4-a7f7aff83182",
+    "service_type": "ETHERNET",
+    "sid": "GA-01893",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.MAR.FR.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      },
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "FR153394"
+      },
+      {
+        "equipment": "DIGITAL REALTY Z-END",
+        "port": "FR153394"
+      }
+    ],
+    "imsid": 713469,
+    "monitored": false,
+    "name": "MAR01 OOB LINK",
+    "scid": "2f20a489-d2cb-4328-a882-064dec0e8a68",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00409",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 735407,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10G-LINK2",
+    "scid": "2f2beed5-52de-415a-959b-9dc4e90f4a75",
+    "service_type": "ETHERNET",
+    "sid": "GA-01575",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-0/0/7"
+      }
+    ],
+    "imsid": 658558,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-019(ETH)",
+    "scid": "2f3d11fd-1712-4366-8b44-087a1c5d5ae7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01252",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "DUB-LON-IPTRUNK",
+    "scid": "2f3e9279-ef7a-4da7-9929-f26d2b1ba130",
+    "service_type": null,
+    "sid": "DS-31343",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae5"
+      }
+    ],
+    "imsid": 717035,
+    "monitored": true,
+    "name": "MAD-MAR01-LAG",
+    "scid": "2f60bfa7-39d8-4759-81e4-f52f70112c03",
+    "service_type": "ETHERNET",
+    "sid": "GA-02010",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.3918"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.38"
+      }
+    ],
+    "imsid": 732192,
+    "monitored": true,
+    "name": "NORDUNET-MSER-EXPRESSROUTE-VLAN3918",
+    "scid": "2f76e589-0179-467c-9a1f-9f8efeedbaab",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02411",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 735952,
+    "monitored": true,
+    "name": "RT1.AMS-RT2.AMS-LAG",
+    "scid": "2f9bda15-9f61-4911-8be0-23d10daa100f",
+    "service_type": "ETHERNET",
+    "sid": "GA-02033",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 659222,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-076(ETH)",
+    "scid": "2faa2005-f963-49aa-bc47-98889518767c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01322",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743286,
+    "monitored": true,
+    "name": "THE-THE-MGMT-LAG",
+    "scid": "2faa4b95-1848-4753-9236-f8d98ead381d",
+    "service_type": "ETHERNET",
+    "sid": "GA-02625",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659289,
+    "monitored": true,
+    "name": "LONDON-LONDON-1GBE-014(ETH)",
+    "scid": "2fc5e92b-ea77-4bbf-a535-c189bcabe867",
+    "service_type": "ETHERNET",
+    "sid": "GA-01467",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "Nordunet_OULU_ExpressRoute_Vlan3905",
+    "scid": "2fcc0935-9fde-4538-ab79-a4f270f6222f",
+    "service_type": null,
+    "sid": "DS-52717",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae5"
+      }
+    ],
+    "imsid": 747826,
+    "monitored": true,
+    "name": "BUD-ZAG-LAG",
+    "scid": "2fcd6323-8c7b-4c92-8cfb-eef07e95ef93",
+    "service_type": "ETHERNET",
+    "sid": "GA-01738",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708218,
+    "monitored": false,
+    "name": "GTS-MANAGEMENT-PRA-CZ",
+    "scid": "2fd1b24d-5181-4e8e-aa9f-58b613fc2254",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00192",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [],
+    "imsid": 709657,
+    "monitored": false,
+    "name": "ARNES-GN-PRACE-VPN-PROXY-VIENNA-L3VPN",
+    "scid": "2ff708b9-e056-43aa-981f-0140b0cda73e",
+    "service_type": "MD-VPN (PROXY)",
+    "sid": "GS-01060",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663030,
+    "monitored": false,
+    "name": "PSMP-SOF-BG-DRAC",
+    "scid": "3001ac26-62f8-4123-8918-c059cae619fa",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00367",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "138.44.226.7/31",
+          "2001:0388:cf7f:0002::1/127"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3101"
+      }
+    ],
+    "imsid": 661460,
+    "monitored": true,
+    "name": "UK-AARNET",
+    "scid": "3010291b-fe82-45c9-8fd2-313b5735eb64",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00904",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SANET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.5/30",
+          "2001:4118:0:81::2/64"
+        ],
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae13.420"
+      }
+    ],
+    "imsid": 719686,
+    "monitored": true,
+    "name": "SANET-AP1",
+    "scid": "301ccc83-78c0-4d22-8916-efb503f3224d",
+    "service_type": "GEANT IP",
+    "sid": "GS-00511",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "equipment": "GEN01-GRV8",
+        "port": "1/2/3"
+      },
+      {
+        "equipment": "FRA01-GRV4",
+        "port": "1/3/3"
+      },
+      {
+        "equipment": "FRA01-GRV4",
+        "port": "1/3/5"
+      }
+    ],
+    "imsid": 739821,
+    "monitored": true,
+    "name": "GEN1-POZ-PSNC-24052-3",
+    "scid": "30716c4d-0717-4123-bfd5-5a814a40d766",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02551",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661491,
+    "monitored": false,
+    "name": "PAR-GROOVE-1",
+    "scid": "30842b92-6e12-4c14-bf77-0acb725cb2b7",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00272",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 740947,
+    "monitored": true,
+    "name": "GEN-MIL2-LAG",
+    "scid": "30924b0a-4db1-4415-9158-8ffa674c3f78",
+    "service_type": "ETHERNET",
+    "sid": "GA-01774",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "DUB2-LON2-IPTRUNK",
+    "scid": "30b21d95-498c-459b-a668-f18ab032c01d",
+    "service_type": null,
+    "sid": "DS-42045",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS2.BRU.BE.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 726440,
+    "monitored": true,
+    "name": "BRUSSELS OOB LINK",
+    "scid": "30d7f436-a163-45d0-9204-841476926549",
+    "service_type": "ETHERNET",
+    "sid": "GA-02281",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662001,
+    "monitored": false,
+    "name": "HADES-POZ-PL-DRAC",
+    "scid": "30d964bb-a62b-4af9-a860-e11d1f03e41f",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00196",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.201/30",
+          "2001:798:111:1::1d/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae12.111"
+      }
+    ],
+    "imsid": 663175,
+    "monitored": true,
+    "name": "GARR-AP2-LHCONE",
+    "scid": "30edb650-7438-48d1-8659-2d8336c44132",
+    "service_type": "L3-VPN",
+    "sid": "GS-00826",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/3.2704"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae22.2704"
+      }
+    ],
+    "imsid": 737889,
+    "monitored": false,
+    "name": "LON-PAR-SCION-WACREN",
+    "scid": "3119f218-6059-41bf-8eae-cccd22f373cc",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02495",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.43"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-124074"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4069"
+      }
+    ],
+    "imsid": 744239,
+    "monitored": true,
+    "name": "MSEHOGENT-02573",
+    "scid": "316d6661-8b13-4ff7-8215-b8dd8dabbb76",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02573",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae10.2806"
+      },
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:2102"
+      }
+    ],
+    "imsid": 747547,
+    "monitored": true,
+    "name": "BUD-HAM-02513",
+    "scid": "31876dae-2b17-4cec-8d98-a6b9d67d392b",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02513",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-3/0/1"
+      }
+    ],
+    "imsid": 658923,
+    "monitored": true,
+    "name": "POZNAN-POZNAN-10GBE-005(ETH)",
+    "scid": "3196835f-d05a-49f1-9a87-e187775f92ad",
+    "service_type": "ETHERNET",
+    "sid": "GA-02138",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658526,
+    "monitored": false,
+    "name": "730XD-5-VSAN-TRAFFIC-LAG-PAR",
+    "scid": "31a3090a-23c3-493c-a8f2-26705c7a0d42",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01729",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708196,
+    "monitored": false,
+    "name": "PS-POZ-PL-OWAMP",
+    "scid": "31b53fae-b07b-4f0b-b41e-c15ab081bab4",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00346",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 712378,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-FUNET-2-FI",
+    "scid": "31eeb33b-4e32-4961-b281-eba629ffe683",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01020",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663076,
+    "monitored": false,
+    "name": "KVMOIP-BUC-RO-VLAN60",
+    "scid": "322da42d-258c-4041-8340-557376761ce0",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00218",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae26"
+      }
+    ],
+    "imsid": 732182,
+    "monitored": true,
+    "name": "MICROSOFT-EXPRESSROUTE-NORDUNET-FRA-LAG3",
+    "scid": "323d5aa9-2d6f-4e7f-84a2-507ad27ae288",
+    "service_type": "ETHERNET",
+    "sid": "GA-01946",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "IRANET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.93/30",
+          "2001:798:99:1::85/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "gr-4/0/0.0"
+      }
+    ],
+    "imsid": 735729,
+    "monitored": false,
+    "name": "NL-IRANET",
+    "scid": "32499fb3-e4a5-4639-8ae5-a4e0d3729d0d",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-01168",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.poz.pl.geant.net",
+        "interface": "lag-7"
+      }
+    ],
+    "imsid": 740493,
+    "monitored": true,
+    "name": "POZ-PRA-LAG",
+    "scid": "324e9c37-b810-4081-9883-bceb0105b8d3",
+    "service_type": "ETHERNET",
+    "sid": "GA-02408",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "LON01-GRV6",
+        "port": "1/1/8"
+      }
+    ],
+    "imsid": 733792,
+    "monitored": true,
+    "name": "LON1-LON2-ESNET-23092-400G",
+    "scid": "325c451b-cc2f-46d6-bd1b-cb5d3c892f63",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02338",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 713247,
+    "monitored": true,
+    "name": "LAG-RT2.CHI.MD_AE2-SW1.CHI.MD_AE3",
+    "scid": "3262cab0-6211-4b86-b9b1-0cd084a33884",
+    "service_type": "ETHERNET",
+    "sid": "GA-02039",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "WIX"
+    ],
+    "endpoints": [],
+    "imsid": 719130,
+    "monitored": false,
+    "name": "WIX-TO-NETHERLIGHT-TEST3",
+    "scid": "3281b907-5524-4655-9f0c-210ccf9c6eac",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00769",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 746303,
+    "monitored": true,
+    "name": "RIG-TAR-LAG",
+    "scid": "32a53de5-20c4-4c3b-8364-1b1b3a4b42fd",
+    "service_type": "ETHERNET",
+    "sid": "GA-02347",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708274,
+    "monitored": false,
+    "name": "GTS-IDRAC-PRA-CZ",
+    "scid": "32a84177-abe9-4b46-b87e-53fd9cc5d824",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00190",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 677585,
+    "monitored": false,
+    "name": "DUB2 OOB LINK",
+    "scid": "32b30bd1-2317-43f7-a542-5872e0ae32de",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00398",
+    "speed": 10485760,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AZSCIENCENET"
+    ],
+    "endpoints": [],
+    "imsid": 673680,
+    "monitored": false,
+    "name": "AZSCIENCENET-TESTVLAN-TTK",
+    "scid": "32ce9a96-e5ea-4b9c-89c4-7c2a82867142",
+    "service_type": "GEANT IP",
+    "sid": "GS-00432",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661605,
+    "monitored": false,
+    "name": "PS-SIMPLE-LOOKUP-SERVICE",
+    "scid": "32cec9d5-11e5-498a-abf4-41bf0b3560ef",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00352",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae10.700"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.700"
+      }
+    ],
+    "imsid": 736674,
+    "monitored": true,
+    "name": "LON-PAR-SYNGENTA-JISC-INTERNET2-17052",
+    "scid": "32d03ddf-0e6b-48ab-8632-ded748411c2c",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00730",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "198.71.45.237/31",
+          "2001:468:ff:15c5::2/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.102"
+      }
+    ],
+    "imsid": 661992,
+    "monitored": true,
+    "name": "FR-INTERNET2",
+    "scid": "32d3c3bd-3d5e-4534-aaa7-4be36f438019",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00884",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-1/0/6"
+      }
+    ],
+    "imsid": 658466,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-015(ETH)",
+    "scid": "33146da9-5a76-4cea-9e41-a826b5226527",
+    "service_type": "ETHERNET",
+    "sid": "GA-01272",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [],
+    "imsid": 712386,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-GARR-1-IT",
+    "scid": "332ea4ca-b2d9-48bf-ba52-103f9348acee",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01042",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.90.1/30",
+          "2001:798:1:3::1/126"
+        ],
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20.333"
+      }
+    ],
+    "imsid": 744232,
+    "monitored": true,
+    "name": "BELNET-AP1-IAS",
+    "scid": "3345876b-a0fc-43b1-b473-272358988c96",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00524",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661314,
+    "monitored": false,
+    "name": "PS-ATH-GR-IDRAC",
+    "scid": "3348e365-be67-41e7-aad4-2dfa2f765689",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00290",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 717035,
+    "monitored": true,
+    "name": "MAD-MAR01-LAG",
+    "scid": "334f91a2-c0f6-4b39-aebd-0493a57a94f0",
+    "service_type": "ETHERNET",
+    "sid": "GA-02171",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ams-lon_EXPReS_JANET-NetherLight_07010",
+    "scid": "3393df68-d71d-4bda-949c-a1190db7413b",
+    "service_type": null,
+    "sid": "GS-00642",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:1006"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-22:1006"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-114015"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-114015"
+      }
+    ],
+    "imsid": 747356,
+    "monitored": true,
+    "name": "FED4FIRE-00669",
+    "scid": "33c03821-badf-4fd5-9f25-dd259de16ae0",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00669",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708155,
+    "monitored": false,
+    "name": "PS-AMS-NL-BWCTL",
+    "scid": "33cb807a-3b6f-41ec-98b7-3d68b3c6cd4d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00283",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "LON2 BMS Server #9 port 1",
+    "scid": "33d5fc19-5b56-452f-833b-cd9e6277482d",
+    "service_type": null,
+    "sid": "GA-01329",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.123.241/29",
+          "2001:798:bb:1d::1/64"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-11/1/2.100"
+      }
+    ],
+    "imsid": 736817,
+    "monitored": false,
+    "name": "DTN-LON-100G-DATA",
+    "scid": "33dd571b-92a9-45fe-917d-a658b965ad62",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00143",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "91.210.16.189/22",
+          "2001:7f8:14::95:1/64"
+        ],
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae12.0"
+      }
+    ],
+    "imsid": 708283,
+    "monitored": false,
+    "name": "IX-PEERINGS-IN-NIX",
+    "scid": "33e16c3c-3f5b-42d5-a177-8bb9cfbc5353",
+    "service_type": "IP PEERING - NON R&E (PUBLIC)",
+    "sid": "GS-00953",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.POR.PT.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 712815,
+    "monitored": false,
+    "name": "PORTO OOB LINK",
+    "scid": "3407f2e5-ed4d-467f-97b3-ef130942feb9",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00412",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662248,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-059(ETH)",
+    "scid": "341413e9-ee0a-468a-a055-c99fe379aece",
+    "service_type": "ETHERNET",
+    "sid": "GA-01581",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 744731,
+    "monitored": true,
+    "name": "BUCHAREST 2-CHISINAU-LAG-001(GEANT)",
+    "scid": "341937b8-6090-4f9f-87fc-0baea521d04c",
+    "service_type": "ETHERNET",
+    "sid": "GA-50052",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.173/30",
+          "2001:798:111:1::21/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.2015"
+      }
+    ],
+    "imsid": 661556,
+    "monitored": true,
+    "name": "REDCLARA-PAR-LHCONE",
+    "scid": "342dd7e8-af4d-49fd-9c10-e826ceb4906c",
+    "service_type": "L3-VPN",
+    "sid": "GS-00847",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/0"
+      }
+    ],
+    "imsid": 658553,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-027(ETH)",
+    "scid": "343898ce-fe8c-4a2c-a4f5-2668f9cbad13",
+    "service_type": "ETHERNET",
+    "sid": "GA-01207",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.48/31",
+          "2001:798::5d/126"
+        ],
+        "hostname": "mx2.ath.gr.geant.net",
+        "interface": "ae10.667"
+      }
+    ],
+    "imsid": 661415,
+    "monitored": true,
+    "name": "GRNET-AP1-CLS",
+    "scid": "343bb712-7756-4ebc-b6a4-478dee260c43",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00608",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661898,
+    "monitored": false,
+    "name": "LON-GROOVE-3",
+    "scid": "347ed421-cea2-4295-b487-3afd31e620e1",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00232",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.112.19/28",
+          "2001:799:cb2:2::3/64"
+        ],
+        "hostname": "srx2.ch.office.geant.net",
+        "interface": "ge-0/0/3.500"
+      }
+    ],
+    "imsid": 662925,
+    "monitored": false,
+    "name": "CITY-HOUSE-NETWORK-INFRASTRUCTURE",
+    "scid": "34923920-01d9-43ce-bacb-819dd85b1f61",
+    "service_type": "CORPORATE",
+    "sid": "GS-00447",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659257,
+    "monitored": true,
+    "name": "MILAN 2 CALDERA-MILAN 2 CALDERA-10GBE-025(ETH)",
+    "scid": "34c1588c-6c14-4580-954d-dec51fd415ed",
+    "service_type": "ETHERNET",
+    "sid": "GA-01335",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662182,
+    "monitored": true,
+    "name": "BUCHAREST-BUCHAREST-1GBE-004(ETH)",
+    "scid": "3528b55d-df6f-4a8b-a1be-426e18422321",
+    "service_type": "ETHERNET",
+    "sid": "GA-01598",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae34"
+      }
+    ],
+    "imsid": 732185,
+    "monitored": true,
+    "name": "MICROSOFT-EXPRESSROUTE-NORDUNET-FRA-LAG4",
+    "scid": "35410e69-7d9e-45ac-8455-908c985b69f8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01965",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.90.18/31",
+          "2001:798:1::23d/126"
+        ],
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.340"
+      }
+    ],
+    "imsid": 718228,
+    "monitored": true,
+    "name": "REDIRIS-AP2-IAS",
+    "scid": "35452849-6d0f-40f7-b6a8-dd898b27db5b",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00582",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "TENET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.132/31",
+          "2001:798:99:1::91/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae28.100"
+      }
+    ],
+    "imsid": 717803,
+    "monitored": true,
+    "name": "UK-TENET",
+    "scid": "356661ef-ba12-4c89-a16f-aa9a448f80b7",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-01192",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661776,
+    "monitored": false,
+    "name": "MIL2-GROOVE-2-MANAGEMENT",
+    "scid": "3571e7db-d717-47e5-b078-0e52ef4ddf35",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00251",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 708279,
+    "monitored": false,
+    "name": "BRU-LON-IX-BELNET-LON-13019",
+    "scid": "357d9e54-2c40-4862-a683-32dccac8b303",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00673",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.62/31",
+          "2001:798:1::175/126"
+        ],
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-20.333"
+      }
+    ],
+    "imsid": 745275,
+    "monitored": true,
+    "name": "GRNET-AP2-IAS",
+    "scid": "35b1187b-7502-4398-bf1f-807354be33c2",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00531",
+    "speed": 64424509440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CAREN"
+    ],
+    "endpoints": [],
+    "imsid": 663077,
+    "monitored": true,
+    "name": "DE-CAREN-IAS",
+    "scid": "35f4ada4-7c62-47fa-bd62-7b5b85f1af7a",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00565",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732386,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-003(GEANT)",
+    "scid": "3630599f-49ac-4051-b937-7594e865226d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01618",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [],
+    "imsid": 712384,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-GRNET-GR",
+    "scid": "3637d441-20fe-4217-8bca-b5233c6970a8",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01044",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 747864,
+    "monitored": true,
+    "name": "LJU-ZAG-LAG",
+    "scid": "364148ab-46f3-42cb-8212-a1838b8808f4",
+    "service_type": "ETHERNET",
+    "sid": "GA-02374",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:3919"
+      }
+    ],
+    "imsid": 747634,
+    "monitored": true,
+    "name": "AMS-HAM-MSE-02412",
+    "scid": "366042d8-9e09-4eb2-be7e-9185f699f568",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02412",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [],
+    "imsid": 736761,
+    "monitored": true,
+    "name": "GRNET-BGP-LU-COC",
+    "scid": "3661d66f-9a59-4832-8f34-c4c04e39c724",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01007",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae2.0"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae7.0"
+      }
+    ],
+    "imsid": 708740,
+    "monitored": false,
+    "name": "GEN-MAD-IPTRUNK",
+    "scid": "36df3835-1f80-418b-b212-c5a30e973a02",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00037",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "UBUNTUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/3/2.602"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae22.602"
+      }
+    ],
+    "imsid": 705895,
+    "monitored": true,
+    "name": "LON-LON-UBUNTUNET-WACREN-20103",
+    "scid": "36e11a6a-4a2e-40e8-b602-c8802e96146f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00731",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663224,
+    "monitored": false,
+    "name": "AAI-AMS-NL-VLAN75",
+    "scid": "36ec0d6b-209d-4ed3-aee4-cc0a068c8396",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00089",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 747271,
+    "monitored": true,
+    "name": "HEANET-AP1-LAG",
+    "scid": "36efa0f4-8c60-4649-8c91-8dbf4a2c3aab",
+    "service_type": "ETHERNET",
+    "sid": "GA-01925",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RESTENA"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae18"
+      }
+    ],
+    "imsid": 739247,
+    "monitored": true,
+    "name": "RESTENA-AP1-LAG",
+    "scid": "3728ab0f-f357-4ee9-b835-53005f454da4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01952",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659174,
+    "monitored": true,
+    "name": "MILAN 2 CALDERA-MILAN 2 CALDERA-1GBE-009(ETH)",
+    "scid": "37331f33-6f61-4122-a5ae-ec1802c37758",
+    "service_type": "ETHERNET",
+    "sid": "GA-01521",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "10.101.0.1/30"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/2.18"
+      }
+    ],
+    "imsid": 661962,
+    "monitored": false,
+    "name": "VIRGIN-MEDIA-EX1-LON2-TO-CAM-SRX-VLAN18",
+    "scid": "374c7649-9a48-49d6-b2d5-8750ae36099e",
+    "service_type": "CORPORATE",
+    "sid": "GS-00005",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MANLAN"
+    ],
+    "endpoints": [],
+    "imsid": 727572,
+    "monitored": false,
+    "name": "PAR-PAR-MANLAN-SURFNET-60096414",
+    "scid": "375cd0d4-5362-4d73-aa88-d34fefb0b468",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02316",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.fra.de.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 739044,
+    "monitored": true,
+    "name": "FRA-FRA-800G-LAG",
+    "scid": "376d2dc2-2f17-410a-bfa5-8e86556ba986",
+    "service_type": "ETHERNET",
+    "sid": "GA-02460",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 677595,
+    "monitored": false,
+    "name": "FRA OOB LINK",
+    "scid": "377b4678-5e92-40a7-aa6d-e8e52f432575",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00399",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae22"
+      }
+    ],
+    "imsid": 727952,
+    "monitored": true,
+    "name": "VIENNA-VIENNA-LAG-001(GEANT)",
+    "scid": "379c35ec-a121-4ba7-8bb5-eae5879dd02b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01859",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662496,
+    "monitored": true,
+    "name": "TELIA-FRA-LAG",
+    "scid": "37a1be5e-ffcb-4aa9-9801-a9b9a3c680ba",
+    "service_type": "ETHERNET",
+    "sid": "GA-01936",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.2704"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-124045"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-20:712"
+      }
+    ],
+    "imsid": 745413,
+    "monitored": true,
+    "name": "SLCUTH-02489",
+    "scid": "37ab7293-5eef-4521-bccb-9e71fc8f17d4",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02489",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [],
+    "imsid": 661705,
+    "monitored": false,
+    "name": "PIONIER-TEMPORARYVLAN",
+    "scid": "37c0cef1-9be8-40e0-9edd-9eacc5859919",
+    "service_type": "GEANT IP",
+    "sid": "GS-00494",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ge-0/3/7"
+      }
+    ],
+    "imsid": 662209,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-1GBE-007(ETH)",
+    "scid": "37e79eb5-256d-4a21-ba32-8cbcdf64288c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01546",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NKN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.820"
+      }
+    ],
+    "imsid": 734561,
+    "monitored": false,
+    "name": "NL-NKN",
+    "scid": "37f5e9a8-2a1e-4563-a2d7-d15074187da3",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00899",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.106.128/31",
+          "2001:798:fc00:28::1/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/3.22"
+      }
+    ],
+    "imsid": 678566,
+    "monitored": false,
+    "name": "PSMP-GN-OWD-LON-UK.GEANT.ORG",
+    "scid": "38019230-9f37-4c26-b7cc-ee9e9a959928",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00365",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.217/30",
+          "2001:798:1::4d/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae12.333"
+      }
+    ],
+    "imsid": 663118,
+    "monitored": true,
+    "name": "GARR-AP2-IAS",
+    "scid": "38238cff-d62e-4c2a-a2ae-57ff08c7f64a",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00571",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661374,
+    "monitored": false,
+    "name": "DEEPFIELD-IDRAC-PAR-FR",
+    "scid": "38703357-9007-4565-84c2-e5ce1fa6c8ff",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00133",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 724380,
+    "monitored": false,
+    "name": "VIENNA-VERIZON-2-15133-AT-1",
+    "scid": "38734f84-1ffb-46dd-ba2c-7af19e87c1b4",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-02224",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "lon-lon_MSExpressRoutesTest_NORDUNET-SURFNET_16033",
+    "scid": "38a70b5c-2066-44cd-b64a-88e39cb99675",
+    "service_type": null,
+    "sid": "DS-34705",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "CESNET-GN-XIFI-VPN-PROXY-PRAGUE-L3VPN",
+    "scid": "38c1cc49-2a59-4943-b2b0-7c4e727398e4",
+    "service_type": null,
+    "sid": "GS-01062",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.237/31",
+          "2001:798:cc:1::aa/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae4.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.236/31",
+          "2001:798:cc:1::a9/126"
+        ],
+        "hostname": "rt0.gen.ch.geant.net",
+        "interface": "lag-4.0"
+      }
+    ],
+    "imsid": 739738,
+    "monitored": true,
+    "name": "GEN-MAR-IPTRUNK",
+    "scid": "38c31549-491d-4f7c-b7a8-93b9a8920e45",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00038",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707277,
+    "monitored": true,
+    "name": "VIE-ZAG-LAG",
+    "scid": "38cc0fb2-467a-413d-a01a-46782ef65ba6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01870",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ACONET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae18"
+      }
+    ],
+    "imsid": 659377,
+    "monitored": true,
+    "name": "ACONET-AP2-LAG",
+    "scid": "3904f984-6286-4de8-9812-9324d22a981c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01770",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.411"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.3"
+      }
+    ],
+    "imsid": 706055,
+    "monitored": true,
+    "name": "REDIRIS-UCLM-EXPRESSROUTE-VLAN411",
+    "scid": "391b49a2-e3e8-48f2-8650-712782de591f",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01166",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.73/30",
+          "2001:798:1::5d/126"
+        ],
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-20.333"
+      }
+    ],
+    "imsid": 747283,
+    "monitored": true,
+    "name": "HEANET-AP1-IAS",
+    "scid": "39219259-4c80-4fa0-aefe-d9f2eb9d7d24",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00572",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 709297,
+    "monitored": false,
+    "name": "EXFO-MANAGEMENT-VLAN30",
+    "scid": "3927ff13-ec55-4a83-b905-64b4a8b3ac40",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00161",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [],
+    "imsid": 733111,
+    "monitored": false,
+    "name": "FRA-GEN-CERN-DFN-3",
+    "scid": "3938a77e-d606-4cd0-a847-6514a28d3db0",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02445",
+    "speed": 536870912000,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/0/3.0"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/1/4"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/1/4.0"
+      }
+    ],
+    "imsid": 734546,
+    "monitored": true,
+    "name": "AMS-PAR-LOFAR-RENATER-NETHERLIGHT-10001",
+    "scid": "3961d120-d24f-4ed8-b381-2f1f8f8e1ffe",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00784",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707278,
+    "monitored": true,
+    "name": "POZ-VIE-LAG",
+    "scid": "3986305e-e4b8-410e-9eaa-c43e94f8b266",
+    "service_type": "ETHERNET",
+    "sid": "GA-01869",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NEA3R"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-4/1/4.2050"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.2050"
+      }
+    ],
+    "imsid": 738640,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-ESNET-NEA3R",
+    "scid": "3999f781-b111-4b2f-8a94-a7579a0f7193",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-02250",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [],
+    "imsid": 714989,
+    "monitored": true,
+    "name": "SURF-AMS-LON1-SPECTRUM SERVICE 1",
+    "scid": "39b84ae2-4804-465e-b50d-7fb37c171ccd",
+    "service_type": "GEANT SPECTRUM SERVICE",
+    "sid": "GS-00071",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708181,
+    "monitored": false,
+    "name": "PS-SOF-BG-BWCTL",
+    "scid": "39beb7b4-28c8-4bfe-a4bc-e6fbfa6f761d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00353",
+    "speed": 104857600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "UBUNTUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.402"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae17.402"
+      }
+    ],
+    "imsid": 735618,
+    "monitored": true,
+    "name": "AMS-LON-MISC-UBUNTUNET-CANARIE-170352",
+    "scid": "39ddcbb1-e292-4246-a52c-f70f74902cef",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00646",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RARE"
+    ],
+    "endpoints": [],
+    "imsid": 714367,
+    "monitored": false,
+    "name": "FRA-HAM-WP7T2SF-RARE-20104-FRA",
+    "scid": "39e32e1d-003a-4bd7-af20-f7a111826336",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00691",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708165,
+    "monitored": false,
+    "name": "OOB-SINGAREN-LON2-UK",
+    "scid": "39e6c438-9dde-4138-bd78-44a452a3dfbe",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00243",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.158/31",
+          "2001:798:99:1::fd/126"
+        ],
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "ae10.100"
+      }
+    ],
+    "imsid": 714069,
+    "monitored": true,
+    "name": "RENAM-AP2",
+    "scid": "39f75ada-0cc7-4f4c-929d-85c7a4901186",
+    "service_type": "GEANT IP",
+    "sid": "GS-00501",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.46/31",
+          "2001:798:cc:1::79/126"
+        ],
+        "hostname": "rt1.kie.ua.geant.net",
+        "interface": "ae3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.47/31",
+          "2001:798:cc:1::7a/126"
+        ],
+        "hostname": "rt0.poz.pl.geant.net",
+        "interface": "lag-2.0"
+      }
+    ],
+    "imsid": 740201,
+    "monitored": true,
+    "name": "KIE-POZ-IPTRUNK",
+    "scid": "39fdfad7-8e05-49c4-8685-43b0c2aecd2a",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00046",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/1/6.1220"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae30.1220"
+      }
+    ],
+    "imsid": 734115,
+    "monitored": true,
+    "name": "AMS-PAR-INFINICORTEX-ESNET-RENATER-15030",
+    "scid": "3a0003dd-c73b-4e06-926a-62861f7d493a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00653",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.165/30",
+          "2001:798:111:1::15/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae10.2030"
+      }
+    ],
+    "imsid": 661732,
+    "monitored": true,
+    "name": "JISC-AP1-LHCONE",
+    "scid": "3a65bfbf-21dd-45d2-acad-980c6f61cfee",
+    "service_type": "L3-VPN",
+    "sid": "GS-00832",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.3020"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae2.3020"
+      }
+    ],
+    "imsid": 736070,
+    "monitored": false,
+    "name": "AMS-PAR-SINET-SD-WAN-SINET-SINET-17090",
+    "scid": "3a795c56-2d2b-430a-94f0-be94d9a6a76e",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00659",
+    "speed": 150323855360,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "194.141.252.254/30",
+          "2001:4b58:acad:252::62/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-101.200"
+      }
+    ],
+    "imsid": 744952,
+    "monitored": true,
+    "name": "BREN-AP2",
+    "scid": "3acbcb54-d600-4814-846b-7caf21fdb435",
+    "service_type": "GEANT IP",
+    "sid": "GS-00439",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "lon-lon_GEANTOPEN_NEA3R-TENET_18097",
+    "scid": "3acf4897-6613-4d4f-a757-0d3eb5e2947f",
+    "service_type": null,
+    "sid": "DS-44443",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679112,
+    "monitored": true,
+    "name": "TAL-TAL-LAG",
+    "scid": "3ae13919-0b82-4662-b408-f456ed973f5e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01735",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-3/0/0"
+      }
+    ],
+    "imsid": 659164,
+    "monitored": true,
+    "name": "POZNAN-POZNAN-10GBE-009(ETH)",
+    "scid": "3ae1bb23-291f-45c9-8da2-4f36c076973b",
+    "service_type": "ETHERNET",
+    "sid": "GA-02137",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae23.600"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae14.600"
+      }
+    ],
+    "imsid": 734173,
+    "monitored": true,
+    "name": "AMS-GEN-NREN-IX-AMSIX-SWITCH-18008",
+    "scid": "3af45187-c28b-4e1b-8403-dcd467f9a92d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00638",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "185.203.16.35/29"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-26.0"
+      }
+    ],
+    "imsid": 747942,
+    "monitored": true,
+    "name": "SETCOR-HR-61211",
+    "scid": "3b4cef24-edd8-499b-82f4-71f9c0212321",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00942",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.29/30",
+          "2001:798:13:10aa::1/126"
+        ],
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae11.600"
+      }
+    ],
+    "imsid": 725106,
+    "monitored": true,
+    "name": "CESNET-AP1",
+    "scid": "3b63449e-d8ff-4c0c-ac63-6075fbcb356e",
+    "service_type": "GEANT IP",
+    "sid": "GS-00444",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "T-SYSTEMS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "94.100.252.88/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae25.333"
+      }
+    ],
+    "imsid": 732135,
+    "monitored": true,
+    "name": "DE-TSYSTEMS-IAS",
+    "scid": "3b687c63-129b-4fac-aede-1c84a9103aad",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00927",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708763,
+    "monitored": false,
+    "name": "NL-T-SYSTEMS-IAS-1",
+    "scid": "3b744d2a-5202-4eb8-8ed7-0c25020062dd",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00940",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707413,
+    "monitored": true,
+    "name": "RIG-RIG-LAG",
+    "scid": "3b9229a4-3f7d-4969-b5a0-8fcae0d7c9b4",
+    "service_type": "ETHERNET",
+    "sid": "GA-02030",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663053,
+    "monitored": false,
+    "name": "GEN-GROOVE-1",
+    "scid": "3be6cb2f-73a2-4d60-83cd-093171bf441c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00181",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NETHERLIGHT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae34"
+      }
+    ],
+    "imsid": 668883,
+    "monitored": true,
+    "name": "NL-NETHERLIGHT-100G-IP1",
+    "scid": "3be74e6d-2bc9-41df-b4aa-3dca92bf90a7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01593",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx1.am.office.geant.net",
+        "interface": "fxp0"
+      },
+      {
+        "addresses": [
+          "172.16.1.2/24"
+        ],
+        "hostname": "srx1.am.office.geant.net",
+        "interface": "fxp0.0"
+      }
+    ],
+    "imsid": 708164,
+    "monitored": false,
+    "name": "SRX1-AMS-FXP0",
+    "scid": "3bfda9c7-5273-4062-b5d5-126b045e7aff",
+    "service_type": "CORPORATE",
+    "sid": "GS-01534",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.137/30"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.1"
+      }
+    ],
+    "imsid": 732673,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-CBG-LAB",
+    "scid": "3c5bc75f-4bfd-4544-93e1-93697d1b5393",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-00791",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx2.am.office.geant.net",
+        "interface": "ge-0/0/1"
+      }
+    ],
+    "imsid": 677379,
+    "monitored": true,
+    "name": "PHY INFASTRUCTURE | CONNECTION TO SRX1",
+    "scid": "3c691b34-5d5c-49eb-8d74-07ef1bc21a37",
+    "service_type": "ETHERNET",
+    "sid": "GA-01247",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.vie.at - Traffic - ae25 - LAG PRIVATE AWS SRF9940295",
+    "scid": "3c774ed1-2fe5-4f1f-ad7f-b4224321216f",
+    "service_type": null,
+    "sid": "GA-01856",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662220,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-047(ETH)",
+    "scid": "3cb58c52-e106-4384-a864-044d3886e67a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01582",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "10.101.0.2/30",
+          "2001:799:cb2:1::1/64"
+        ],
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/4.18"
+      }
+    ],
+    "imsid": 662977,
+    "monitored": false,
+    "name": "VIRGIN_MEDIA_EX1_LON2_TO_CAM_SRX_VLAN18-CH",
+    "scid": "3cd7a22f-5f82-4573-8d52-a9ccfd6613ea",
+    "service_type": "CORPORATE",
+    "sid": "GS-00003",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.237/30",
+          "2001:798:111:1::9/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-20.111"
+      }
+    ],
+    "imsid": 747853,
+    "monitored": true,
+    "name": "ARNES-AP2-LHCONE",
+    "scid": "3cda8a29-37e0-4259-ad2b-10742ef98987",
+    "service_type": "L3-VPN",
+    "sid": "GS-00808",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.97/30",
+          "2001:798:17:10aa::d/126"
+        ],
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae10.1930"
+      }
+    ],
+    "imsid": 661976,
+    "monitored": true,
+    "name": "FCCN-AP1",
+    "scid": "3cf306a4-2eaf-4ae7-8dfa-29fa749010b4",
+    "service_type": "GEANT IP",
+    "sid": "GS-00459",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "LITNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.213/30",
+          "2001:798:1::f5/126"
+        ],
+        "hostname": "rt0.kau.lt.geant.net",
+        "interface": "lag-21.333"
+      }
+    ],
+    "imsid": 746533,
+    "monitored": true,
+    "name": "LITNET-AP1-IAS",
+    "scid": "3cf3aefa-9960-47e0-b8c6-ad9b8e3d1190",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00534",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "IUCC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.1/30",
+          "2001:798:14:20aa::1/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae22.100"
+      }
+    ],
+    "imsid": 729999,
+    "monitored": true,
+    "name": "IUCC-AP2",
+    "scid": "3d1322b3-bb1a-4d2a-b0c0-069f6f8c3264",
+    "service_type": "GEANT IP",
+    "sid": "GS-00478",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.72/31",
+          "2001:798:111:1::101/126"
+        ],
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-20.111"
+      }
+    ],
+    "imsid": 743311,
+    "monitored": true,
+    "name": "JISC-AP2-LHCONE",
+    "scid": "3d1558ee-e2a4-4ecc-aebf-cd720839816e",
+    "service_type": "L3-VPN",
+    "sid": "GS-02474",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/3/2"
+      }
+    ],
+    "imsid": 669237,
+    "monitored": true,
+    "name": "UBUNTUNET LON IP LL",
+    "scid": "3d294ddd-c1f7-464b-a68e-496c24185b56",
+    "service_type": "ETHERNET",
+    "sid": "GA-01463",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [],
+    "imsid": 736737,
+    "monitored": false,
+    "name": "INTERNET2-WIXRTT-TEST",
+    "scid": "3d2f3b38-5b75-4f74-8330-b267524df6c6",
+    "service_type": "GEANT IP",
+    "sid": "GS-00476",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658737,
+    "monitored": true,
+    "name": "PARIS-FLOWMON-IDRAC-1GBE-005(ETH)",
+    "scid": "3d5aab2f-b839-4a58-b5ac-5698699e5496",
+    "service_type": "ETHERNET",
+    "sid": "GA-01410",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 712093,
+    "monitored": false,
+    "name": "HA-77DCB24D4F",
+    "scid": "3d678eef-61b6-484e-b642-f22fd4386b2d",
+    "service_type": "GTS",
+    "sid": "GS-01176",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.27.1/24"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.992"
+      }
+    ],
+    "imsid": 714244,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-HEL-FI",
+    "scid": "3d67f605-1196-42ea-a968-403953b3b4d7",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00130",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.222/31",
+          "2001:798:cc:1::75/126"
+        ],
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae4.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.223/31",
+          "2001:798:cc:1::76/126"
+        ],
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-4.0"
+      }
+    ],
+    "imsid": 739468,
+    "monitored": true,
+    "name": "BIL-PAR-IPTRUNK",
+    "scid": "3d795236-0bc9-4c0b-9b7e-4c56f50b9826",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00016",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.76/31",
+          "2001:798:cc::79/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.77/31",
+          "2001:798:cc::7a/126"
+        ],
+        "hostname": "rt0.gen.ch.geant.net",
+        "interface": "lag-1.0"
+      }
+    ],
+    "imsid": 739713,
+    "monitored": true,
+    "name": "GEN-GEN-IPTRUNK",
+    "scid": "3d9cb1c6-027f-4d95-9a74-0f53d9872bf0",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02464",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.44/31",
+          "2001:798:cc:1::d/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.45/31",
+          "2001:798:cc:1::e/126"
+        ],
+        "hostname": "rt0.vie.at.geant.net",
+        "interface": "lag-9.0"
+      }
+    ],
+    "imsid": 740790,
+    "monitored": false,
+    "name": "BUD-VIE-IPTRUNK",
+    "scid": "3e75c7af-7253-4f8d-ac4a-959bff2e8162",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00026",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.gen.ch.geant.net",
+        "interface": "lag-5"
+      }
+    ],
+    "imsid": 739734,
+    "monitored": true,
+    "name": "FRA-GEN-1.6T-LAG",
+    "scid": "3e82f4ab-f77c-4ea7-98b4-69189ccfd08b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01888",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [],
+    "imsid": 709737,
+    "monitored": true,
+    "name": "CARNET EUMETCAST AP2",
+    "scid": "3e87b238-ee33-428c-b4aa-2afbfbf786ff",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01098",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "addresses": [
+          "10.0.0.2/28"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "irb.3006"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae30.3006"
+      }
+    ],
+    "imsid": 733017,
+    "monitored": false,
+    "name": "TAAS-GTS-IMS-MEDIATION-FRANKFURT",
+    "scid": "3ea7703d-27d9-4281-a89d-83925bcae38b",
+    "service_type": "L3-VPN",
+    "sid": "GS-00866",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 702120,
+    "monitored": true,
+    "name": "TEST-GOC-LINK (DO NOT OPEN A TICKET)",
+    "scid": "3ea9baba-1cfc-40d7-b221-a73cb86409dd",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00376",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.15"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4092"
+      }
+    ],
+    "imsid": 739680,
+    "monitored": true,
+    "name": "BELNET-NCCN-EXPRESSROUTE-VLAN4092",
+    "scid": "3eb5830f-634e-4293-9fc7-55a3dcbb18e4",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01126",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663152,
+    "monitored": false,
+    "name": "PSMP-BUC-RO-VLAN124",
+    "scid": "3ecf200c-40a5-4899-9074-e3cc7354dbdd",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00364",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743167,
+    "monitored": true,
+    "name": "COR-COR-MGMT-LAG",
+    "scid": "3f12b13d-a18a-4b04-be5a-d67a58f9e260",
+    "service_type": "ETHERNET",
+    "sid": "GA-02617",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RASH"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.172/31",
+          "2001:798:1::91/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-24.333"
+      }
+    ],
+    "imsid": 745019,
+    "monitored": true,
+    "name": "RASH-AP2-IAS",
+    "scid": "3f1a013b-8d15-41ed-91a3-e852f9529b19",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00540",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-224050"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:3507"
+      },
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.951"
+      }
+    ],
+    "imsid": 745317,
+    "monitored": true,
+    "name": "GEANT_EPIPE_224050",
+    "scid": "3f1c0443-a1c9-4a6e-baaf-1c5630bd9a3f",
+    "service_type": "ETHERNET",
+    "sid": "GS-02515",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "T-SYSTEMS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "80.158.74.253/31"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae27.4001"
+      }
+    ],
+    "imsid": 734863,
+    "monitored": false,
+    "name": "NL-T-SYSTEMS-IAS",
+    "scid": "3f215178-a475-499a-b9c2-e7f422af6f56",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-02271",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/18"
+      }
+    ],
+    "imsid": 658648,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-043(ETH)",
+    "scid": "3f23736f-1a0e-49ed-b650-9e8e40f5668c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01244",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.141/30"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.2"
+      }
+    ],
+    "imsid": 732658,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-NCI-CSIRO",
+    "scid": "3f3093de-461c-4559-8dd2-fe8ea7e7b4ac",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01084",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.POZ.PL.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-3/0/2.107"
+      },
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/6"
+      },
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/6.107"
+      }
+    ],
+    "imsid": 737234,
+    "monitored": false,
+    "name": "PRA-POZ-RARE-BMS9",
+    "scid": "3f320a27-40e2-4968-93f1-2677d3fbb71e",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00751",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ams-fra_MISC_SURFNET-DFN_17070",
+    "scid": "3f4f3f8b-8f4e-48af-8691-7ebe8643350d",
+    "service_type": null,
+    "sid": "DS-40615",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.MAD.ES.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 677765,
+    "monitored": false,
+    "name": "MAD OOB LINK",
+    "scid": "3f69f5e6-e42e-4116-8be4-637697c29663",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00407",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.gen.ch - Traffic - ae7 - LAG INFRASTRUCTURE BACKBONE | GEN-MAD |",
+    "scid": "3fa425fb-9737-457d-a8ab-c9d55bb86c3e",
+    "service_type": null,
+    "sid": "GA-01879",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FCT"
+    ],
+    "endpoints": [],
+    "imsid": 712373,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-FCT-1-PT",
+    "scid": "3fb8df59-fc98-43d1-af1b-2bd04574d245",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01017",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "149.6.182.114/29",
+          "2001:978:2:26::2/112"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae19.0"
+      }
+    ],
+    "imsid": 708282,
+    "monitored": true,
+    "name": "COGENT-GWS-BUD",
+    "scid": "3fc038e5-7e9e-4969-bab9-dd92030d8a4c",
+    "service_type": "GWS - UPSTREAM",
+    "sid": "GS-00065",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ams-lon_GEANTOpen_SINET-SINGAREN_CAE1_19120_VL2361",
+    "scid": "3fd04e5f-e3d2-4882-91fe-11ad0bc9ba29",
+    "service_type": null,
+    "sid": "GS-00958",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/47"
+      }
+    ],
+    "imsid": 658836,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-057(ETH)",
+    "scid": "3fe0469d-f339-4859-a9f0-879cd115dd55",
+    "service_type": "ETHERNET",
+    "sid": "GA-01230",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.182/31",
+          "2001:798:cc:1::e1/126"
+        ],
+        "hostname": "rt0.fra.de.geant.net",
+        "interface": "lag-5.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.183/31",
+          "2001:798:cc:1::e2/126"
+        ],
+        "hostname": "rt0.gen.ch.geant.net",
+        "interface": "lag-5.0"
+      }
+    ],
+    "imsid": 739737,
+    "monitored": true,
+    "name": "FRA-GEN-IPTRUNK",
+    "scid": "40573045-0dd0-4623-a68f-36044ba8523c",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00034",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 718917,
+    "monitored": false,
+    "name": "DCN_MANAGEMENT_ZAG",
+    "scid": "406fe4ba-65b4-4f03-adcb-ab523f1d3b34",
+    "service_type": "SERVER LINK",
+    "sid": "GS-01218",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "80.249.210.137/21",
+          "2001:7f8:1::a502:1320:1/64"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae12.100"
+      }
+    ],
+    "imsid": 734937,
+    "monitored": false,
+    "name": "IX-PEERINGS-IN-AMS-IX",
+    "scid": "40792b2f-837f-493c-94a9-1a99ad9342ea",
+    "service_type": "IP PEERING - NON R&E (PUBLIC)",
+    "sid": "GS-00955",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.106.149/30",
+          "2001:798:bb:1::d/126"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/0/2.0"
+      }
+    ],
+    "imsid": 727045,
+    "monitored": false,
+    "name": "DTN-LON2-10G-DATA",
+    "scid": "40bb5a5c-adba-4607-b39c-9d9597d1ab53",
+    "service_type": "SERVER LINK",
+    "sid": "GS-02355",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae15"
+      }
+    ],
+    "imsid": 733833,
+    "monitored": true,
+    "name": "FR-ITER-LAG",
+    "scid": "40d68758-67a3-4aa7-8b9a-308698a0c96f",
+    "service_type": "ETHERNET",
+    "sid": "GA-02416",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/1/6"
+      }
+    ],
+    "imsid": 733211,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-030(GEANT)",
+    "scid": "40f1ef9e-5fcc-4cfb-b0cc-01a406ab5a0a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01330",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "equipment": "MIL01-MTC6-1",
+        "port": "2-A-1-S9"
+      },
+      {
+        "equipment": "MIL01-MTC6-1",
+        "port": "2-A-1-S9"
+      },
+      {
+        "equipment": "MIL01-MTC6-1",
+        "port": "2-A-1-S9"
+      },
+      {
+        "equipment": "MIL01-MTC6-1",
+        "port": "2-A-1-S9"
+      }
+    ],
+    "imsid": 732748,
+    "monitored": true,
+    "name": "GARR-GEN1-MIL1 SPECTRUM SERVICE 1",
+    "scid": "4101396b-fd48-45cb-b38d-cc23ec7f795a",
+    "service_type": "GEANT SPECTRUM SERVICE",
+    "sid": "GS-02603",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.114/31",
+          "2001:798:1::219/126"
+        ],
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae10.333"
+      }
+    ],
+    "imsid": 714070,
+    "monitored": true,
+    "name": "RENAM-AP1-IAS",
+    "scid": "4118479e-f597-461e-8213-e4213301a0b3",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00541",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 703117,
+    "monitored": true,
+    "name": "MAD-PAR-LAG",
+    "scid": "4120f4b8-5300-4bbe-afcc-c7ad54a75221",
+    "service_type": "ETHERNET",
+    "sid": "GA-01825",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "REDIRIS-AP1-CLS|ASN766",
+    "scid": "412121b4-d1fc-4091-9316-b36e1dbdefb4",
+    "service_type": null,
+    "sid": "GS-00613",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae13"
+      }
+    ],
+    "imsid": 731115,
+    "monitored": true,
+    "name": "GOOGLE-FRA15-LAG",
+    "scid": "4131122c-3646-4d48-a141-9fcc09ea3d82",
+    "service_type": "ETHERNET",
+    "sid": "TE-01943",
+    "speed": 32212254720,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "LITNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 745327,
+    "monitored": true,
+    "name": "LITNET-AP2-LAG",
+    "scid": "413f5dcd-71f2-4eb8-abd9-2110fe993351",
+    "service_type": "ETHERNET",
+    "sid": "GA-02071",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.3909"
+      },
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.11"
+      }
+    ],
+    "imsid": 707121,
+    "monitored": true,
+    "name": "NORDUNET-LTU-EXPRESSROUTE-VLAN3909",
+    "scid": "41479a30-9611-4916-b26b-e85a5284458c",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01153",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "VERIZON"
+    ],
+    "endpoints": [],
+    "imsid": 731620,
+    "monitored": false,
+    "name": "FRANKFURT-VERIZON-2-15133-DE-2",
+    "scid": "416dc93b-5e72-49e3-8027-a0067c0dbb26",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00933",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.415"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae40.415"
+      }
+    ],
+    "imsid": 719496,
+    "monitored": true,
+    "name": "FRA-MAD-ORACLE-REDIRIS-22010-VL415",
+    "scid": "419195fb-dcce-4588-a5fe-f7e95c69c6f7",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02096",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "10.1.0.1/24"
+        ],
+        "hostname": "srx2.ch.office.geant.net",
+        "interface": "ge-0/0/3.996"
+      }
+    ],
+    "imsid": 663240,
+    "monitored": false,
+    "name": "CITY-HOUSE-LAB-INFINERA-MGMT-NETWORK",
+    "scid": "4198f124-51f4-41bc-9759-dca44d793ecc",
+    "service_type": "CORPORATE",
+    "sid": "GS-01212",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINGAREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/5"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/5.3179"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3179"
+      }
+    ],
+    "imsid": 726769,
+    "monitored": false,
+    "name": "LON-LON2-GEANT2-SINGAREN-SINGAREN-17085",
+    "scid": "41d6eb6d-7112-4a7c-a7fc-715040ac6199",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00724",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661419,
+    "monitored": false,
+    "name": "PSMP-PAR-FR-DRAC",
+    "scid": "41feda79-33c7-49a7-bde6-24b7119d411d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00366",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.90.14/31",
+          "2001:798:1::231/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae24.0"
+      }
+    ],
+    "imsid": 731914,
+    "monitored": true,
+    "name": "DE-EXOSCALE-IAS",
+    "scid": "420a7118-5bcd-4bf8-9f9a-2f5deb5fd3e7",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00604",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 712569,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-PRA-CZ",
+    "scid": "421078d8-ea4e-4cb6-b035-e9f78b5a0984",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00126",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ROEDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.buc.ro.geant.net",
+        "interface": "xe-5/0/6"
+      },
+      {
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "xe-0/1/3"
+      },
+      {
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "xe-0/1/3.0"
+      },
+      {
+        "hostname": "rt1.buc.ro.geant.net",
+        "interface": "xe-5/0/6.0"
+      }
+    ],
+    "imsid": 743607,
+    "monitored": true,
+    "name": "BUC-CHI-RENAM-ROEDUNET-240752",
+    "scid": "422233ff-182c-4e42-9498-a4b305169b89",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-02576",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "lon-lon-GEANTOpen-AARNET-NETHERLIGHT-21003",
+    "scid": "423c2c55-96c3-44bd-abec-b3216b1ce93b",
+    "service_type": null,
+    "sid": "DS-53405",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ASNET-TW"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/1/5"
+      }
+    ],
+    "imsid": 742817,
+    "monitored": true,
+    "name": "NL-ASNET-TW-LL",
+    "scid": "423cf5d9-086a-4edd-90af-3a2c970a5314",
+    "service_type": "ETHERNET",
+    "sid": "GA-01635",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661197,
+    "monitored": false,
+    "name": "LON2-GROOVE-1-MANAGEMENT",
+    "scid": "425875d0-eed3-44c7-879e-c558c1063f90",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00239",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658691,
+    "monitored": false,
+    "name": "LON2-PRD-ESX11-VSAN-LAG",
+    "scid": "426f601c-483f-4046-9b01-8d40cc76c27e",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01712",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.4"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240581"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4072"
+      }
+    ],
+    "imsid": 744226,
+    "monitored": true,
+    "name": "MSESCIENSAN-02535",
+    "scid": "427e94ed-8c99-4a0e-aae4-b8e8dca5c2b4",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02535",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/2"
+      },
+      {
+        "addresses": [
+          "62.40.112.34/31"
+        ],
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/2.0"
+      }
+    ],
+    "imsid": 708237,
+    "monitored": false,
+    "name": "SRX1-CAM-TO-SWITCHCLUSTER-VME0",
+    "scid": "427f1af0-ddd2-4a15-bf80-1edcc8f07057",
+    "service_type": "CORPORATE",
+    "sid": "GS-01748",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662988,
+    "monitored": false,
+    "name": "VM-AMS-NL-IDRACS-250",
+    "scid": "4289a714-3b4c-4cb1-b446-3f66ed65a55c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00384",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662218,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-1GBE-014(ETH)",
+    "scid": "429e5a17-a495-4972-bb00-09724c29debc",
+    "service_type": "ETHERNET",
+    "sid": "GA-01642",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661716,
+    "monitored": false,
+    "name": "PRA-GROOVE-1-MANAGEMENT",
+    "scid": "42b2a681-de66-4ece-8d38-7dfc675777a7",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00280",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [],
+    "imsid": 739842,
+    "monitored": false,
+    "name": "GEN-PAR-CERN-INTERNET2-22065",
+    "scid": "42fddcea-ec9b-4141-bfcb-5113a64f7ef6",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-2558",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae8"
+      }
+    ],
+    "imsid": 658666,
+    "monitored": false,
+    "name": "LON2-PRD-ESX12-ESXI-TRAFFIC",
+    "scid": "431944c2-5b39-43b8-ba84-f4140db6252f",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01698",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "IUCC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.89/30",
+          "2001:798:1::6d/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae22.333"
+      }
+    ],
+    "imsid": 729998,
+    "monitored": true,
+    "name": "IUCC-AP2-IAS",
+    "scid": "43367b26-0a2a-4f38-84ad-453522b049a1",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00533",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.80/31",
+          "2001:798:cc:1::e9/126"
+        ],
+        "hostname": "rt0.ams.nl.geant.net",
+        "interface": "lag-3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.81/31",
+          "2001:798:cc:1::ea/126"
+        ],
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-4.0"
+      }
+    ],
+    "imsid": 744129,
+    "monitored": true,
+    "name": "AMS-BRU-IPTRUNK",
+    "scid": "4354685f-d1e0-4c87-a92e-e490ab6c6647",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00008",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/1/3"
+      }
+    ],
+    "imsid": 720004,
+    "monitored": true,
+    "name": "SCION1ILO.GEN.CH-EXTERNAL-LL",
+    "scid": "435cab2c-b6cf-4b6e-a33c-ec9a3f9e83b9",
+    "service_type": "ETHERNET",
+    "sid": "GA-02187",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.57/30",
+          "2001:798:99:1::7d/126"
+        ],
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-20.1"
+      }
+    ],
+    "imsid": 743310,
+    "monitored": true,
+    "name": "JISC-AP2",
+    "scid": "436002e6-83dc-403a-9b26-3d0618a7595e",
+    "service_type": "GEANT IP",
+    "sid": "GS-00480",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662180,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-005(ETH)",
+    "scid": "4371dfdb-55d3-4f26-9de7-c39b257a5bd0",
+    "service_type": "ETHERNET",
+    "sid": "GA-01614",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "COLT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae29"
+      }
+    ],
+    "imsid": 732120,
+    "monitored": true,
+    "name": "COLT-GWS-FRA-LAG",
+    "scid": "43b33ee4-e828-42a6-99da-77c2c84d8f5d",
+    "service_type": "ETHERNET",
+    "sid": "GA-02113",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:3915"
+      }
+    ],
+    "imsid": 747633,
+    "monitored": true,
+    "name": "AMS-HAM-MSE-01161",
+    "scid": "43c0d2fd-e899-48a7-90fe-6d9a2d8fe91c",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-01161",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "APPLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae45"
+      }
+    ],
+    "imsid": 730218,
+    "monitored": true,
+    "name": "DE-APPLE-LAG",
+    "scid": "43d11dc8-16c5-4132-977a-e957d56de5fd",
+    "service_type": "ETHERNET",
+    "sid": "GA-02394",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.FRA.DE.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/7"
+      },
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/7.104"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/2.104"
+      }
+    ],
+    "imsid": 737235,
+    "monitored": false,
+    "name": "FRA-PRA-RARE-BMS8",
+    "scid": "43eedbf4-a32c-44d4-bf30-6efbc6a48ecf",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00706",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/3/0"
+      }
+    ],
+    "imsid": 662849,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-079(GEANT)",
+    "scid": "43ffe391-ebc6-47c8-bcad-7188b38b05e9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01652",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx2.am.office.geant.net",
+        "interface": "ge-0/0/0"
+      }
+    ],
+    "imsid": 662514,
+    "monitored": true,
+    "name": "SRX-2 TO SWITCH CLUSTER",
+    "scid": "4422026b-b5c4-4dde-8ce5-45bbc170b8fa",
+    "service_type": "ETHERNET",
+    "sid": "GA-01246",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae12"
+      }
+    ],
+    "imsid": 658523,
+    "monitored": false,
+    "name": "LON2-PRD-ESX02-VM-TRAFFIC",
+    "scid": "442e145d-72c8-46a8-9235-10243125b0cd",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01700",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-23:505.505"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-21:505.505"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-667"
+      }
+    ],
+    "imsid": 745484,
+    "monitored": true,
+    "name": "GRIX-00667",
+    "scid": "444df2b0-46b2-4978-ad24-c4396ff3784b",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00667",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae4"
+      }
+    ],
+    "imsid": 742838,
+    "monitored": true,
+    "name": "POR-POR-MGMT-LAG",
+    "scid": "44620c82-68ae-4fc7-992c-7fd1368dba5b",
+    "service_type": "ETHERNET",
+    "sid": "GA-02585",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658697,
+    "monitored": false,
+    "name": "730XD-3-VM-TRAFFIC-LAG-PAR",
+    "scid": "44818516-04d0-4a9a-8a86-74e4bd1917fa",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01725",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708287,
+    "monitored": false,
+    "name": "FLOWMON-DDOS-FRA-DE-NETFLOW",
+    "scid": "448dfc45-8eb6-4c6b-bd4b-776de589b642",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00165",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "FRA01-GRV4",
+        "port": "1/1/5"
+      },
+      {
+        "equipment": "GEN01-GRV8",
+        "port": "1/2/5"
+      },
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "DE259799"
+      },
+      {
+        "equipment": "DIGITAL REALTY Z-END",
+        "port": "DE259799"
+      }
+    ],
+    "imsid": 739640,
+    "monitored": true,
+    "name": "FRA-GEN-NORDUNET-24055-1",
+    "scid": "44b6bd4c-e302-4be2-b4fd-21f3aad71dd3",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02531",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [],
+    "imsid": 738290,
+    "monitored": true,
+    "name": "PSNC-SUNET-SLICES-KTH",
+    "scid": "44c44e92-2780-464a-9f65-5741830dbd9b",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-024914",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ANKABUT"
+    ],
+    "endpoints": [],
+    "imsid": 708290,
+    "monitored": false,
+    "name": "UK-ANKABUT",
+    "scid": "44d937fc-998d-436f-a304-6768c5379046",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00906",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.3101"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-1/3/0.3101"
+      }
+    ],
+    "imsid": 726158,
+    "monitored": true,
+    "name": "LON-LON-SURF-AARNET-23009",
+    "scid": "44da7eb4-a406-4a2d-81c3-9aed23056a86",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02249",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663225,
+    "monitored": false,
+    "name": "PS-AMS-NL-IDRAC",
+    "scid": "44fd748e-9303-4ba2-8545-3a2203363489",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00285",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/5.2110"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.2110"
+      }
+    ],
+    "imsid": 709340,
+    "monitored": true,
+    "name": "LON-PAR-GEANTOPEN-INTERNET2-HBKU-190092",
+    "scid": "4511029e-8a2b-4dba-85fd-81c19a239745",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00985",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.112.42/30",
+          "2001:799:cb2:3::2/64"
+        ],
+        "hostname": "srx2.ch.office.geant.net",
+        "interface": "ge-0/0/1.10"
+      }
+    ],
+    "imsid": 662939,
+    "monitored": false,
+    "name": "SRX2-SRX1-CH-OFFICE",
+    "scid": "4524394e-b166-4b9a-b43e-534663d73aa3",
+    "service_type": "CORPORATE",
+    "sid": "GS-00448",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.gen.ch.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 739712,
+    "monitored": true,
+    "name": "GEN-GEN-800G-LAG",
+    "scid": "452535d6-c624-462c-a6df-632141afaba4",
+    "service_type": "ETHERNET",
+    "sid": "GA-02463",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662961,
+    "monitored": false,
+    "name": "AMS-SINET-EDGE-DEVICE-IDRAC",
+    "scid": "453f74db-71d7-4f83-8029-a30212e35186",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00097",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658832,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-011(ETH)",
+    "scid": "455259b6-b9de-4dd0-b0be-a22d7a459b70",
+    "service_type": "ETHERNET",
+    "sid": "GA-01513",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.17"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240587"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4081"
+      }
+    ],
+    "imsid": 744143,
+    "monitored": false,
+    "name": "BELNET-ARPGAN-01130",
+    "scid": "457783ac-46db-4652-8548-a4716b496540",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01130",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ORANGE"
+    ],
+    "endpoints": [],
+    "imsid": 733922,
+    "monitored": true,
+    "name": "NL-ORANGE-LAG-2",
+    "scid": "458cd561-74cc-462d-a726-52edacccd897",
+    "service_type": "ETHERNET",
+    "sid": "GA-02181",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-5"
+      }
+    ],
+    "imsid": 745265,
+    "monitored": true,
+    "name": "MIL2-THE-LAG",
+    "scid": "458dc566-c365-428c-aff3-be772e147f88",
+    "service_type": "ETHERNET",
+    "sid": "GA-02608",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMS01-GRV2",
+        "port": "1/1/5"
+      },
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "DE258133"
+      },
+      {
+        "equipment": "DIGITAL REALTY Z-END",
+        "port": "DE258133"
+      }
+    ],
+    "imsid": 739362,
+    "monitored": true,
+    "name": "AMS-FRA-NORDUNET-24054-1",
+    "scid": "45f5b94b-79a7-4364-9771-9097859a2374",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02529",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.148/31",
+          "2001:798:111:1::25/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae30.111"
+      }
+    ],
+    "imsid": 734117,
+    "monitored": true,
+    "name": "NL-ESNET-LHCONE",
+    "scid": "46284a44-4369-4f04-96f0-6e5f3c9d2c55",
+    "service_type": "L3-VPN",
+    "sid": "GS-00835",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-0/0/3"
+      }
+    ],
+    "imsid": 658498,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-016(ETH)",
+    "scid": "463da2e0-77fb-4696-b01f-99cf57aa75d3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01258",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708295,
+    "monitored": false,
+    "name": "VIENNA-VERIZON-1-15133-AT-1",
+    "scid": "464e5e07-22c2-424d-af56-8d6c3bc4a320",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00945",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661306,
+    "monitored": false,
+    "name": "ETHS-MX1.PAR.FR_GE-0/2/0.22",
+    "scid": "46ae5cf2-baf5-44d1-b997-cea28ed93346",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00267",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "et-1/0/5.0 - eumet"
+      }
+    ],
+    "imsid": 709834,
+    "monitored": true,
+    "name": "SWITCH EUMETCAST AP1",
+    "scid": "46bafea3-4e98-4188-9345-8c440ba5a08b",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01120",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-124050"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:3506"
+      },
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.975"
+      }
+    ],
+    "imsid": 745316,
+    "monitored": true,
+    "name": "GEANT_EPIPE_124050",
+    "scid": "46c8f60b-4d9e-4a13-902c-c8cd3ea1fe7a",
+    "service_type": "ETHERNET",
+    "sid": "GS-02514",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661169,
+    "monitored": false,
+    "name": "LON2-SEC-ESX-DEVICES-IDRAC",
+    "scid": "47113998-b5b8-41ea-9a76-8d2bec72b4eb",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00242",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 718110,
+    "monitored": true,
+    "name": "BRA-VIE-IP4",
+    "scid": "47385e1e-d7b0-4348-bbae-201bd54fc77b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01298",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658747,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-10GBE-001(ETH)",
+    "scid": "47543186-cfab-489b-9b2e-c52c638eee41",
+    "service_type": "ETHERNET",
+    "sid": "GA-01424",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 711783,
+    "monitored": true,
+    "name": "LAG-SW1.LIS.PT_AE2",
+    "scid": "4755c37d-f858-4cb4-9d34-d877df5e359a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01788",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732392,
+    "monitored": true,
+    "name": "LONDON-LONDON-1GBE-012(GEANT)",
+    "scid": "47567e20-bfd7-4142-ad45-c40eba87740c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01476",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.85/30"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae13.104"
+      }
+    ],
+    "imsid": 730143,
+    "monitored": true,
+    "name": "UK-ESNET-IPV4",
+    "scid": "475970dd-f379-4b8a-87b9-90d8a0d4669c",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00915",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ge-0/3/7"
+      }
+    ],
+    "imsid": 677319,
+    "monitored": true,
+    "name": "LISBON-LISBON-1GBE-004(ETH)",
+    "scid": "47852c3f-1835-4d20-b57a-075fbb3da811",
+    "service_type": "ETHERNET",
+    "sid": "GA-01656",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae13.40"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.40"
+      }
+    ],
+    "imsid": 714175,
+    "monitored": false,
+    "name": "AMS-PAR-SCION-SWITCH-NETHERLIGHT-20019",
+    "scid": "47a6fc09-7235-47e3-b49d-ea21cefde2ab",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00658",
+    "speed": 644245094400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "AZSCIENCENET"
+    ],
+    "endpoints": [],
+    "imsid": 663144,
+    "monitored": false,
+    "name": "AZSCIENCENET-TESTVLAN-E2E",
+    "scid": "47c73a84-d0d6-4030-bcd1-bee5ebcb3ce2",
+    "service_type": "GEANT IP",
+    "sid": "GS-00431",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732258,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-1GBE-002(GEANT)",
+    "scid": "47e14bca-8d11-4486-954b-e4ec26af5e00",
+    "service_type": "ETHERNET",
+    "sid": "GA-01547",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663069,
+    "monitored": false,
+    "name": "TEMPACCESS-AMS-NL-VLAN79",
+    "scid": "4849459e-772f-4455-883f-52e2c9dda260",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00375",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732405,
+    "monitored": true,
+    "name": "A10-DDOS-SCRUBBING-FRA-DIRTY-TRAFFIC-LAG",
+    "scid": "486705a2-adad-4f58-90d8-5f1ecf084314",
+    "service_type": "ETHERNET",
+    "sid": "GA-01955",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-1/0/47"
+      }
+    ],
+    "imsid": 658624,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-029(ETH)",
+    "scid": "48784ac1-c86c-481c-8383-de072d434ad6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01268",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.139/31"
+        ],
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/4.19"
+      }
+    ],
+    "imsid": 709123,
+    "monitored": false,
+    "name": "VIRGIN_MEDIA_EX1_LON2_TO_CAM_SRX_VLAN19-CH",
+    "scid": "48b43226-341c-43c9-982b-d07f511541bd",
+    "service_type": "CORPORATE",
+    "sid": "GS-00516",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-1/0/2"
+      }
+    ],
+    "imsid": 659047,
+    "monitored": true,
+    "name": "LONDON-LONDON-10GBE-022(ETH)",
+    "scid": "48e4f694-bb38-4431-83e5-dc5f2c2346a3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01478",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 727421,
+    "monitored": true,
+    "name": "V-LAN_1005_RT2.BRU.BE_XE-0/1/0_",
+    "scid": "48e9d205-0a37-4545-b2c8-5a3d5d10eea9",
+    "service_type": "ETHERNET",
+    "sid": "GS-00678",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.194/31",
+          "2001:798:cc:1::81/126"
+        ],
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae1.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.195/31",
+          "2001:798:cc:1::82/126"
+        ],
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "ae1.0"
+      }
+    ],
+    "imsid": 713273,
+    "monitored": true,
+    "name": "CHI-CHI-IPTRUNK",
+    "scid": "49072222-cfac-4efd-92aa-e73035815706",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00028",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.pra.cz.geant.net",
+        "interface": "xe-2/0/3.1003"
+      }
+    ],
+    "imsid": 661729,
+    "monitored": true,
+    "name": "JRA1-SDN-BOD-PILOT-BR53-PRA",
+    "scid": "49132879-562a-4341-a03a-54a960132472",
+    "service_type": "L3-VPN",
+    "sid": "GS-02123",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.931"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae11.931"
+      }
+    ],
+    "imsid": 719501,
+    "monitored": true,
+    "name": "FRA-MAD-DFN-REDIRIS-21028",
+    "scid": "49218421-3532-441f-9762-9d7c2d0772dc",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00692",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "COLT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae28"
+      }
+    ],
+    "imsid": 720365,
+    "monitored": true,
+    "name": "LAG-MX1.VIE.AT_AE28",
+    "scid": "4928ff63-df00-43ec-a90c-97fee746e9fc",
+    "service_type": "ETHERNET",
+    "sid": "GA-02114",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ge-0/3/0"
+      }
+    ],
+    "imsid": 732260,
+    "monitored": true,
+    "name": "VIENNA-VIENNA-1GBE-001(GEANT)",
+    "scid": "494a706e-d295-4626-8e3b-986d3104d773",
+    "service_type": "ETHERNET",
+    "sid": "GA-01483",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "AMRES"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.28/31",
+          "2001:798:1::1b5/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-21.333"
+      }
+    ],
+    "imsid": 747849,
+    "monitored": true,
+    "name": "AMRES-AP1-IAS",
+    "scid": "4952cd4b-c119-434a-a775-8eea4c7553e6",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00522",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.153/30",
+          "2001:798:99:1::35/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae14.100"
+      }
+    ],
+    "imsid": 733814,
+    "monitored": true,
+    "name": "CYNET-AP1",
+    "scid": "49582058-887b-46af-a913-9be8bc6674bc",
+    "service_type": "GEANT IP",
+    "sid": "GS-02441",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:3908"
+      }
+    ],
+    "imsid": 747631,
+    "monitored": true,
+    "name": "AMS-HAM-MSE-01159",
+    "scid": "4976dd5b-356a-4a21-b109-0552262620f8",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-01159",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "IUCC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.65/30",
+          "2001:798:28:20aa::5/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae21.100"
+      }
+    ],
+    "imsid": 730578,
+    "monitored": true,
+    "name": "IUCC-AP1",
+    "scid": "498dcc2a-482b-4c6d-b1f9-d3c0406c97ce",
+    "service_type": "GEANT IP",
+    "sid": "GS-00477",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661392,
+    "monitored": false,
+    "name": "PAR-GROOVE-2",
+    "scid": "49a272f3-aae1-4732-9d3b-f8279032187f",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00274",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/1/5"
+      },
+      {
+        "addresses": [
+          "62.40.120.25/29",
+          "2001:798:bb:1e::1/64"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/1/5.0"
+      }
+    ],
+    "imsid": 708302,
+    "monitored": false,
+    "name": "DTN-LON-100G-JBO-DATA",
+    "scid": "49b7f45f-5da3-48c9-8e23-101b41c1bb68",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00144",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PSMP-LHC-DRAC-LON-UK.GEANT.ORG",
+        "port": "10GE-1"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/7"
+      },
+      {
+        "addresses": [
+          "62.40.126.192/31",
+          "2001:798:111:1::6d/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/7.0"
+      }
+    ],
+    "imsid": 708314,
+    "monitored": false,
+    "name": "PS-LON-UK-PSMP-BWCTL-LHCONE",
+    "scid": "49c194fb-93af-45f0-bf79-1affb0b77923",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00320",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 745264,
+    "monitored": true,
+    "name": "SOF-THE-LAG",
+    "scid": "49d06c0b-caf2-48bd-952a-a1f192690888",
+    "service_type": "ETHERNET",
+    "sid": "GA-02426",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MAEEN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae27.101"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.101"
+      }
+    ],
+    "imsid": 736648,
+    "monitored": true,
+    "name": "LON-PAR-GEANTOPEN-MAEEN-INTERNET2-21086",
+    "scid": "49dff6cd-fac0-43c9-949c-1382db927bf5",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00728",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURFNET"
+    ],
+    "endpoints": [],
+    "imsid": 663143,
+    "monitored": false,
+    "name": "SURFNET-AP1-LHCONE",
+    "scid": "49ecbba0-20cc-4b9c-8cbb-77183dc602c6",
+    "service_type": "L3-VPN",
+    "sid": "GS-00860",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AARNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-1/3/0.3104"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3104"
+      }
+    ],
+    "imsid": 705943,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-AARNET-SINGAREN-CAE1-20044-VL3104",
+    "scid": "49faeeef-7c99-4043-82ac-c58fc12cb751",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00960",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MAEEN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.152/31",
+          "2001:798:99:1::f1/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae27.100"
+      }
+    ],
+    "imsid": 713957,
+    "monitored": true,
+    "name": "UK-MAEEN",
+    "scid": "49fdffe9-2dae-4aa1-96fd-47938a90e6e8",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00921",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [],
+    "imsid": 712391,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-KIFU-HU",
+    "scid": "4a26efe7-ee1b-4611-aaf7-d17b326eb2c2",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01025",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "xe-4/2/3"
+      }
+    ],
+    "imsid": 719664,
+    "monitored": true,
+    "name": "VIENNA-VIENNA-10GBE-023(GEANT)",
+    "scid": "4a4ae342-0a6d-4b26-a2ca-4d2caf9f5301",
+    "service_type": "ETHERNET",
+    "sid": "GA-02147",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 728001,
+    "monitored": true,
+    "name": "AMS-PSMP-PS OWAMP(GEANT)",
+    "scid": "4a7df1f8-cf92-447c-a472-bd28636780d8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01633",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708213,
+    "monitored": false,
+    "name": "PS-FRA-DE-PSMP3-BWCTL",
+    "scid": "4a92bd8b-2b89-473f-8d2b-fe4f5c4758bb",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00305",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708168,
+    "monitored": true,
+    "name": "PHYSICAL INFRASTURACTURE | TO SWITCH CLUSTER VME.0",
+    "scid": "4a98c3c4-cbb6-4ac6-b49e-6588c45bf0d1",
+    "service_type": "ETHERNET",
+    "sid": "GS-00170",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "LIS-LON-TRUNK",
+    "scid": "4a9e45b3-99e5-41d4-a858-c7ac381459b5",
+    "service_type": null,
+    "sid": "GA-01764",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 734736,
+    "monitored": false,
+    "name": "ATH2-MIL2-IPTRUNK",
+    "scid": "4aad7c02-30de-4213-90c7-75b9e7fa5fe8",
+    "service_type": "IP TRUNK",
+    "sid": "DS-000199",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.9"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4090"
+      }
+    ],
+    "imsid": 739678,
+    "monitored": true,
+    "name": "BELNET-FGOV-EXPRESSROUTE-VLAN4090",
+    "scid": "4b0a013b-0ace-45c8-8d22-a753cbb9b911",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01124",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 724614,
+    "monitored": true,
+    "name": "GEN-LON-800G-IPTRUNK",
+    "scid": "4b39e902-f15d-44d8-b5f6-e96e12b5e19a",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02227",
+    "speed": 858993459200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.2/31",
+          "2001:798:111:1::85/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.666"
+      }
+    ],
+    "imsid": 734592,
+    "monitored": true,
+    "name": "SURF-AP1-LHCONE-2",
+    "scid": "4b3f8013-ae4c-41a6-aafc-d4c8e2370559",
+    "service_type": "L3-VPN",
+    "sid": "GS-00793",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.2260"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae20.2260"
+      }
+    ],
+    "imsid": 706922,
+    "monitored": true,
+    "name": "AMS-LON-GEANTOPEN-SINET-SINGAREN-CAE1-19103-VL2260",
+    "scid": "4b49ec90-c550-44ba-8f81-93c90466a11d",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00957",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.104.22/31"
+        ],
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae1.28"
+      }
+    ],
+    "imsid": 729004,
+    "monitored": false,
+    "name": "PRA-EUMETSAT-SERVER-DATA-TRAFFIC",
+    "scid": "4b775653-bc38-4802-a916-730c46d58ba4",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02361",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.123.22/31"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae5.7"
+      }
+    ],
+    "imsid": 661176,
+    "monitored": false,
+    "name": "NTP5.GEANT.NET",
+    "scid": "4b95fe57-65f3-4704-9659-8aef879ed66e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00261",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-2/0/46"
+      }
+    ],
+    "imsid": 658395,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-010(ETH)",
+    "scid": "4ba02003-7cd8-43a8-8fd1-29b6466c518b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01264",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 702630,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-LAG-006(GEANT)",
+    "scid": "4ba6de72-996e-4e13-b4a4-12f31f6c6be7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01820",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662192,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-042(ETH)",
+    "scid": "4bb5aae5-68ea-4896-9cd1-8523922b70d4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01577",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae8"
+      }
+    ],
+    "imsid": 740789,
+    "monitored": true,
+    "name": "BRA-VIE-LAG",
+    "scid": "4bb947cf-76a7-46a7-bd25-badbf401c0be",
+    "service_type": "ETHERNET",
+    "sid": "GA-01755",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ams.nl.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 738597,
+    "monitored": true,
+    "name": "AMS-LON-1.6T-LAG",
+    "scid": "4bdb4f3a-5ee3-4107-a444-067735a35148",
+    "service_type": "ETHERNET",
+    "sid": "GA-02267",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "GTS link to Server 3",
+    "scid": "4c100266-7912-4065-8227-8e6c61e156b7",
+    "service_type": null,
+    "sid": "GA-01637",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707277,
+    "monitored": true,
+    "name": "VIE-ZAG-LAG",
+    "scid": "4c2781e7-04b0-48d2-b7ca-ef31743e0141",
+    "service_type": "ETHERNET",
+    "sid": "GA-01740",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.37"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4065"
+      }
+    ],
+    "imsid": 739672,
+    "monitored": true,
+    "name": "BELNET-MSER-NCCN-EXPRESSROUTE-VLAN4065",
+    "scid": "4c86107a-e6ec-4d6a-869a-19275e40aa68",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02371",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.134/31",
+          "2001:798:99:1::61/126"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.251"
+      }
+    ],
+    "imsid": 719144,
+    "monitored": true,
+    "name": "REDIRIS-AP1",
+    "scid": "4c8a1b3a-3970-4cad-9d23-99d83384d472",
+    "service_type": "GEANT IP",
+    "sid": "GS-00498",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ge-0/3/2.991"
+      }
+    ],
+    "imsid": 707244,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-VIE-AT",
+    "scid": "4cb4410e-a671-4d9e-91a1-958d8182c762",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00379",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-99287741"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:1175"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae23.25"
+      }
+    ],
+    "imsid": 745321,
+    "monitored": true,
+    "name": "GEANT_EPIPE_99287741",
+    "scid": "4ce9fda9-fe3c-4e59-b61e-7969f7612158",
+    "service_type": "ETHERNET",
+    "sid": "GS-00671",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.fra.de.geant.net",
+        "interface": "lag-5"
+      }
+    ],
+    "imsid": 739734,
+    "monitored": true,
+    "name": "FRA-GEN-1.6T-LAG",
+    "scid": "4cfe96b7-aaa1-4ead-b11d-d4b83b3513a7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01961",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/3"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/3.2701"
+      },
+      {
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "pwe-123050"
+      },
+      {
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "lag-20:2701"
+      }
+    ],
+    "imsid": 746441,
+    "monitored": false,
+    "name": "PAR-TAR-SCION-EENET",
+    "scid": "4d08e5f8-3781-4c41-a0cf-3690c854ee09",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02356",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 727506,
+    "monitored": false,
+    "name": "BRU-LON-FED4FIRE-BELNET-JISC-14023",
+    "scid": "4d2628bc-866d-4728-98bb-849c3a3449c3",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00672",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 727455,
+    "monitored": false,
+    "name": "BRU-LON-IX-BELNET-BELNET-18002",
+    "scid": "4d4c7d36-caaa-460e-bee8-2844791faab1",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00788",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.7"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4085"
+      }
+    ],
+    "imsid": 739663,
+    "monitored": true,
+    "name": "BELNET-IMEC-EXPRESSROUTE-VLAN4085",
+    "scid": "4d511273-6029-47b2-9156-9eb8c2549a1e",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02091",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae4"
+      }
+    ],
+    "imsid": 658530,
+    "monitored": true,
+    "name": "LAG-QFX.PAR.FR_AE4",
+    "scid": "4d5b1c47-f98a-4ce7-9c19-5ee3b7da3246",
+    "service_type": "ETHERNET",
+    "sid": "GA-01717",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662967,
+    "monitored": false,
+    "name": "TAAS-CONTROL-HAMBURG",
+    "scid": "4d8bb1d6-4515-4b1e-a751-65cb06a948ae",
+    "service_type": "GTS",
+    "sid": "GS-01187",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMT1.FRA.DE",
+        "port": "AE1.20"
+      },
+      {
+        "addresses": [
+          "83.97.90.40/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae7.20"
+      }
+    ],
+    "imsid": 747180,
+    "monitored": false,
+    "name": "FRA-FRA-AMT-RELAYLINK-IAS",
+    "scid": "4d909b52-3634-4a0f-89cc-f689b2b0002c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-02637",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.182/31",
+          "2001:798:99:1::109/126"
+        ],
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.320"
+      }
+    ],
+    "imsid": 718229,
+    "monitored": true,
+    "name": "REDIRIS-AP2",
+    "scid": "4dd59270-a093-4653-894f-8d40ba062f34",
+    "service_type": "GEANT IP",
+    "sid": "GS-00499",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30.991"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "irb.991"
+      }
+    ],
+    "imsid": 712146,
+    "monitored": false,
+    "name": "CORIANT-LIBRENMS-ACCESS-PAR-FR",
+    "scid": "4df1e811-e4a7-4847-912d-5b2fc2d95973",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00109",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BASNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-1/0/0"
+      }
+    ],
+    "imsid": 669075,
+    "monitored": true,
+    "name": "BASNET-AP-LL",
+    "scid": "4df37c5f-8204-48a9-ac3e-61e22d14802a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01370",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 734099,
+    "monitored": true,
+    "name": "ATH2-ATH2-IPTRUNK",
+    "scid": "4dfd1827-4094-4f4c-8f66-1d2493a73f7e",
+    "service_type": "IP TRUNK",
+    "sid": "DS-00099",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/1/6.1304"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.1304"
+      }
+    ],
+    "imsid": 734614,
+    "monitored": true,
+    "name": "AMS-FRA-SCION-KREONET-SWITCH",
+    "scid": "4dfdd8ea-c738-401a-bbf5-c0fbe4ec7a04",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02292",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.232/31",
+          "2001:798:cc:1::a1/126"
+        ],
+        "hostname": "rt0.gen.ch.geant.net",
+        "interface": "lag-2.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.233/31",
+          "2001:798:cc:1::a2/126"
+        ],
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-2.0"
+      }
+    ],
+    "imsid": 740949,
+    "monitored": true,
+    "name": "GEN-MIL2-IPTRUNK",
+    "scid": "4e06a01f-5846-4c43-ada1-2ccab8e26253",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00039",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.33/31",
+          "2001:798:cc::4a/126"
+        ],
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-4.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.32/31",
+          "2001:798:cc::49/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-4.0"
+      }
+    ],
+    "imsid": 745269,
+    "monitored": true,
+    "name": "SOF-THE-IPTRUNK",
+    "scid": "4e28d59f-ab63-47d8-a854-77e8f4cfffcf",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02424",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "COGENT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae29"
+      }
+    ],
+    "imsid": 659389,
+    "monitored": true,
+    "name": "LAG-MX1.VIE.AT_AE29",
+    "scid": "4e2e08f4-616f-48ab-9e7f-b94f5dc579fc",
+    "service_type": "ETHERNET",
+    "sid": "GA-01849",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662935,
+    "monitored": false,
+    "name": "PSMP-BUC-RO-DRAC",
+    "scid": "4e37b6ac-f019-4b4a-b20e-974cd70b64a5",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00363",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "173.194.120.187/31",
+          "2001:4860:1:1::24f3/127"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae11.0"
+      }
+    ],
+    "imsid": 734909,
+    "monitored": true,
+    "name": "NL-GOOGLE-2-15169",
+    "scid": "4e3e39df-9882-4b0c-abf1-27a14e6c9c76",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00938",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658754,
+    "monitored": true,
+    "name": "BRATISLAVA-BRATISLAVA-1GBE-003(ETH)",
+    "scid": "4e54514a-1813-4a57-99ff-974f2abaa36d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01304",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "addresses": [
+          "10.254.254.2/29"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "irb.3004"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae30.3004"
+      }
+    ],
+    "imsid": 733012,
+    "monitored": false,
+    "name": "TAAS-CONTROL-FRANKFURT-VRF-VLAN3004",
+    "scid": "4e5cd641-e4f6-4df7-be17-a8c43eb06876",
+    "service_type": "L3-VPN",
+    "sid": "GS-00862",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "WACREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.233/30",
+          "2001:798:99:1::b1/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae22.100"
+      }
+    ],
+    "imsid": 661300,
+    "monitored": true,
+    "name": "UK-WACREN",
+    "scid": "4e849a9b-4a32-4c0c-b98b-b62354329bad",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00910",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661645,
+    "monitored": false,
+    "name": "OWAMP-MIL2-IT",
+    "scid": "4e93e676-f373-4d4f-a036-bb087af7da40",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00266",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ORANGE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.90.10/31",
+          "2001:798:1::229/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae31.0"
+      }
+    ],
+    "imsid": 718722,
+    "monitored": true,
+    "name": "FR-ORANGE-2280-2",
+    "scid": "4eadbe20-6069-4885-a3ee-14e630f00e46",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-01179",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NEA3R"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.500"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.500"
+      }
+    ],
+    "imsid": 718304,
+    "monitored": true,
+    "name": "LON-LON-NEA3R-SURF-22015",
+    "scid": "4eb79c4e-640a-4266-a90f-3e52d72bf8d5",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00707",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.34/31",
+          "2001:798::3d/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae11.667"
+      }
+    ],
+    "imsid": 661280,
+    "monitored": false,
+    "name": "SURFNET-AP2-CLS",
+    "scid": "4ed0e03f-9d07-42ee-b979-8adddc3713e9",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00623",
+    "speed": 53687091200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.49/30",
+          "2001:798:1::35/126"
+        ],
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-21.333"
+      }
+    ],
+    "imsid": 745495,
+    "monitored": true,
+    "name": "CYNET-AP2-IAS",
+    "scid": "4ee20c3c-69b9-488a-8459-ec69800600eb",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00525",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662911,
+    "monitored": false,
+    "name": "GEN-GROOVE-2-MANAGEMENT",
+    "scid": "4eed7482-07ab-4ec7-aaea-5fb7c13132b1",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00184",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 728949,
+    "monitored": true,
+    "name": "TAR-TAR-LAG",
+    "scid": "4ef190f0-ebc2-46c6-8a43-418fde2ed294",
+    "service_type": "ETHERNET",
+    "sid": "GA-02353",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.6.1/24"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae3.103"
+      }
+    ],
+    "imsid": 702127,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-MAD-ES",
+    "scid": "4f096f84-b7f1-49be-bf85-cc5b4f6f03a2",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00121",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662241,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-019(ETH)",
+    "scid": "4f865222-f76e-4b5a-908c-c89ab0b0450c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01606",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [],
+    "imsid": 719502,
+    "monitored": true,
+    "name": "FRA-MAD-ORACLE-REDIRIS-22009-VL414",
+    "scid": "4f8872aa-5de1-4686-94ce-9fc5ba4121f2",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02095",
+    "speed": 225485783040,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.38/31",
+          "2001:798:cc::61/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae5.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.39/31",
+          "2001:798:cc::62/126"
+        ],
+        "hostname": "rt0.ams.nl.geant.net",
+        "interface": "lag-5.0"
+      }
+    ],
+    "imsid": 735616,
+    "monitored": true,
+    "name": "AMS-AMS-IPTRUNK",
+    "scid": "4f9a5909-fbfa-465c-b264-f8101f82774d",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02458",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708221,
+    "monitored": false,
+    "name": "PS-PAR-FR-OWAMP",
+    "scid": "4fa11497-1bff-491d-9f27-c7256dc101e5",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00342",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663063,
+    "monitored": false,
+    "name": "AMS-GROOVE-2",
+    "scid": "4fba9d4f-58bf-4578-86a5-4b5a0f8ef6c7",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00093",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae21.120"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.120"
+      }
+    ],
+    "imsid": 713981,
+    "monitored": true,
+    "name": "GEN-PAR-CERN-REDCLARA-21072",
+    "scid": "4fbc30c8-9bfe-48c8-8896-8b4969b70625",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00716",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-0/0/2"
+      }
+    ],
+    "imsid": 658590,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-023(ETH)",
+    "scid": "4ff377c1-bf3c-4cc0-9d46-0f2ae9bb495f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01259",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ge-0/2/2"
+      }
+    ],
+    "imsid": 727547,
+    "monitored": true,
+    "name": "POZNAN 1-POZNAN 1-1GBE-003(GEANT)",
+    "scid": "5007a914-9a24-422b-82f9-be34fd91738c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01376",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708989,
+    "monitored": false,
+    "name": "EUMETSAT-GRE-CMA",
+    "scid": "500d1dac-0903-4092-8dac-d744afa98945",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01073",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ams-poz_EXPReS_NetherLight-PIONIER_07001",
+    "scid": "5031cdcf-2895-4508-b707-a5fc4512aa56",
+    "service_type": null,
+    "sid": "DS-28664",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660558,
+    "monitored": false,
+    "name": "JRA1-SDX-L2-PILOT-VLAN1002",
+    "scid": "5038a9e2-47c6-4dea-8457-dfbcb82265d0",
+    "service_type": "L3-VPN",
+    "sid": "GS-00799",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "TEIN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "202.179.249.34/30",
+          "2001:254:8001:9::2/64"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3202"
+      }
+    ],
+    "imsid": 661949,
+    "monitored": true,
+    "name": "UK-TEIN",
+    "scid": "503f0386-24c9-465d-91b2-dd1ca7172654",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00924",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.pra.cz.geant.net",
+        "interface": "lag-6"
+      }
+    ],
+    "imsid": 740464,
+    "monitored": true,
+    "name": "FRA-PRA-LAG",
+    "scid": "5044ca4d-2dec-4fd5-9b9f-cc444b18ee6d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01827",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663233,
+    "monitored": false,
+    "name": "OPERATIONS-AMS-NL-VLAN550",
+    "scid": "50533c53-b11b-4b57-8c81-dd6b552db7a5",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00263",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30.3000"
+      }
+    ],
+    "imsid": 712149,
+    "monitored": true,
+    "name": "VM-DATANETWORK-PAR",
+    "scid": "507645af-9c34-4ff2-8e2e-2b971bb50387",
+    "service_type": "POP LAN LINK",
+    "sid": "GS-00085",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "TENET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.420"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae28.420"
+      }
+    ],
+    "imsid": 718087,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-NEA3R-TENET-18097",
+    "scid": "5091f195-6143-4b73-8651-6814fb42f77d",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00971",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ham_par-SCION-GTS_20055",
+    "scid": "50b1ed0a-649f-41ad-96fb-e6e5df9e2f5e",
+    "service_type": null,
+    "sid": "DS-51662",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SINGAREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.90.25/30",
+          "2001:798:1::251/126"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/5.333"
+      }
+    ],
+    "imsid": 729063,
+    "monitored": true,
+    "name": "SINGAREN-IAS",
+    "scid": "50bf3f31-b635-4399-9b10-617b60f4995b",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-02359",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [],
+    "imsid": 719548,
+    "monitored": false,
+    "name": "BRU-MAD-FED4FIRE-BELNET-REDIRIS-14010",
+    "scid": "50c86dde-3200-4767-8dd4-2479f265f3ed",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00674",
+    "speed": 332859965440,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-0/0/0"
+      }
+    ],
+    "imsid": 658559,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-020(ETH)",
+    "scid": "513410e5-0608-4d13-a8ac-c7dff1c36227",
+    "service_type": "ETHERNET",
+    "sid": "GA-01260",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.DUB.IE.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 677584,
+    "monitored": false,
+    "name": "DUB OOB LINK",
+    "scid": "51a3bab9-9947-4470-be17-587a980fe1c0",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00397",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 713233,
+    "monitored": true,
+    "name": "BUC-CHI-IPTRUNK-40G",
+    "scid": "51c2ef33-a40b-40c2-bbd3-49c59e56cc83",
+    "service_type": "IP TRUNK",
+    "sid": "GS-90022",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662323,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-10GBE-064(GEANT)",
+    "scid": "51ce3e9a-e135-47d3-93db-21ffc871cce2",
+    "service_type": "ETHERNET",
+    "sid": "GA-01601",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "HBKU"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/5"
+      }
+    ],
+    "imsid": 669635,
+    "monitored": true,
+    "name": "HBKU COLT",
+    "scid": "51de3c06-8d66-452e-a07c-d224108099bb",
+    "service_type": "ETHERNET",
+    "sid": "GA-01398",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "185.6.36.108/23",
+          "2001:7f8:18::108/64"
+        ],
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-21.0"
+      }
+    ],
+    "imsid": 747291,
+    "monitored": false,
+    "name": "IX-PEERINGS-IN-INEX",
+    "scid": "51e0759a-e87b-48de-8287-5102cc44715c",
+    "service_type": "IP PEERING - NON R&E (PUBLIC)",
+    "sid": "GS-00950",
+    "speed": 0,
+    "status": "planned"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.205/30"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.111"
+      }
+    ],
+    "imsid": 660442,
+    "monitored": false,
+    "name": "RENATER-AP1-IPV4-LHCONE",
+    "scid": "520484d0-2bdb-4c3b-a340-cc4dbd0f2e24",
+    "service_type": "L3-VPN",
+    "sid": "GS-00853",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "WP6T3"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/7"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/0/5"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/7.10"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/0/5.10"
+      }
+    ],
+    "imsid": 715032,
+    "monitored": false,
+    "name": "LON2-LON2-WP7T2SF-BMS7-JRA2T4-21089",
+    "scid": "520b4d86-effe-4f0a-b203-37e8480b2da2",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00739",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RARE"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-11/0/0.102"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.102"
+      }
+    ],
+    "imsid": 736095,
+    "monitored": false,
+    "name": "AMS-PAR-RARE-RARE-21101",
+    "scid": "5281120d-30be-46aa-8e16-facecba8d7d0",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00656",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661519,
+    "monitored": false,
+    "name": "ETHS-MX1.POZ.PL_GE-0/2/0.24",
+    "scid": "529bd1e9-6c63-4a3b-bf29-55d5f7d0e19e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00345",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "GEN01-GRV4",
+        "port": "1/1/5"
+      },
+      {
+        "equipment": "AMS01-GRV2",
+        "port": "1/2/3"
+      }
+    ],
+    "imsid": 739638,
+    "monitored": true,
+    "name": "AMS-GEN1-SURF-24056-1",
+    "scid": "52a9b40e-0864-476a-b0e4-8535dca9e441",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02533",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.90.20/31",
+          "2001:798:1::241/126"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.252"
+      }
+    ],
+    "imsid": 719126,
+    "monitored": true,
+    "name": "REDIRIS-AP1-IAS",
+    "scid": "52cbff63-5e9e-449c-a1ed-c949a411e48d",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00581",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/3.1305"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.1305"
+      }
+    ],
+    "imsid": 727330,
+    "monitored": false,
+    "name": "LON-PAR-SCION-KREONET-SWITCH",
+    "scid": "52d3dbd0-d095-49a3-b422-f3644a8c4edb",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02293",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "72.14.209.139/31",
+          "2001:4860:1:1::30d7/127"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae12.0"
+      }
+    ],
+    "imsid": 708198,
+    "monitored": true,
+    "name": "GOOGLE-15169-IT",
+    "scid": "52e664c9-4551-4854-9da3-3c0f1309b148",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00935",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/2"
+      }
+    ],
+    "imsid": 658497,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-025(ETH)",
+    "scid": "52e9f1a8-1a5c-46eb-a60b-48812e9be2e0",
+    "service_type": "ETHERNET",
+    "sid": "GA-01226",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/19"
+      }
+    ],
+    "imsid": 658555,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-029(ETH)",
+    "scid": "52eacb7a-60b9-4203-97bf-677e4cc06f0d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01221",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "T-SYSTEMS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "80.158.74.251/31"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae27.4002"
+      }
+    ],
+    "imsid": 734872,
+    "monitored": true,
+    "name": "NL-T-SYSTEMS-R&E",
+    "scid": "52f9003c-1b2c-4db7-99f4-124cde623974",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02329",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659039,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-10GBE-014(ETH)",
+    "scid": "530d9310-a744-4d1e-b8ee-d33e81c1a267",
+    "service_type": "ETHERNET",
+    "sid": "GA-01418",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.gen.ch.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 739735,
+    "monitored": true,
+    "name": "GEN-MAR-LAG",
+    "scid": "5318fb3e-a100-47d2-9bcc-62cd76321c12",
+    "service_type": "ETHERNET",
+    "sid": "GA-01878",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FACEBOOK"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "et-2/0/1"
+      }
+    ],
+    "imsid": 731651,
+    "monitored": true,
+    "name": "FACEBOOK-FRA-100G-LL1",
+    "scid": "531c2a7c-d566-41ae-b14e-078b0d1c1af6",
+    "service_type": "ETHERNET",
+    "sid": "GA-20365",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707223,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-GEN-CH",
+    "scid": "53230070-f34d-45e1-9df1-ce1f11ad01b0",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00180",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GRENA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.64/31",
+          "2001:798:1::18d/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae20.333"
+      }
+    ],
+    "imsid": 747643,
+    "monitored": false,
+    "name": "GRENA-AP1-IAS",
+    "scid": "534d1155-56fa-41a4-b767-e68448cb4970",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-02653",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae14"
+      }
+    ],
+    "imsid": 658686,
+    "monitored": false,
+    "name": "LON2-SEC-ESX20-VM-TRAFFIC",
+    "scid": "53699a26-68e3-4d8f-9c7a-d7349b0e8ee0",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01702",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732505,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-006(GEANT)",
+    "scid": "5376e6c9-50d5-438c-951e-f61473ca4f40",
+    "service_type": "ETHERNET",
+    "sid": "GA-01624",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.41/30",
+          "2001:798:1::2d/126"
+        ],
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae11.333"
+      }
+    ],
+    "imsid": 661262,
+    "monitored": true,
+    "name": "CESNET-AP1-IAS",
+    "scid": "5396cbf4-49c3-4f23-aaec-d2f808b22073",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00563",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.217/30",
+          "2001:798:111:1::11/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae10.111"
+      }
+    ],
+    "imsid": 663086,
+    "monitored": true,
+    "name": "CERN-GEN-LHCONE",
+    "scid": "539a5eb6-04b1-4e04-b3e2-399d0c33f858",
+    "service_type": "L3-VPN",
+    "sid": "GS-00811",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae18"
+      }
+    ],
+    "imsid": 662508,
+    "monitored": true,
+    "name": "BIX-HU-LAG",
+    "scid": "539fe189-90a4-437f-b047-c76e05d2b736",
+    "service_type": "ETHERNET",
+    "sid": "GA-01900",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 712392,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-FUNET-2-FI",
+    "scid": "53a1394d-b82c-4a40-b674-585a27c70c94",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01041",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [],
+    "imsid": 712402,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-CARNET-HR",
+    "scid": "53aa0545-9890-495d-8db1-e06a908ad5b1",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01035",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-8"
+      }
+    ],
+    "imsid": 739434,
+    "monitored": true,
+    "name": "LON2-PAR-1.6T-LAG",
+    "scid": "53fb0ca0-c2ca-40e4-a429-215cc613ee75",
+    "service_type": "ETHERNET",
+    "sid": "GA-01762",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658794,
+    "monitored": true,
+    "name": "FR-ORANGE-LL #1",
+    "scid": "545cc131-62bf-4f96-8ba3-45cd3b53bc52",
+    "service_type": "ETHERNET",
+    "sid": "GA-01386",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.3532"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.3532"
+      }
+    ],
+    "imsid": 745529,
+    "monitored": false,
+    "name": "RARE-02644",
+    "scid": "5481f2bb-0ac6-46e7-8c6a-38ce8730ab3a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02644",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.35"
+      },
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:3918"
+      }
+    ],
+    "imsid": 747549,
+    "monitored": true,
+    "name": "AMS-HAM-MSE-02328",
+    "scid": "5496fbf5-74d0-497c-af42-3b79d94646e1",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02328",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662239,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-018(ETH)",
+    "scid": "54cacdf7-0fff-40f6-afd4-6773450bdfd6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01620",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae31"
+      }
+    ],
+    "imsid": 718721,
+    "monitored": true,
+    "name": "FR-ORANGE-LAG-4",
+    "scid": "54d55066-809b-44a9-901d-0b4a96a9b5ab",
+    "service_type": "ETHERNET",
+    "sid": "GA-02145",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMT1.AMS.NL",
+        "port": "AE1"
+      }
+    ],
+    "imsid": 744346,
+    "monitored": true,
+    "name": "AMS-AMT-LAG",
+    "scid": "54d6fea1-1060-4215-bbd3-20febb41317d",
+    "service_type": "ETHERNET",
+    "sid": "GA-02299",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KAUST"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.3610"
+      }
+    ],
+    "imsid": 734575,
+    "monitored": true,
+    "name": "NL-KAUST",
+    "scid": "54e08b7d-2f8b-4d2d-8427-b535a98c7b92",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00895",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662401,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10GBE-032(GEANT)",
+    "scid": "54eed323-fbbb-4b12-95e5-68dfd228ec8c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01574",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NETHERLIGHT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.2779"
+      }
+    ],
+    "imsid": 707103,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-NETHERLIGHT-WIX",
+    "scid": "55093fa1-130d-4b34-831b-40bc17204434",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00973",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "xe-5/2/2"
+      }
+    ],
+    "imsid": 739293,
+    "monitored": true,
+    "name": "BUDAPEST-BUDAPEST-10GBE-004(GEANT)",
+    "scid": "5513e63a-8be0-4e31-9e4f-f166d8ba8537",
+    "service_type": "ETHERNET",
+    "sid": "GA-01567",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "Nordunet_OULU_ExpressRoute_Vlan3904",
+    "scid": "5540e589-fdde-4ecf-b345-78793c2681cd",
+    "service_type": null,
+    "sid": "DS-52713",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "LITNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.105/30",
+          "2001:798:1f:10aa::5/126"
+        ],
+        "hostname": "rt0.kau.lt.geant.net",
+        "interface": "lag-21.100"
+      }
+    ],
+    "imsid": 746528,
+    "monitored": true,
+    "name": "LITNET-AP1",
+    "scid": "554ef71b-a308-4289-9af0-6d54623c6333",
+    "service_type": "GEANT IP",
+    "sid": "GS-00486",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae12.4087"
+      },
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.23"
+      }
+    ],
+    "imsid": 707644,
+    "monitored": true,
+    "name": "GARR-UDMILANO-EXPRESSROUTE-VLAN4087",
+    "scid": "557054e0-25c8-4caf-9530-696d09fece29",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01146",
+    "speed": 332859965440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURFNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-10/3/0"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-9/1/5"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19"
+      }
+    ],
+    "imsid": 732097,
+    "monitored": true,
+    "name": "SURF-AP2-LL2",
+    "scid": "5579c1d1-c3eb-477a-a678-19fccb513243",
+    "service_type": "ETHERNET",
+    "sid": "GA-01477",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661170,
+    "monitored": false,
+    "name": "LON2-GROOVE-2-MANAGEMENT",
+    "scid": "557d8ee7-6305-4782-b621-2d627e591fdc",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00241",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [],
+    "imsid": 705424,
+    "monitored": false,
+    "name": "GEN-PAR-SYNGENTA-SWITCH-INTERNET2-17045",
+    "scid": "557e4343-5450-47c8-b9b1-87636e915738",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00715",
+    "speed": 536870912000,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.188/31",
+          "2001:798:cc:1::e5/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae5.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.189/31",
+          "2001:798:cc:1::e6/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-3.0"
+      }
+    ],
+    "imsid": 747898,
+    "monitored": true,
+    "name": "BUD-ZAG-IPTRUNK",
+    "scid": "5595358e-dce2-421d-ab8a-f8d6971a278e",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00027",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 726336,
+    "monitored": true,
+    "name": "BUD-UTIC-LAG",
+    "scid": "55a0af3e-1a6f-48a6-b279-59e84a2f2cfe",
+    "service_type": "ETHERNET",
+    "sid": "GA-02231",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.poz.pl.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 740146,
+    "monitored": true,
+    "name": "HAM-POZ-LAG",
+    "scid": "55aa8fb7-4351-4f70-a2bd-940b1623b4d5",
+    "service_type": "ETHERNET",
+    "sid": "GA-02341",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW2.PRA.CZ",
+        "port": "AE2"
+      }
+    ],
+    "imsid": 725149,
+    "monitored": true,
+    "name": "PRAGUE 2-PRAGUE 2-LAG-001(GEANT)",
+    "scid": "55ba74b7-3257-490b-ad7c-65fdfc827376",
+    "service_type": "ETHERNET",
+    "sid": "GA-02064",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [],
+    "imsid": 709754,
+    "monitored": true,
+    "name": "GRNET EUMETCAST AP1",
+    "scid": "55bc45e1-6f48-4f4b-aef2-5b712e9be889",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01107",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/3"
+      }
+    ],
+    "imsid": 678558,
+    "monitored": true,
+    "name": "LONDON-LONDON-10GBE-005(GEANT)",
+    "scid": "55c59749-330b-481d-aa7f-b53563370e76",
+    "service_type": "ETHERNET",
+    "sid": "GA-01657",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661926,
+    "monitored": false,
+    "name": "OWAMP-POZ-PL",
+    "scid": "5605c2f7-2106-4195-8620-c52aaf4449c2",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00268",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.LIS.PT.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 677667,
+    "monitored": false,
+    "name": "LIS OOB LINK",
+    "scid": "56778e0f-9738-489d-aaea-830ecea74433",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00403",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae17"
+      }
+    ],
+    "imsid": 662503,
+    "monitored": true,
+    "name": "CERN-AP1-LAG",
+    "scid": "567aaef5-21ee-4aa4-a5c3-6d3d9ebc54a1",
+    "service_type": "ETHERNET",
+    "sid": "GA-01882",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 662468,
+    "monitored": true,
+    "name": "CERN-LHCONE-LAG#2",
+    "scid": "5694963d-3223-4280-b235-04d3d6157fee",
+    "service_type": "ETHERNET",
+    "sid": "GA-01885",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "AMRES"
+    ],
+    "endpoints": [],
+    "imsid": 712352,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-AMRES-RS",
+    "scid": "56e16d98-13bb-4667-85a1-1c3a457ef36a",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01011",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae6"
+      }
+    ],
+    "imsid": 719610,
+    "monitored": true,
+    "name": "BIL-MAD-LAG",
+    "scid": "57098cef-f809-4f64-8ac1-e65c2e4275d3",
+    "service_type": "ETHERNET",
+    "sid": "GA-02144",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae4"
+      }
+    ],
+    "imsid": 739463,
+    "monitored": true,
+    "name": "BIL-PAR-LAG",
+    "scid": "572a5a34-00d5-473f-8b8b-8ebb9204b63e",
+    "service_type": "ETHERNET",
+    "sid": "GA-02087",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.906"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/3"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/3.906"
+      }
+    ],
+    "imsid": 661593,
+    "monitored": false,
+    "name": "LON-LON-MISC-GEANT-INTERNET2-9940197",
+    "scid": "572fb3c8-7022-42c3-8382-7fd9b0eb3a2d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00726",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661576,
+    "monitored": false,
+    "name": "DANTE-TECHNICAL-CUSTOMER-SUPPORT",
+    "scid": "57891c76-8dc8-427e-9e3e-c452268ee3ea",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00111",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae24"
+      }
+    ],
+    "imsid": 731896,
+    "monitored": true,
+    "name": "DE-EXOSCALE-IAS-LAG",
+    "scid": "578d3bd6-6fc9-4ef7-a7f4-9b83e6af06d0",
+    "service_type": "ETHERNET",
+    "sid": "GA-01948",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [],
+    "imsid": 718086,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-INTERNET2-TENET-19004",
+    "scid": "579292fb-f890-4b98-b51d-0288e1804645",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00943",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "FCCN_IPP_ExpressRoute_Vlan1942",
+    "scid": "57d08b05-de28-49c2-ae28-714f39717ef7",
+    "service_type": null,
+    "sid": "DS-51564",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 746144,
+    "monitored": true,
+    "name": "MAR-MIL2-LAG",
+    "scid": "57dd753d-b3c2-4d80-8b18-7ca96e791ea5",
+    "service_type": "ETHERNET",
+    "sid": "GA-02164",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PRO-M/NIIF"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 662452,
+    "monitored": true,
+    "name": "KIFU-AP1-LAG",
+    "scid": "57e18d43-682b-4b63-b1b8-6fcf0ad7375e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01905",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-11/2/0"
+      }
+    ],
+    "imsid": 659244,
+    "monitored": true,
+    "name": "PARIS-DTN-10G-1",
+    "scid": "57e4c151-bcdb-4210-b81e-1f6af1f16346",
+    "service_type": "ETHERNET",
+    "sid": "GA-01377",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 735202,
+    "monitored": true,
+    "name": "THESSALONIKI-THESSALONIKI-LAG-004(GEANT)",
+    "scid": "580129d9-fe5f-4d38-a8cc-a2d6caf115db",
+    "service_type": "ETHERNET",
+    "sid": "DA-01794",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663033,
+    "monitored": false,
+    "name": "PS-AMS-NL-IDRAC2",
+    "scid": "581e6eab-dfa1-4708-99a6-ddf28ed571aa",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00286",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-1/0/46"
+      }
+    ],
+    "imsid": 658393,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-009(ETH)",
+    "scid": "582c0e78-f59d-49fe-8a86-a0674b41670f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01271",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 738104,
+    "monitored": true,
+    "name": "ZAGREB 1-ZAGREB 1-10GBE-006(GEANT)",
+    "scid": "58399ae4-e83f-44c9-8fa2-6ebc9ab27620",
+    "service_type": "ETHERNET",
+    "sid": "GA-02099",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/2.12"
+      }
+    ],
+    "imsid": 661358,
+    "monitored": false,
+    "name": "CORSA-MANAGEMENT-LON2-UK",
+    "scid": "585f1c2d-1ae1-47e0-b8de-b1d3c2a2e137",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00110",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 747866,
+    "monitored": true,
+    "name": "SOF-ZAG-LAG",
+    "scid": "58b2496b-451c-4c75-b574-06bd08b4b328",
+    "service_type": "ETHERNET",
+    "sid": "GA-02368",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/4"
+      }
+    ],
+    "imsid": 669239,
+    "monitored": true,
+    "name": "UK-PS-LHCONE-MGMT",
+    "scid": "58d81517-ef85-4ab2-90bd-b954de0d97be",
+    "service_type": "ETHERNET",
+    "sid": "GA-01462",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 747277,
+    "monitored": true,
+    "name": "DUB-LON-LAG",
+    "scid": "58d9da77-a2be-4a06-934a-41eabbc43e70",
+    "service_type": "ETHERNET",
+    "sid": "GA-02008",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.198/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.14"
+      }
+    ],
+    "imsid": 732677,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-JPL",
+    "scid": "58f59360-f10e-4eda-99e7-d0b494af1edd",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01081",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIAE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae16"
+      }
+    ],
+    "imsid": 734243,
+    "monitored": true,
+    "name": "NL-KIAE-LAG",
+    "scid": "59014dbf-426d-42d9-a0ac-7ab6ea953a4e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01918",
+    "speed": 32212254720,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663191,
+    "monitored": false,
+    "name": "MDVPN-SECURITYTOOL-DUB-IE-VLAN210",
+    "scid": "59206bdf-206e-4796-9ac9-135f7576487a",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00246",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661562,
+    "monitored": false,
+    "name": "DASHBOARD-SERVER-LON2-VLAN50_",
+    "scid": "594d9fdb-4d30-4811-b918-5137227ff361",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00112",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.20"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240583"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4090"
+      }
+    ],
+    "imsid": 744265,
+    "monitored": true,
+    "name": "MSEARTEV-01131",
+    "scid": "5953760f-6295-48a3-bcd7-56f80409092f",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01131",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708715,
+    "monitored": true,
+    "name": "RIG-RIG-IPTRUNK",
+    "scid": "598594e6-9a37-4a4a-9c46-9c3b40d3b2aa",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00060",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/25"
+      }
+    ],
+    "imsid": 658455,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-010(ETH)",
+    "scid": "599f00dd-75e0-4cc4-83b2-1bb00d3dbb7d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01217",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/0/0.472"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.472"
+      }
+    ],
+    "imsid": 736071,
+    "monitored": false,
+    "name": "AMS-GEN-CERN-RARE-123010",
+    "scid": "59a82de1-15d8-4387-b3f6-db0bfb3d9828",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02262",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae30"
+      }
+    ],
+    "imsid": 721403,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-LAG-002(GEANT)",
+    "scid": "59a93e23-ce24-406a-b7f0-0ea2a7562855",
+    "service_type": "ETHERNET",
+    "sid": "GA-01709",
+    "speed": 0,
+    "status": "terminated"
+  },
+  {
+    "customers": [
+      "AMS-IX"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae12"
+      }
+    ],
+    "imsid": 734926,
+    "monitored": true,
+    "name": "NL-AMS-IX-LAG",
+    "scid": "59b7c90f-2d1e-4776-97f9-6de08e1dbcb2",
+    "service_type": "ETHERNET",
+    "sid": "GA-01920",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.1390"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae23.1390"
+      }
+    ],
+    "imsid": 714179,
+    "monitored": false,
+    "name": "GEN-PAR-SCION-RENATER-SWITCH-20026",
+    "scid": "59c46342-d5fb-4bc3-a884-924d9223c782",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00717",
+    "speed": 751619276800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 745430,
+    "monitored": false,
+    "name": "ATH2-ATH2-IPTRUNK",
+    "scid": "59f5c567-09a2-4854-8f7a-eb2aa5756262",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00013",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-23"
+      }
+    ],
+    "imsid": 745468,
+    "monitored": true,
+    "name": "GRIX-LAG",
+    "scid": "5a04dbf3-80f0-4e14-b805-c887c47927a1",
+    "service_type": "ETHERNET",
+    "sid": "GA-01640",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae9"
+      }
+    ],
+    "imsid": 658532,
+    "monitored": false,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-064(GEANT)",
+    "scid": "5a0f322f-7364-4428-9c28-dbfae037ee51",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01681",
+    "speed": 32212254720,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "addresses": [
+          "62.40.108.129/27",
+          "2001:798:ee:18::1/64"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae30.2001"
+      }
+    ],
+    "imsid": 733918,
+    "monitored": false,
+    "name": "ESXI-MANAGEMENT-FRA",
+    "scid": "5a17e036-61de-441e-b241-9d1ec074cf86",
+    "service_type": "POP LAN LINK",
+    "sid": "GS-00073",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "BUD-SOF TRUNK",
+    "scid": "5a2ad8ee-9b9a-4639-b149-f5ed13730427",
+    "service_type": null,
+    "sid": "DS-12661",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [],
+    "imsid": 708701,
+    "monitored": false,
+    "name": "CYNET-GN-PRACE-VPN-PROXY-FRANKFURT-L3VPN",
+    "scid": "5a32a28e-f6e1-4805-b33c-729a9aba0007",
+    "service_type": "MD-VPN (PROXY)",
+    "sid": "GS-01063",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708246,
+    "monitored": false,
+    "name": "PS-AMS-NL-OWAMP",
+    "scid": "5a3635d2-7492-4264-82f3-0701288caced",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00289",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "GEN02-GRV-2",
+        "port": "1/1/8"
+      }
+    ],
+    "imsid": 739944,
+    "monitored": true,
+    "name": "GEN2-LON1-ESNET-24015-2-400G",
+    "scid": "5a4a5fc1-b015-4977-a704-1c508c63265e",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02453",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.2126"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.2126"
+      }
+    ],
+    "imsid": 736734,
+    "monitored": true,
+    "name": "LON-PAR-CANARIE-CERN-15014",
+    "scid": "5a743cd3-fb7d-4ea1-9099-bd83a4897a2f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00720",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [],
+    "imsid": 732235,
+    "monitored": true,
+    "name": "HEANET-BGP-LU-COC-AP2",
+    "scid": "5a774eb9-3577-48dd-b73f-ebe5a14d3a2e",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01009",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.106/31",
+          "2001:798:cc:1::b9/126"
+        ],
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-8.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.107/31",
+          "2001:798:cc:1::ba/126"
+        ],
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-8.0"
+      }
+    ],
+    "imsid": 739436,
+    "monitored": true,
+    "name": "LON2-PAR-IPTRUNK",
+    "scid": "5a7c517a-0581-48bf-92b3-6bca478f5ac6",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00053",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 677589,
+    "monitored": false,
+    "name": "HAM OOB LINK",
+    "scid": "5a8a6e2c-22c0-4315-805e-eac80f2597f5",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00401",
+    "speed": 10485760,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ORANGE"
+    ],
+    "endpoints": [],
+    "imsid": 733925,
+    "monitored": false,
+    "name": "NL-ORANGE-2281-2",
+    "scid": "5ab4d709-c473-4b06-9a07-10e03b74998e",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-02182",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 714060,
+    "monitored": true,
+    "name": "RENAM-AP2-LAG",
+    "scid": "5ad22108-183d-4d49-aa2c-edc15ecf2008",
+    "service_type": "ETHERNET",
+    "sid": "GA-02038",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ham-ham_SCION_GTS-DFN_20020",
+    "scid": "5afeb2b4-f9a6-4fc1-8ec4-b29cd6f3e567",
+    "service_type": null,
+    "sid": "DS-51507",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658689,
+    "monitored": false,
+    "name": "730XD-2-VSAN-TRAFFIC-LAG",
+    "scid": "5b365f3b-2906-4c03-bccc-c87c2605a45b",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01676",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 678987,
+    "monitored": true,
+    "name": "DUB-DUB2-LAG",
+    "scid": "5b6a39c8-9066-4622-bde1-c3368a90c023",
+    "service_type": "ETHERNET",
+    "sid": "GA-01891",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 715163,
+    "monitored": true,
+    "name": "DUB2-LON-LAG",
+    "scid": "5b6cffcd-1c22-4469-ba8e-3a799f037103",
+    "service_type": "ETHERNET",
+    "sid": "GA-02007",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [],
+    "imsid": 661892,
+    "monitored": true,
+    "name": "GEN-PAR-LSST-RENATER-INTERNET2-16005",
+    "scid": "5bc855a6-fd97-4ac4-af0d-ab3ea6761c7c",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00713",
+    "speed": 536870912000,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CAAREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.14/31",
+          "2001:798:dd:9::1/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.23"
+      }
+    ],
+    "imsid": 732664,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-CAAREN",
+    "scid": "5bcf72e9-c2ff-453e-9ab3-449f1dc51123",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02376",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [],
+    "imsid": 712355,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-CARNET",
+    "scid": "5bcfba64-7a34-4ea9-93d0-def486730fcc",
+    "service_type": "MD-VPN (PROXY)",
+    "sid": "GS-01014",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lon.uk.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 738840,
+    "monitored": true,
+    "name": "LON-LON2-1.6T-LAG",
+    "scid": "5bdb6856-4078-448f-8589-fef8dcc10717",
+    "service_type": "ETHERNET",
+    "sid": "GA-01846",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/3"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/3.902"
+      }
+    ],
+    "imsid": 678922,
+    "monitored": false,
+    "name": "LON-LON-MISC-GEANT-INTERNET2-9940169",
+    "scid": "5bdd1b9c-d46e-400d-ae89-19af288cf1e4",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00725",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-0/0/47"
+      }
+    ],
+    "imsid": 658465,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-014(ETH)",
+    "scid": "5be9ef48-8006-428a-8429-d514c437fbb9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01251",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ath-lon-FutureInternet-GRNET-JANET-12204",
+    "scid": "5c3bf324-1a95-4c9c-ada1-7ce98428f365",
+    "service_type": null,
+    "sid": "GS-00666",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661493,
+    "monitored": false,
+    "name": "BOD-SDN-PILOT-HOST-ETH0-PRAGUE",
+    "scid": "5c41ebaf-52ef-4741-b0bb-a82f857686a5",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00101",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708729,
+    "monitored": false,
+    "name": "BRU-LON-IPTRUNK",
+    "scid": "5c4af477-5de7-4ef1-bda2-346db258a4d6",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00020",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae23"
+      }
+    ],
+    "imsid": 702102,
+    "monitored": true,
+    "name": "SWITCH-AP1-LAG",
+    "scid": "5c4f5fb4-f916-477a-8e2d-2f4ee2759098",
+    "service_type": "ETHERNET",
+    "sid": "GA-01880",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 741099,
+    "monitored": false,
+    "name": "LIS-PAR-BELLA-IPTRUNK",
+    "scid": "5c5d0c2a-44b0-4458-b54e-0c242ac60b8a",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02572",
+    "speed": 429496729600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NETHERLIGHT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "10.10.10.1/30"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.750"
+      }
+    ],
+    "imsid": 661590,
+    "monitored": true,
+    "name": "LON-NETHERLIGHT-OPEN-TEST-VLAN",
+    "scid": "5c5f7752-1a40-4383-9f6c-a6ee3dcb5929",
+    "service_type": "GEANT IP",
+    "sid": "GS-00488",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/6"
+      }
+    ],
+    "imsid": 658492,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-020(ETH)",
+    "scid": "5c6b0e1a-6320-48bd-b042-8ee96adbaa55",
+    "service_type": "ETHERNET",
+    "sid": "GA-01232",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CLOUDFERRO"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae35"
+      }
+    ],
+    "imsid": 731783,
+    "monitored": true,
+    "name": "CLOUDFERRO-FRA-LAG",
+    "scid": "5c6b2d3e-6771-46e1-958e-148cc450b937",
+    "service_type": "ETHERNET",
+    "sid": "GA-01966",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ENSTINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.300"
+      }
+    ],
+    "imsid": 734576,
+    "monitored": true,
+    "name": "NL-ENSTINET-AP1",
+    "scid": "5c88fe16-a180-4f16-901f-1d09c2cd9c4a",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00892",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae13"
+      }
+    ],
+    "imsid": 658695,
+    "monitored": false,
+    "name": "LON2-PRD-ESX03-VM-TRAFFIC",
+    "scid": "5ca32973-71d2-4001-a98a-de0d5ce4fc63",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01701",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.24/31",
+          "2001:798:1::e5/126"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae15.0"
+      }
+    ],
+    "imsid": 733062,
+    "monitored": false,
+    "name": "GOOGLE-2-15169-IT",
+    "scid": "5cb191e2-4708-4133-8f4f-a6b9a56305ed",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-02248",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 712374,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-NORDUNET-1-DK",
+    "scid": "5cc08d50-aaf3-43a0-ab95-cf8a87bf21df",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01047",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708259,
+    "monitored": false,
+    "name": "VEEAMSERVER-BRA-IDRAC",
+    "scid": "5cda5c86-7569-4ac1-ad5c-2e49cbcbbc31",
+    "service_type": "POP LAN LINK",
+    "sid": "GS-00083",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "LAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.145/30",
+          "2001:798:1::b1/126"
+        ],
+        "hostname": "rt0.kau.lt.geant.net",
+        "interface": "lag-20.33"
+      }
+    ],
+    "imsid": 746531,
+    "monitored": true,
+    "name": "LAT-AP2-IAS",
+    "scid": "5d29ec85-4dbf-4b58-812c-d6b8b5cea92d",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00578",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661352,
+    "monitored": false,
+    "name": "NPL-TEST-LON-UK-VLAN300",
+    "scid": "5d4eae42-8d7d-44ea-b542-cb73836633a4",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00259",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 677777,
+    "monitored": false,
+    "name": "POZ OOB LINK",
+    "scid": "5d6b1b26-8dae-4676-93af-b39682d1e7ce",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00413",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "MIL-VIE-TRUNK",
+    "scid": "5daeab3f-418c-42c4-a50a-f638c7676edc",
+    "service_type": null,
+    "sid": "DS-12689",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AZSCIENCENET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-11/2/5"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae37"
+      }
+    ],
+    "imsid": 731781,
+    "monitored": true,
+    "name": "AZSCIENCENET-FRA-LL-1",
+    "scid": "5dcdb879-3ad3-4f22-b310-c746d129f839",
+    "service_type": "ETHERNET",
+    "sid": "GA-01599",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.LJU2.SI.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 669568,
+    "monitored": false,
+    "name": "LJU OOB IP LINK",
+    "scid": "5df60e13-66ef-4dcb-a662-5fddccb10b6d",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00404",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662971,
+    "monitored": false,
+    "name": "RARE-P4-MANAGEMENT-VLAN26",
+    "scid": "5e061145-adfe-4a20-9231-39aa6a2dcf0d",
+    "service_type": "L2SERVICES",
+    "sid": "GS-00775",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.21.5.1/24"
+        ],
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae2.998"
+      }
+    ],
+    "imsid": 679551,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-LIS-PT",
+    "scid": "5e73dd25-c9b5-430e-ac21-cd8c4c09ed13",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00153",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.19"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240592"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4061"
+      }
+    ],
+    "imsid": 744266,
+    "monitored": true,
+    "name": "MSESTAD-02245",
+    "scid": "5ea103fa-88e1-4f5b-9471-2948d0559b08",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02245",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "149.6.175.250/29",
+          "2001:978:2::3c:2/112"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae29.0"
+      }
+    ],
+    "imsid": 708322,
+    "monitored": true,
+    "name": "COGENT-GWS-VIE",
+    "scid": "5eb259ba-53a9-4e31-91d7-f3136aac9aab",
+    "service_type": "GWS - UPSTREAM",
+    "sid": "GS-00067",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.254/31",
+          "2001:798:111:1::45/126"
+        ],
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae11.111"
+      }
+    ],
+    "imsid": 725154,
+    "monitored": true,
+    "name": "CESNET-AP1-LHCONE",
+    "scid": "5ec1ebab-ecb8-4969-8652-6c696851a063",
+    "service_type": "L3-VPN",
+    "sid": "GS-00813",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMT1.FRA.DE",
+        "port": "AE1.0"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae7.0"
+      }
+    ],
+    "imsid": 744390,
+    "monitored": true,
+    "name": "FRA-FRA-AMT-RELAYLINK",
+    "scid": "5ec2ccb7-1de2-4e89-a53d-6e6d0cf1b364",
+    "service_type": "SERVER LINK",
+    "sid": "GS-02306",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-5"
+      }
+    ],
+    "imsid": 745265,
+    "monitored": true,
+    "name": "MIL2-THE-LAG",
+    "scid": "5eed4367-d2e9-441e-b825-638b6b41e91a",
+    "service_type": "ETHERNET",
+    "sid": "GA-02607",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.FRA.DE.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-11/2/0.702"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/2.702"
+      }
+    ],
+    "imsid": 733002,
+    "monitored": false,
+    "name": "PAR-FRA-DTN-GENERATOR",
+    "scid": "5eefc369-de0e-4f84-8706-4bc214ec7ca8",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00745",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.66/31",
+          "2001:798:111:1::f9/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae23.611"
+      }
+    ],
+    "imsid": 729642,
+    "monitored": true,
+    "name": "SWITCH-UNIBE-LHCONE",
+    "scid": "5f30d7c0-b8d2-4f3e-abf1-0a2e1b19f280",
+    "service_type": "L3-VPN",
+    "sid": "GS-02378",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae2.3005"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae2.3501"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.3501"
+      }
+    ],
+    "imsid": 736109,
+    "monitored": false,
+    "name": "RARE-P4-MANAGEMENT-VLAN26",
+    "scid": "5f46fcf2-facf-4544-b989-84dd78515b34",
+    "service_type": "L2SERVICES",
+    "sid": "GS-02639",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/1/4.1337"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.1337"
+      }
+    ],
+    "imsid": 726378,
+    "monitored": false,
+    "name": "AMS-GEN-SCION-SURF-SCION-23012",
+    "scid": "5f6fe82b-6979-4bf2-a852-b81cb1a104b2",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02263",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661744,
+    "monitored": false,
+    "name": "TAAS-GTS-GATE",
+    "scid": "5f7ff061-cb43-49ad-ab9d-f6ff9bafbcf2",
+    "service_type": "GTS",
+    "sid": "GS-01191",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "T-SYSTEMS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae27"
+      }
+    ],
+    "imsid": 734842,
+    "monitored": true,
+    "name": "NL-T-SYSTEM-LAG",
+    "scid": "5f8e4602-2fb8-4c07-91f0-47fd237874db",
+    "service_type": "ETHERNET",
+    "sid": "GA-02270",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.2200"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.2200"
+      }
+    ],
+    "imsid": 736080,
+    "monitored": false,
+    "name": "AMS-PAR-RENATER-RARE-20070",
+    "scid": "5faba6a7-a8fe-4de0-90d0-0dce30cc8f69",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00657",
+    "speed": 332859965440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.30/31",
+          "2001:798:dd:6::5/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-11/0/0.666"
+      }
+    ],
+    "imsid": 716843,
+    "monitored": false,
+    "name": "RARE-PAR-FR",
+    "scid": "5fc2b664-0190-490d-8bb8-3c88175d267d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00369",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae11"
+      }
+    ],
+    "imsid": 658655,
+    "monitored": false,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-052(GEANT)",
+    "scid": "5fe0fc36-a470-4f12-83b1-02a2ed2b0042",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01683",
+    "speed": 32212254720,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743128,
+    "monitored": true,
+    "name": "RIG-RIG-MGMT-LAG",
+    "scid": "5fe35af3-9e2b-4eab-aa4f-a2538171937e",
+    "service_type": "ETHERNET",
+    "sid": "GA-02611",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708006,
+    "monitored": true,
+    "name": "RIG-TAL-LAG",
+    "scid": "60248db0-848f-4eb4-b38a-de80b3109513",
+    "service_type": "ETHERNET",
+    "sid": "GA-01734",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 718155,
+    "monitored": true,
+    "name": "BRATISLAVA-BRATISLAVA-10GBE-003(GEANT)",
+    "scid": "60385cb5-e120-46f2-8113-5cd839876970",
+    "service_type": "ETHERNET",
+    "sid": "GA-01295",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ge-0/3/2.60"
+      }
+    ],
+    "imsid": 661623,
+    "monitored": false,
+    "name": "KVMOIP-VIE-AT",
+    "scid": "60421eeb-95b6-418c-90e6-0a286893fcae",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00224",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MANLAN"
+    ],
+    "endpoints": [],
+    "imsid": 727573,
+    "monitored": false,
+    "name": "PAR-PAR-MANLAN-SURFNET-6009641475",
+    "scid": "60942ce5-1df0-4996-a033-93eec9f96792",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02317",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.3100"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3100"
+      }
+    ],
+    "imsid": 705937,
+    "monitored": true,
+    "name": "LON-LON-SURF-AARNET-19097",
+    "scid": "60bfe66b-a9c4-485b-8e23-2411c90179f0",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00721",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae17"
+      }
+    ],
+    "imsid": 658654,
+    "monitored": false,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-051(GEANT)",
+    "scid": "60cee9da-b952-49dd-a46d-4ae990d2c92e",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01689",
+    "speed": 32212254720,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.FRA.DE.GEANT.NET",
+        "port": "XE-1"
+      },
+      {
+        "equipment": "PF1-RARE.BUD.HU.GEANT.NET",
+        "port": "XE-1"
+      },
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "xe-3/0/1.0"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/1.0"
+      }
+    ],
+    "imsid": 708177,
+    "monitored": false,
+    "name": "BUD-FRA-RARE-P4-9951387",
+    "scid": "60ee5b00-c0a2-4b23-b02d-5c06fb830712",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00684",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "LIS01-GRV-1",
+        "port": "1/1/4"
+      },
+      {
+        "equipment": "POR01-GRV-1",
+        "port": "1/1/4"
+      },
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "et-4/0/5"
+      },
+      {
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "et-0/1/2"
+      }
+    ],
+    "imsid": 712167,
+    "monitored": true,
+    "name": "LIS-POR-IP2",
+    "scid": "60f86de5-9e02-48ba-9ee4-ffc59d32063a",
+    "service_type": "ETHERNET",
+    "sid": "GS-00800",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/1/6"
+      }
+    ],
+    "imsid": 669221,
+    "monitored": true,
+    "name": "RENATER GN2PLUS LL",
+    "scid": "610e0c6b-02f6-479c-8df4-a954f5960975",
+    "service_type": "ETHERNET",
+    "sid": "GA-01385",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EENET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.49/30",
+          "2001:798:16:10aa::1/126"
+        ],
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "lag-20.100"
+      }
+    ],
+    "imsid": 746455,
+    "monitored": true,
+    "name": "EENET-AP1",
+    "scid": "614ff2fd-99a8-4451-a4d9-a6cb6dd21be7",
+    "service_type": "GEANT IP",
+    "sid": "GS-00454",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "MICROSOFT-LAG-2",
+    "scid": "615600da-fc4d-407c-98e2-af87dddec7bc",
+    "service_type": null,
+    "sid": "GA-01797",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "LAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.237/30",
+          "2001:798:99:1::51/126"
+        ],
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-20.83"
+      }
+    ],
+    "imsid": 745983,
+    "monitored": true,
+    "name": "LAT-AP1",
+    "scid": "618967ae-7cb7-4440-af58-bc5c1c87becf",
+    "service_type": "GEANT IP",
+    "sid": "GS-00484",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.lon2.uk - Traffic - xe-2/0/5.13 - SRV_L2CIRCUIT CUSTOMER WP6T3 WP6T3 #lon2_pra-WP6-GTS_20063 |",
+    "scid": "619a1480-a935-4cfa-85be-4aa20f6cc0fc",
+    "service_type": null,
+    "sid": "DS-52366",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663089,
+    "monitored": false,
+    "name": "AMS-GROOVE-3",
+    "scid": "61a97882-e717-494b-baec-9619ce879bbb",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00095",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708863,
+    "monitored": true,
+    "name": "DUB-DUB2-IPTRUNK",
+    "scid": "61d5f9af-3f6a-48b4-a5df-99bf124ff545",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00030",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae21"
+      }
+    ],
+    "imsid": 727954,
+    "monitored": true,
+    "name": "T-SYSTEMS FRA 100G LAG",
+    "scid": "61f45093-67ac-4261-967e-c27721b127d2",
+    "service_type": "ETHERNET",
+    "sid": "GA-02272",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-9"
+      }
+    ],
+    "imsid": 739968,
+    "monitored": true,
+    "name": "AMS-HAM-LAG-300G",
+    "scid": "62520bbe-774f-4d47-9ed3-c8572be551d5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01896",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 746301,
+    "monitored": true,
+    "name": "HAM-TAR-LAG",
+    "scid": "626d1035-cc8c-4d04-b1f8-d83ee5e2294b",
+    "service_type": "ETHERNET",
+    "sid": "GA-02349",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "COGENT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae32"
+      }
+    ],
+    "imsid": 731784,
+    "monitored": true,
+    "name": "COGENT-FRA-LAG",
+    "scid": "62bebeba-9d0b-4cd2-b043-eddcba0f45a0",
+    "service_type": "ETHERNET",
+    "sid": "GA-01939",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "UOM"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae19"
+      }
+    ],
+    "imsid": 720364,
+    "monitored": true,
+    "name": "UOM-AP2-100G-LAG",
+    "scid": "62c2786b-5087-475d-b82c-08681a4a7e5f",
+    "service_type": "ETHERNET",
+    "sid": "GA-02163",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708313,
+    "monitored": false,
+    "name": "PS-FRA-DE-PSMP2-BWCTL",
+    "scid": "62ca3c46-1628-40c4-a920-946c3fb7ba3a",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00302",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659094,
+    "monitored": true,
+    "name": "PARIS-FLOWMON-NET-1GBE-009(ETH)",
+    "scid": "62d26f33-f331-4a6c-a47b-c8134d1d85da",
+    "service_type": "ETHERNET",
+    "sid": "GA-01402",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.153/30",
+          "2001:798:1::bd/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae23.333"
+      }
+    ],
+    "imsid": 663229,
+    "monitored": true,
+    "name": "SWITCH-AP1-IAS",
+    "scid": "62da0b17-5cf1-43c3-b882-2789a00a949f",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00589",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae10.3260"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.3260"
+      }
+    ],
+    "imsid": 732707,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-JISC-NEA3R",
+    "scid": "62de5e96-007d-49e3-bc14-a6dc4aa4358b",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-02399",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.poz.pl.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 740147,
+    "monitored": true,
+    "name": "POZ-POZ-LAG",
+    "scid": "62f0b62d-ab89-48b5-9fb9-e8248b721d81",
+    "service_type": "ETHERNET",
+    "sid": "GA-02527",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ORANGE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.90.8/31",
+          "2001:798:1::225/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae32.0"
+      }
+    ],
+    "imsid": 720102,
+    "monitored": true,
+    "name": "FR-ORANGE-2280",
+    "scid": "62f70f04-2a06-498c-81c0-7fa7202a68c9",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-02180",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708261,
+    "monitored": false,
+    "name": "FLOWMON-PAR-FR-NETFLOW",
+    "scid": "630bf59c-1f88-49cd-8bbe-4cfce53b903f",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00169",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.fra.de.geant.net",
+        "interface": "ae19.113"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae10.113"
+      }
+    ],
+    "imsid": 705431,
+    "monitored": true,
+    "name": "FRA-GEN-ORACLE-CERN-19114",
+    "scid": "6321c237-8890-48d6-ab96-ae8e0abf8c71",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00697",
+    "speed": 128849018880,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lju.si.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 747864,
+    "monitored": true,
+    "name": "LJU-ZAG-LAG",
+    "scid": "632286fd-79c5-4541-8e87-bca20782af51",
+    "service_type": "ETHERNET",
+    "sid": "GA-02373",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PSMP-GN-DRAC-LON2-UK.GEANT.ORG",
+        "port": "0-2"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/3/0"
+      },
+      {
+        "addresses": [
+          "62.40.107.222/31",
+          "2001:798:bb:2::d1/126"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/3/0.0"
+      }
+    ],
+    "imsid": 708222,
+    "monitored": false,
+    "name": "PSMP-MANAGEMENT-LON2-UK",
+    "scid": "63360d55-2a7d-4f23-8d47-ec95bf1a27dc",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00361",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.38/31",
+          "2001:798::45/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae14.667"
+      }
+    ],
+    "imsid": 662915,
+    "monitored": false,
+    "name": "RENATER-AP2-CLS",
+    "scid": "63449276-bb8b-4fcb-aa7c-56fbad888b43",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00619",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 703027,
+    "monitored": true,
+    "name": "SOF-VIE-LAG",
+    "scid": "635f2547-2e38-42fc-823c-c09a0ceed4e0",
+    "service_type": "ETHERNET",
+    "sid": "GA-01731",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "138.44.226.19/31"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.2102"
+      }
+    ],
+    "imsid": 709695,
+    "monitored": false,
+    "name": "AARNET-LON-LHCONE-AER",
+    "scid": "63614065-ea3f-4734-8607-05873d8ed563",
+    "service_type": "L3-VPN",
+    "sid": "GS-00806",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.4006"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae10.4006"
+      }
+    ],
+    "imsid": 719849,
+    "monitored": true,
+    "name": "AMS-LON-5GUK-JISC-NKN-22048",
+    "scid": "636b6093-7ae5-4d20-803f-eff875a1386f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02162",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SANET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.10/31",
+          "2001:798:99:1::49/126"
+        ],
+        "hostname": "rt2.bra.sk.geant.net",
+        "interface": "ae13.420"
+      }
+    ],
+    "imsid": 733189,
+    "monitored": false,
+    "name": "SANET-AP2",
+    "scid": "638759b1-1bb4-46c0-b47c-2593a90333c3",
+    "service_type": "GEANT IP",
+    "sid": "GS-02438",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663245,
+    "monitored": false,
+    "name": "IPCAMERA-FRA-DE",
+    "scid": "6399fc15-c6e9-4d99-802b-7d2f1ea3be74",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00209",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [],
+    "imsid": 669640,
+    "monitored": false,
+    "name": "LJU-MIL2-ARNES-GARR-19014",
+    "scid": "63a47ec5-00c7-49a4-9b92-dada8c031d63",
+    "service_type": "GEANT LAMBDA",
+    "sid": "GS-00801",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661617,
+    "monitored": false,
+    "name": "MIL2-GROOVE-1",
+    "scid": "63b2cbb0-619f-4004-9275-a011b83d49ca",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00248",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "212.133.15.10/30",
+          "2001:1900:5:2:2:0:8:852a/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae21.0"
+      }
+    ],
+    "imsid": 728441,
+    "monitored": true,
+    "name": "COLT-GWS-BUD",
+    "scid": "63b6a84f-c1d2-4c8d-aa9d-9b3eda14e6fd",
+    "service_type": "GWS - UPSTREAM",
+    "sid": "GS-00068",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 735952,
+    "monitored": true,
+    "name": "RT1.AMS-RT2.AMS-LAG",
+    "scid": "63b83d3b-216a-488f-89e7-d9dfcd2998af",
+    "service_type": "ETHERNET",
+    "sid": "GA-02013",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 745463,
+    "monitored": true,
+    "name": "ATH2-THE-LAG",
+    "scid": "63d1ed0b-87f7-4523-827b-b492068584cc",
+    "service_type": "ETHERNET",
+    "sid": "GA-02422",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae5"
+      }
+    ],
+    "imsid": 658516,
+    "monitored": false,
+    "name": "LON2-SEC-ESX21-ESXI-TRAFFIC",
+    "scid": "63d24ad4-f10d-40a5-9870-8fb7db3bf9cb",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01697",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.26.1/24"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/2.991"
+      }
+    ],
+    "imsid": 713898,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-LON2-UK",
+    "scid": "63f6f98e-ecd7-481c-a424-3f95bc39e699",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00120",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae14"
+      }
+    ],
+    "imsid": 733808,
+    "monitored": true,
+    "name": "CYNET-AP1-LAG",
+    "scid": "6406dd0b-2085-4f17-a237-aced710c1c7b",
+    "service_type": "ETHERNET",
+    "sid": "GA-02440",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.gen.ch.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 740947,
+    "monitored": true,
+    "name": "GEN-MIL2-LAG",
+    "scid": "6432dc8e-4faa-42a0-84e9-0fe95ce17715",
+    "service_type": "ETHERNET",
+    "sid": "GA-01886",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.193/30"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.12"
+      }
+    ],
+    "imsid": 732663,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-KNMI",
+    "scid": "6434c00d-099f-4d24-8eb2-5fd9a8514cb1",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01083",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "Link to Interoute for Helix Nebula",
+    "scid": "6447f228-9207-4bc2-b882-af545305af9a",
+    "service_type": null,
+    "sid": "DA-25427",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "addresses": [
+          "62.40.106.90/29",
+          "2001:798:bb:9::2/64"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "irb.3002"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae30.3002"
+      }
+    ],
+    "imsid": 733022,
+    "monitored": false,
+    "name": "PS-LATENCY-NETWORK-FRA-DE",
+    "scid": "6461a73e-a999-4eb5-8a11-3bc7582c351e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00312",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/25"
+      }
+    ],
+    "imsid": 658496,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-024(ETH)",
+    "scid": "6466ecbd-d00a-4a9b-a0ed-fd14ac07a471",
+    "service_type": "ETHERNET",
+    "sid": "GA-01238",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIAE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.0/31",
+          "2001:798:111:1::7d/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae16.111"
+      }
+    ],
+    "imsid": 734247,
+    "monitored": false,
+    "name": "NL-KIAE-LHCONE",
+    "scid": "64cf2767-c24e-4b6e-85c2-b4a4195500fb",
+    "service_type": "L3-VPN",
+    "sid": "GS-00836",
+    "speed": 32212254720,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.254.9/30"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "gr-10/1/0.0"
+      }
+    ],
+    "imsid": 737548,
+    "monitored": false,
+    "name": "FORTIGATE-TUNNEL-TO-CH-LON2-UK",
+    "scid": "64e66cb7-9b93-4c6f-b95f-0a50ea6a4cbc",
+    "service_type": "L3-VPN",
+    "sid": "GS-02124",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "CSTNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.184/31",
+          "2001:798:99:1::12d/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae12.1005"
+      }
+    ],
+    "imsid": 729009,
+    "monitored": true,
+    "name": "FR-IC1-CSTNET-PRIMARY",
+    "scid": "6515de12-fb6a-4e93-bddb-163e19272e8b",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02358",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "et-10/0/5"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae17"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae17.1"
+      }
+    ],
+    "imsid": 668957,
+    "monitored": true,
+    "name": "SURF-GEO-FR-1-LL",
+    "scid": "654caf28-87eb-467b-bcfb-5828cca231a7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01819",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ACONET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.1/30",
+          "2001:798:1::5/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae15.52"
+      }
+    ],
+    "imsid": 661622,
+    "monitored": true,
+    "name": "ACONET-AP1-IAS",
+    "scid": "65604160-6d30-4715-b63c-d50e630e2ef8",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00550",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.fra.de - Traffic - ae23 - LAG GRENA + AzScienceNet",
+    "scid": "6594ec51-c431-46bc-aebc-7e3f639d2719",
+    "service_type": null,
+    "sid": "GA-01949",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "LINX"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "195.66.226.161/21",
+          "2001:7f8:4:0::5348:1/64"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae20.0"
+      }
+    ],
+    "imsid": 708212,
+    "monitored": false,
+    "name": "IX-PEERINGS-IN-LINX",
+    "scid": "65a46d05-0ae9-4f66-a5b4-180a244d6c33",
+    "service_type": "IP PEERING - NON R&E (PUBLIC)",
+    "sid": "GS-00951",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ge-0/0/9"
+      }
+    ],
+    "imsid": 659068,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-020(ETH)",
+    "scid": "65c07874-01cf-4834-94dd-7fb5c8b97e28",
+    "service_type": "ETHERNET",
+    "sid": "GA-01502",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3.1022"
+      }
+    ],
+    "imsid": 661201,
+    "monitored": true,
+    "name": "SDN-BOD-BR53-OF-1-HOST-G-ETH1",
+    "scid": "65c2d5a1-14e4-4c07-a56b-4e3d1de29471",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00753",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660443,
+    "monitored": false,
+    "name": "MIL2-GROOVE-2",
+    "scid": "65de4502-620b-400a-b880-6023c3289135",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00250",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "LAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.89/30",
+          "2001:798:21:10aa::1/126"
+        ],
+        "hostname": "rt0.kau.lt.geant.net",
+        "interface": "lag-20.83"
+      }
+    ],
+    "imsid": 746529,
+    "monitored": true,
+    "name": "LAT-AP2",
+    "scid": "65e233d2-3663-40dd-9851-8ed91256c156",
+    "service_type": "GEANT IP",
+    "sid": "GS-00485",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.9/30",
+          "2001:798::1/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae17.667"
+      }
+    ],
+    "imsid": 662938,
+    "monitored": false,
+    "name": "CERN-AP1-CLS",
+    "scid": "65f1d652-995b-4dd6-86ba-6f9ff6787f30",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00598",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae15"
+      }
+    ],
+    "imsid": 658662,
+    "monitored": false,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-053(GEANT)",
+    "scid": "65f8c2ad-03c8-4c96-a97d-c2b0e5efb7a3",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01687",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 715106,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10GBE-017(GEANT)",
+    "scid": "6602a6b0-2c4f-4030-b3a1-eac31cf3e682",
+    "service_type": "ETHERNET",
+    "sid": "GA-01572",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae10.4086"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.23"
+      }
+    ],
+    "imsid": 707643,
+    "monitored": true,
+    "name": "GARR-UDMILANO_EXPRESSROUTE_VLAN4086",
+    "scid": "6602bd2e-aaa1-4f9f-bc7b-63ebeff4ffc2",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01148",
+    "speed": 332859965440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.mad.es.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 742614,
+    "monitored": true,
+    "name": "MAD-MAD-MGMT-LAG",
+    "scid": "6606138a-a403-4cf4-b47b-ff70c3834708",
+    "service_type": "ETHERNET",
+    "sid": "GA-02592",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "WP6T3"
+    ],
+    "endpoints": [],
+    "imsid": 714884,
+    "monitored": false,
+    "name": "LON2-PRA-WP7T2SF-BMS8-BMS7-21090",
+    "scid": "6659ecaf-073f-48bf-bf92-e58d72225ab3",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00741",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-2/0/5"
+      }
+    ],
+    "imsid": 658429,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-012(ETH)",
+    "scid": "66630962-157a-4ae9-9797-987e14104247",
+    "service_type": "ETHERNET",
+    "sid": "GA-01266",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30.3001"
+      },
+      {
+        "addresses": [
+          "10.0.1.131/26"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "irb.3001"
+      }
+    ],
+    "imsid": 712156,
+    "monitored": false,
+    "name": "TAAS-CONTROL-NAGIOS-PAR-FR",
+    "scid": "666cbcf7-f155-4583-be57-0ac4789d273d",
+    "service_type": "L3-VPN",
+    "sid": "GS-00864",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.197/30",
+          "2001:798:28:10aa::1/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae10.0"
+      }
+    ],
+    "imsid": 661264,
+    "monitored": true,
+    "name": "JISC-AP1",
+    "scid": "66a379b2-008f-4e20-9933-cbb010d56541",
+    "service_type": "GEANT IP",
+    "sid": "GS-00479",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "xe-11/2/0"
+      },
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "xe-4/0/1.0"
+      },
+      {
+        "addresses": [
+          "62.40.106.254/31",
+          "2001:798:bb:2::31/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "xe-11/2/0.0"
+      }
+    ],
+    "imsid": 708284,
+    "monitored": false,
+    "name": "PS-VIE-AT-OWAMP",
+    "scid": "66ce6653-8682-49cf-b3ad-f669a0335cb2",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00355",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "KREONET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.1237"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.1237"
+      }
+    ],
+    "imsid": 736100,
+    "monitored": false,
+    "name": "AMS-AMS-KREONET-RARE-22097",
+    "scid": "66dc7964-6858-4346-9c20-170d181d582c",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02218",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 721423,
+    "monitored": true,
+    "name": "RIGA-RIGA-LAG-001(GEANT)",
+    "scid": "66e9b540-f715-435b-b1b1-bef7293ca21b",
+    "service_type": "ETHERNET",
+    "sid": "GA-02032",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.buc.ro.geant.net",
+        "interface": "ae7"
+      }
+    ],
+    "imsid": 730316,
+    "monitored": true,
+    "name": "BUC-BUD-LAG-(200G)",
+    "scid": "66ed9ab4-46c9-4afd-9082-ff3feb7deaa9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01932",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "TENET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae28"
+      }
+    ],
+    "imsid": 717772,
+    "monitored": true,
+    "name": "UK-TENET-LAG",
+    "scid": "6709781f-360f-4558-8d1c-3223aa068321",
+    "service_type": "ETHERNET",
+    "sid": "GA-02014",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae11.938"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.938"
+      }
+    ],
+    "imsid": 747231,
+    "monitored": false,
+    "name": "PRA-AMS-CESNET-SURF-FABRIC",
+    "scid": "67270457-2412-4ba2-802f-dfdf9a5818e7",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02649",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708318,
+    "monitored": false,
+    "name": "PS-PAR-FR-BWCTL-XE4/1/5",
+    "scid": "672df9ce-8663-434b-aebd-64bcc3f1ad15",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00339",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708748,
+    "monitored": false,
+    "name": "VIE-ZAG-IPTRUNK",
+    "scid": "6743227f-b03c-44d5-9943-f31eea3b1da0",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00064",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/1/4.142"
+      },
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae11.142"
+      }
+    ],
+    "imsid": 732905,
+    "monitored": false,
+    "name": "GEN-LIS-SCION-REDCLARA",
+    "scid": "6747f3d7-9fa0-4204-92a0-e2d10876e0f7",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02436",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659214,
+    "monitored": true,
+    "name": "VIENNA-VERIZON-LL-2-1",
+    "scid": "675f3613-9e44-4686-b55e-8513b85209ba",
+    "service_type": "ETHERNET",
+    "sid": "GA-01489",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 726395,
+    "monitored": true,
+    "name": "IE-NORDUNET-LAG",
+    "scid": "67777750-ce29-4f05-9c6a-90d7bde924f5",
+    "service_type": "ETHERNET",
+    "sid": "GA-02266",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AMRES"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.177/30",
+          "2001:798:1b:10aa::1/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-21.1"
+      }
+    ],
+    "imsid": 744955,
+    "monitored": true,
+    "name": "AMRES-AP2",
+    "scid": "67820162-4812-4dbb-8feb-62e905a4ea57",
+    "service_type": "GEANT IP",
+    "sid": "GS-02240",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.mad.es - Traffic - lc-7/0/0.32769",
+    "scid": "67b8a69c-a976-4197-ab58-ca23ac7537fc",
+    "service_type": null,
+    "sid": "DS-23039",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658867,
+    "monitored": true,
+    "name": "MILAN 2 CALDERA-MILAN 2 CALDERA-10GBE-008(ETH)",
+    "scid": "67bd7732-2d04-4b54-99a5-b9bc950db94f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01336",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RESTENA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.137/30",
+          "2001:798:1::a5/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae18.333"
+      }
+    ],
+    "imsid": 732134,
+    "monitored": true,
+    "name": "RESTENA-AP1-IAS",
+    "scid": "67c5a332-a133-4310-8539-9fbcd2b20c24",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00585",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743397,
+    "monitored": true,
+    "name": "TAR-TAR-MGMT-IPTRUNK",
+    "scid": "67ca9197-54f0-44be-8d2b-7291a845d620",
+    "service_type": "IP TRUNK",
+    "sid": "GS-50003",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 734095,
+    "monitored": true,
+    "name": "ATH2-ATH2-LAG",
+    "scid": "67fefa57-af16-464e-b8cb-a77e64599261",
+    "service_type": "ETHERNET",
+    "sid": "DA-00098",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15"
+      }
+    ],
+    "imsid": 734472,
+    "monitored": true,
+    "name": "NL-SURF-LAG",
+    "scid": "68095eff-5d56-4894-9046-9f857495ebde",
+    "service_type": "ETHERNET",
+    "sid": "GA-01919",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [],
+    "imsid": 732659,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-IMO",
+    "scid": "684277cc-4de2-4df9-ab7d-e1434354cdad",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-02097",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.97/31",
+          "2001:798:cc::3e/126"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae4.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.96/31",
+          "2001:798:cc::3d/126"
+        ],
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae4.0"
+      }
+    ],
+    "imsid": 712769,
+    "monitored": true,
+    "name": "LIS-MAD-IPTRUNK",
+    "scid": "68585a7d-8363-4e9e-b6ef-9edfff9104a2",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00048",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663097,
+    "monitored": false,
+    "name": "INFOBLOX-DNS-BUD-HU-VLAN200",
+    "scid": "685bd8a6-4026-428b-900e-a5d5fc302d5e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00206",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.17/30",
+          "2001:0798:0010:10aa::15/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae18.100"
+      }
+    ],
+    "imsid": 734871,
+    "monitored": true,
+    "name": "KIFU-AP2",
+    "scid": "685fa542-7cb9-4192-8c61-7091e7a65354",
+    "service_type": "GEANT IP",
+    "sid": "GS-00482",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RARE"
+    ],
+    "endpoints": [],
+    "imsid": 735909,
+    "monitored": false,
+    "name": "AMS-AMS-WP7TSF-RARE-200105-AMS",
+    "scid": "686b1c7f-e17b-4b11-afe0-5f21248cad3a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00625",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ROEDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.244/31",
+          "2001:798:111:1::a5/126"
+        ],
+        "hostname": "rt0.buc.ro.geant.net",
+        "interface": "lag-20.111"
+      }
+    ],
+    "imsid": 747923,
+    "monitored": false,
+    "name": "ROEDUNET-AP1-LHCONE",
+    "scid": "687404e7-26ce-4f6f-9e68-9ed427e980a6",
+    "service_type": "L3-VPN",
+    "sid": "GS-00857",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.52/31",
+          "2001:798:99:1::6d/126"
+        ],
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-20.100"
+      }
+    ],
+    "imsid": 745493,
+    "monitored": true,
+    "name": "GRNET-AP1",
+    "scid": "687abed5-3662-4d4e-b702-d25373afc721",
+    "service_type": "GEANT IP",
+    "sid": "GS-00471",
+    "speed": 64424509440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.104.49/29",
+          "2001:798:6::1/64"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae1.3009"
+      }
+    ],
+    "imsid": 729102,
+    "monitored": false,
+    "name": "INFOBLOX-GRID-FRA-DE",
+    "scid": "689e7d7c-3da1-4699-b8c0-f7b228489d9c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00201",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae7"
+      }
+    ],
+    "imsid": 740948,
+    "monitored": true,
+    "name": "MIL2-MIL2-LAG",
+    "scid": "68f63a59-1fe7-491a-830d-16669a01da62",
+    "service_type": "ETHERNET",
+    "sid": "GA-02546",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662950,
+    "monitored": false,
+    "name": "GEN-GROOVE-3-MANAGEMENT",
+    "scid": "690e3c02-b0c7-4727-894b-49225a641692",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00186",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae1.3005"
+      }
+    ],
+    "imsid": 739308,
+    "monitored": false,
+    "name": "RARE-P4-MANAGEMENT-VLAN3005",
+    "scid": "69329700-b6f1-45b7-8138-d6043fb9c9ba",
+    "service_type": "L2SERVICES",
+    "sid": "GS-02641",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.fra.de - DE-LU Multicast Traffic",
+    "scid": "6939b127-709f-488e-9c8d-33354815cc04",
+    "service_type": null,
+    "sid": "DS-22013",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/5"
+      }
+    ],
+    "imsid": 658587,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-034(ETH)",
+    "scid": "695e9958-d51d-43b1-a3d3-51b74495370d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01213",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.28/31",
+          "2001:798::2d/126"
+        ],
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae10.667"
+      }
+    ],
+    "imsid": 714068,
+    "monitored": true,
+    "name": "RENAM-AP1-CLS",
+    "scid": "69a70f7d-8c03-41b0-b561-0a93d53ce7f4",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00617",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 658748,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-1GBE-004(ETH)",
+    "scid": "69b0b4de-95ff-4fcc-90ed-4fa2770978dc",
+    "service_type": "ETHERNET",
+    "sid": "GA-01446",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ROEDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.141/30",
+          "2001:798:1::a9/126"
+        ],
+        "hostname": "rt0.buc.ro.geant.net",
+        "interface": "lag-20.333"
+      }
+    ],
+    "imsid": 747922,
+    "monitored": false,
+    "name": "ROEDUNET-AP1-IAS",
+    "scid": "69d29376-ae69-4fc5-8487-c1d39ea81e5f",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00544",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658670,
+    "monitored": false,
+    "name": "730XD-4-VSAN-TRAFFIC-LAG-PAR",
+    "scid": "6a32c63e-40ad-478e-be80-086a393d1ee0",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01722",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 731422,
+    "monitored": false,
+    "name": "NORDUNET-BGP-LU-COC-AP2",
+    "scid": "6a3e19f8-53f0-495e-9794-c69f176aa49f",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01054",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AMRES"
+    ],
+    "endpoints": [],
+    "imsid": 725487,
+    "monitored": true,
+    "name": "AMRES-AP1-BGP-LU-COC",
+    "scid": "6a64ef09-a7ef-41f2-bfec-d3f2d8ceb895",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-00997",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663093,
+    "monitored": false,
+    "name": "MDM-AMS-NL-VLAN91",
+    "scid": "6a7217a7-eb47-4b5b-9ecc-79455cde0bb7",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00245",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 746144,
+    "monitored": true,
+    "name": "MAR-MIL2-LAG",
+    "scid": "6a74cb54-4c64-4462-82e0-5f485ba3befc",
+    "service_type": "ETHERNET",
+    "sid": "GA-01776",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 701541,
+    "monitored": true,
+    "name": "AMS-LON-LAG",
+    "scid": "6abea3ab-7337-4b1c-8564-0ebc32969cd4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01914",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 718935,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-HAM1-DE",
+    "scid": "6ad604dd-3131-4b4a-b389-e0ffd1fbd0a4",
+    "service_type": "SERVER LINK",
+    "sid": "GS-01289",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ARN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.60/31",
+          "2001:798:99:1::119/126"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae18.100"
+      }
+    ],
+    "imsid": 724758,
+    "monitored": true,
+    "name": "ES-ARN-AP1",
+    "scid": "6af3bf02-391a-493a-80d8-8e5f486fc134",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00880",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679098,
+    "monitored": true,
+    "name": "FRA-POZ-LAG",
+    "scid": "6af67d7b-2679-4a4f-8a35-1e269d99a0d2",
+    "service_type": "ETHERNET",
+    "sid": "GA-01814",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/0/0"
+      }
+    ],
+    "imsid": 669538,
+    "monitored": true,
+    "name": "SWITCH GN+ LL",
+    "scid": "6b5cde4a-913b-430d-bde1-2b25f2a59ee4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01541",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 745426,
+    "monitored": true,
+    "name": "ATHENS 2-ATHENS 2-LAG-007(GEANT)",
+    "scid": "6b8eb11d-8f4e-4274-ab25-92cf4cfcf716",
+    "service_type": "ETHERNET",
+    "sid": "GA-50008",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AARNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.2100"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-1/3/0.2100"
+      }
+    ],
+    "imsid": 709856,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-AARNET-NETHERLIGHT-21003",
+    "scid": "6bb16906-92b6-4759-bfdf-dfd8cd13ea69",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00284",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 744126,
+    "monitored": true,
+    "name": "AMS-BRU-LAG",
+    "scid": "6bea6346-0268-4340-b8a9-2e0164fe3693",
+    "service_type": "ETHERNET",
+    "sid": "GA-01792",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708178,
+    "monitored": false,
+    "name": "PS-FRA-DE-PSMP1-BWCTL",
+    "scid": "6c318b37-3900-49b8-ab90-a810fd1109cf",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00301",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "MAEEN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.3611"
+      }
+    ],
+    "imsid": 734556,
+    "monitored": true,
+    "name": "NL-MAEEN",
+    "scid": "6c3ef5a8-88db-4ca9-816f-7db8cef58c3f",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00898",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [],
+    "imsid": 661440,
+    "monitored": true,
+    "name": "ARNES-AP3-IAS",
+    "scid": "6c4d70af-59dc-4550-ae48-f0e7c5b45f98",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00554",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 713232,
+    "monitored": true,
+    "name": "BUC-CHI-40G-LAG",
+    "scid": "6c72cf16-2075-4f74-861e-cd1ccca61a8e",
+    "service_type": "ETHERNET",
+    "sid": "GA-92003",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SANET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.30/31",
+          "2001:798:99:1::4d/126"
+        ],
+        "hostname": "rt2.bra.sk.geant.net",
+        "interface": "ae13.421"
+      }
+    ],
+    "imsid": 733192,
+    "monitored": false,
+    "name": "SANET-AP2-IAS",
+    "scid": "6c9a1a4a-6c54-4463-8a6c-47165bdca719",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-02439",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "equipment": "GEN01-GRV8",
+        "port": "1/1/3"
+      },
+      {
+        "equipment": "MAD01-GRV3",
+        "port": "1/1/3"
+      }
+    ],
+    "imsid": 724593,
+    "monitored": true,
+    "name": "GEN1-MAD-LHC-CERN-REDIRIS-22044",
+    "scid": "6c9d1c63-e115-4f3a-b96a-944bbfaecdf0",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02120",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [],
+    "imsid": 712369,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-DFN-2-DE",
+    "scid": "6cc287b3-07f4-42e3-873f-1e2b89e43647",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01016",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.buc.ro.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 744990,
+    "monitored": true,
+    "name": "BUC-SOF-LAG",
+    "scid": "6ccc732d-8370-4a9f-b105-7eb10c45ae42",
+    "service_type": "ETHERNET",
+    "sid": "GA-01935",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ham_ham-WP6-GTS_21009",
+    "scid": "6d1278d0-5fc2-4a9b-b410-2008c205630c",
+    "service_type": null,
+    "sid": "DS-53415",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-21"
+      }
+    ],
+    "imsid": 745466,
+    "monitored": true,
+    "name": "CYNET-AP2-LAG",
+    "scid": "6d6681ae-2b43-491c-9f38-15fe3b9cfbe8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01928",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ge-0/2/7"
+      }
+    ],
+    "imsid": 659096,
+    "monitored": true,
+    "name": "PARIS-GTS-BMS-1GBE-007(ETH)",
+    "scid": "6d6c0e5b-cce5-4a06-a958-58c56841eed7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01401",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "AZSCIENCENET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-11/3/2"
+      }
+    ],
+    "imsid": 731782,
+    "monitored": true,
+    "name": "AZSCIENCENET-EAP-FRA-LL-1",
+    "scid": "6d852f81-dfd6-4b79-9332-16264e04340d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01651",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-11/1/2"
+      }
+    ],
+    "imsid": 658812,
+    "monitored": true,
+    "name": "LON-DTN-100G-LL",
+    "scid": "6d858a1b-6f3e-43d1-9c9a-49247378018c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01465",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RASH"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.228/31",
+          "2001:798:1::119/126"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae16.333"
+      }
+    ],
+    "imsid": 727802,
+    "monitored": true,
+    "name": "RASH-AP1-100G-IAS",
+    "scid": "6da6ec52-667e-42fa-8261-68cfc344c962",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-02326",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MARWAN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.32/31",
+          "2001:798:99:1::65/126"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae15.100"
+      }
+    ],
+    "imsid": 733897,
+    "monitored": true,
+    "name": "UK-MARWAN",
+    "scid": "6db55316-2135-41cb-978d-da6d0fdc0b41",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02406",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 659070,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-066(ETH)",
+    "scid": "6dd99a9f-fbdf-4aee-938a-b06c29034879",
+    "service_type": "ETHERNET",
+    "sid": "GA-01311",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 709476,
+    "monitored": true,
+    "name": "LAG-SW2.MIL2.IT_AE1",
+    "scid": "6ddb3ba8-f174-4b51-a733-d90630fa2ffe",
+    "service_type": "ETHERNET",
+    "sid": "GA-01778",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [],
+    "imsid": 718310,
+    "monitored": true,
+    "name": "CESNET-SECTEST-EXPRESSROUTE-VLAN409",
+    "scid": "6de70aac-9277-41fb-9120-10249d535071",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02094",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661292,
+    "monitored": false,
+    "name": "JUNOSSPACE-R720-DRAC-PAR-FR",
+    "scid": "6e07311d-cc1f-4b98-b02b-253329865a7e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00213",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "MANLAN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.32"
+      }
+    ],
+    "imsid": 714830,
+    "monitored": true,
+    "name": "FR-MANLAN",
+    "scid": "6e145dd9-0a78-4671-87f9-3e88ea444b47",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00461",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662259,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10GBE-004(GEANT)",
+    "scid": "6e408592-9d20-458f-9847-8c266741f7cf",
+    "service_type": "ETHERNET",
+    "sid": "GA-01632",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.POZ.PL.GEANT.NET",
+        "port": "XE-0"
+      },
+      {
+        "equipment": "PF1-RARE.BUD.HU.GEANT.NET",
+        "port": "XE-0"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-3/0/0.0"
+      },
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "xe-3/0/0.0"
+      }
+    ],
+    "imsid": 708292,
+    "monitored": false,
+    "name": "BUD-POZ-RARE-P4-9951383",
+    "scid": "6e43746b-e4ef-48a0-a5fe-873d39990fcb",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00685",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 746303,
+    "monitored": true,
+    "name": "RIG-TAR-LAG",
+    "scid": "6e4cf35f-373b-4439-921f-6414db862910",
+    "service_type": "ETHERNET",
+    "sid": "GA-02346",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679318,
+    "monitored": false,
+    "name": "NE-ESXI-TNMS-PAR-FR",
+    "scid": "6e896bb5-2114-45a4-a18a-926270d0893f",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00254",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FACEBOOK"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "103.4.98.177/31",
+          "2620:0:1cff:dead:beee::2d9/127"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae14.0"
+      }
+    ],
+    "imsid": 738664,
+    "monitored": true,
+    "name": "FACEBOOK-32934-VIE-FC-203126784",
+    "scid": "6e9f65f0-8eda-4584-b1f5-4fc0372a50dc",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00929",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.0/31",
+          "2001:798::d/126"
+        ],
+        "hostname": "mx1.pra.cz.geant.net",
+        "interface": "ae11.667"
+      }
+    ],
+    "imsid": 661548,
+    "monitored": true,
+    "name": "CESNET-AP1-CLS",
+    "scid": "6eb025b1-ba2a-4111-9c39-2a0b351f9f8a",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00600",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 712404,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-BELNET-1-BE",
+    "scid": "6ed4db26-c0c8-4882-b803-615b5406f8ce",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01033",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "\"PHY PRIVATE DIMENSION_DATA P_ae19",
+    "scid": "6efbbb44-9b0c-4fe4-8bd5-4a9777d20a4e",
+    "service_type": null,
+    "sid": "DS-42349",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae11"
+      }
+    ],
+    "imsid": 659321,
+    "monitored": true,
+    "name": "SURF-AP2-LAG",
+    "scid": "6f08b236-07c9-423b-9a9b-eb3177d4306c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01844",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/3/2"
+      }
+    ],
+    "imsid": 662850,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-080(GEANT)",
+    "scid": "6f0ff73d-dec6-4953-b0ea-6f51e4fb9659",
+    "service_type": "ETHERNET",
+    "sid": "GA-01654",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ams-lon_EXPReS_JANET-NetherLight_07011",
+    "scid": "6f35e01d-6089-4570-86a6-17e4f8a70ef8",
+    "service_type": null,
+    "sid": "GS-00643",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 746135,
+    "monitored": true,
+    "name": "KAU-KAU-MGMT-IPTRUNK",
+    "scid": "6f5860fe-60ae-4d9c-9149-beea902bfca1",
+    "service_type": "IP TRUNK",
+    "sid": "GS-50063",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663036,
+    "monitored": false,
+    "name": "PS-AMS-NL-MANAGEMENT-VLAN22",
+    "scid": "6f6f6281-2a2e-469f-baa5-006ead5f2895",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00287",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ge-0/2/6"
+      }
+    ],
+    "imsid": 658934,
+    "monitored": true,
+    "name": "PARIS-GTS-VPLS-1GBE-006(ETH)",
+    "scid": "6f8a081b-a5ab-49c3-9e86-021451120a32",
+    "service_type": "ETHERNET",
+    "sid": "GA-01411",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-5/2/2"
+      },
+      {
+        "addresses": [
+          "62.40.116.65/28"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-5/2/2.0"
+      }
+    ],
+    "imsid": 731223,
+    "monitored": false,
+    "name": "BENOCS-FRA",
+    "scid": "6fa906a9-70c7-4dce-aa67-87d62a544885",
+    "service_type": "SERVER LINK",
+    "sid": "GS-02434",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "193.203.0.172/23",
+          "2001:7f8:30:0:2:1:2:0965/64"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae10.0"
+      }
+    ],
+    "imsid": 708175,
+    "monitored": false,
+    "name": "IX-PEERINGS-IN-VIX",
+    "scid": "6faf5e62-7a01-4895-b6e6-80b9875dc35e",
+    "service_type": "IP PEERING - NON R&E (PUBLIC)",
+    "sid": "GS-00954",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-1/0/2"
+      }
+    ],
+    "imsid": 658500,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-018(ETH)",
+    "scid": "6fb629a8-4d52-45b1-84ec-578b62acd19b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01276",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.2706"
+      },
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.978"
+      }
+    ],
+    "imsid": 738289,
+    "monitored": false,
+    "name": "PSNC-REDIRIS-SLICES-UC3M",
+    "scid": "6fb81e8f-326f-4e21-93a4-bf20e6173572",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02492",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 727205,
+    "monitored": true,
+    "name": "BRUSSELS-BRUSSELS-10GBE-005(GEANT)",
+    "scid": "6fc34be3-eec5-44d9-a8bd-d5b9b1f3da96",
+    "service_type": "ETHERNET",
+    "sid": "GA-01358",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/0/6"
+      }
+    ],
+    "imsid": 727941,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-10GBE-016(GEANT)",
+    "scid": "6fcea088-b97d-481e-a88f-901cbcc88a33",
+    "service_type": "ETHERNET",
+    "sid": "GA-02134",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ULAKBIM"
+    ],
+    "endpoints": [],
+    "imsid": 709645,
+    "monitored": false,
+    "name": "ULAKBIM-GN-PRACE-VPN-PROXY-FRANKFURT-L3VPN",
+    "scid": "6fd3d4c3-4b0d-41bd-b747-1a907fe19986",
+    "service_type": "MD-VPN (PROXY)",
+    "sid": "GS-01072",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NETHERLIGHT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/1/5.0"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/1/2"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/1/2.0"
+      }
+    ],
+    "imsid": 711990,
+    "monitored": true,
+    "name": "AMS-LON-LOFAR-NETHERLIGHT-JISC-10007",
+    "scid": "6fd3e24b-1563-43d0-b929-7d13bada800d",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00783",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [],
+    "imsid": 719124,
+    "monitored": true,
+    "name": "BIL-FRA-ORACLE-REDIRIS-21051-VL683",
+    "scid": "70057baf-e7f9-451f-a631-f0a116b386c7",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00701",
+    "speed": 343597383680,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SUNET"
+    ],
+    "endpoints": [],
+    "imsid": 712408,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-SUNET-SE",
+    "scid": "701c8625-068e-4137-990e-3d6effa908e0",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01031",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30"
+      }
+    ],
+    "imsid": 712106,
+    "monitored": true,
+    "name": "LAG-QFX.PAR.FR_AE0",
+    "scid": "703b22e7-650c-4faf-870d-a2dbfc8ac7ba",
+    "service_type": "ETHERNET",
+    "sid": "GA-01815",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ams-mad_I2CAT_NetherLight-RedIRIS_12015",
+    "scid": "703dbb67-7871-4347-8b7c-56a86656043c",
+    "service_type": null,
+    "sid": "DS-28662",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PRO-M/NIIF"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae18"
+      }
+    ],
+    "imsid": 734844,
+    "monitored": true,
+    "name": "KIFU-AP2-LAG",
+    "scid": "7043c23f-9b5e-40e5-901b-f2d1dc86e92a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01861",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [],
+    "imsid": 669626,
+    "monitored": false,
+    "name": "GEN2-LON-EEX-ESNET-1426",
+    "scid": "7049c48b-3fac-470b-82ec-adee6ec57aa1",
+    "service_type": "GEANT LAMBDA",
+    "sid": "GS-00796",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661258,
+    "monitored": false,
+    "name": "RARE-P4-B1-POZ",
+    "scid": "707237a6-3ba5-4e2d-bd6d-081cdcae760d",
+    "service_type": "L2SERVICES",
+    "sid": "GS-00772",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [],
+    "imsid": 719498,
+    "monitored": false,
+    "name": "BRU-MAD-OFELIA-BELNET-REDIRIS-14001",
+    "scid": "70c923e6-4cfa-46ad-9835-c04b7b3b77e5",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00679",
+    "speed": 332859965440,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.32/31",
+          "2001:798:111:1::c9/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.2016"
+      }
+    ],
+    "imsid": 736738,
+    "monitored": true,
+    "name": "REDCLARA-PAR-LHCONE-2",
+    "scid": "70f0b140-7251-4f96-a1f9-a09d80188074",
+    "service_type": "L3-VPN",
+    "sid": "GS-00846",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ams.nl.geant.net",
+        "interface": "lag-5"
+      }
+    ],
+    "imsid": 735410,
+    "monitored": true,
+    "name": "AMS-AMS-800G-LAG",
+    "scid": "7123cd23-2ba5-4435-b925-a18747a02814",
+    "service_type": "ETHERNET",
+    "sid": "GA-02457",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.241/30",
+          "2001:798:1::101/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-20.333"
+      }
+    ],
+    "imsid": 744956,
+    "monitored": true,
+    "name": "BREN-AP1-IAS",
+    "scid": "7184a87b-7085-47a1-94c2-3167fe29e79b",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00557",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659011,
+    "monitored": true,
+    "name": "FR-ORANGE-LL #2",
+    "scid": "71ac286b-0ab4-422e-b432-f29d86190158",
+    "service_type": "ETHERNET",
+    "sid": "GA-01383",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663081,
+    "monitored": false,
+    "name": "GEN-GROOVE-3",
+    "scid": "71c3b10b-8923-4912-b7b5-0c9535ded4a7",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00185",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.41/31",
+          "2001:798:cc::56/126"
+        ],
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-1.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.40/31",
+          "2001:798:cc::55/126"
+        ],
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-1.0"
+      }
+    ],
+    "imsid": 745464,
+    "monitored": true,
+    "name": "ATH2-THE-IPTRUNK",
+    "scid": "71dce15d-317c-4308-99c2-844a42f0c03e",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02421",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661498,
+    "monitored": false,
+    "name": "OCVM-LON-UK-ILO",
+    "scid": "71f62723-3632-4fd6-ae89-c34e39b16ae5",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00139",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.79/31",
+          "2001:798:cc::86/126"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae7.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.78/31",
+          "2001:798:cc::85/126"
+        ],
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-7.0"
+      }
+    ],
+    "imsid": 740951,
+    "monitored": true,
+    "name": "MIL2-MIL2-IPTRUNK",
+    "scid": "720815cb-ce30-4b4e-9818-208222110af9",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02548",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.14/31"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "et-11/3/0.111"
+      }
+    ],
+    "imsid": 724437,
+    "monitored": false,
+    "name": "DTN-PAR-100G-DATA-LHCONE",
+    "scid": "720dfded-cc6b-4e48-a329-f9e3c74f840c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-99999",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663200,
+    "monitored": false,
+    "name": "IPCAMERA-GEN-CH",
+    "scid": "72221a06-f2fa-4827-9a41-4194c5900b82",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00210",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PSMP-GN-DRAC-POZ-PL.GEANT.ORG",
+        "port": "10GE-2"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-3/2/1"
+      },
+      {
+        "addresses": [
+          "62.40.114.100/31",
+          "2001:798:bb:2::a9/126"
+        ],
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-3/2/1.0"
+      }
+    ],
+    "imsid": 708161,
+    "monitored": false,
+    "name": "PS-POZ-PL-BWCTL",
+    "scid": "7225c180-29aa-4e88-8111-585c18f87ed0",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00343",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658517,
+    "monitored": false,
+    "name": "730XD-3-VSAN-TRAFFIC-LAG-PAR",
+    "scid": "7228a3ba-c6e8-459d-862c-7d1e87214d39",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01719",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [],
+    "imsid": 717188,
+    "monitored": true,
+    "name": "JISC-AP2-LL3",
+    "scid": "7273bcca-a5cf-4948-b843-71e9554f5a84",
+    "service_type": "ETHERNET",
+    "sid": "GA-01671",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "HBKU"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/2"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/2.1"
+      }
+    ],
+    "imsid": 669142,
+    "monitored": true,
+    "name": "HBKU-GEO-UK-1-LL",
+    "scid": "72773e5b-763d-4f3f-8e60-4575b36f087a",
+    "service_type": "CBL1",
+    "sid": "GA-01458",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.105/30",
+          "2001:798:1::81/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-23.333"
+      }
+    ],
+    "imsid": 747955,
+    "monitored": false,
+    "name": "MARNET-AP2-IAS",
+    "scid": "72952176-9420-446b-8894-b079d5dc74ff",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00537",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.976"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-224046"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-20:713"
+      }
+    ],
+    "imsid": 745414,
+    "monitored": true,
+    "name": "SLCUTH-02498",
+    "scid": "72a1f92b-2bee-442f-901f-f81453ff37fc",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02498",
+    "speed": 493921239040,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 728950,
+    "monitored": true,
+    "name": "TAR-TAR-IPTRUNK",
+    "scid": "72bf1da5-dfe8-4463-940f-cc04869fbffd",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02351",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 658678,
+    "monitored": false,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-056(GEANT)",
+    "scid": "72c6493f-90b6-4619-946f-e59b46d869e8",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01674",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.32"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-124032"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4083"
+      }
+    ],
+    "imsid": 744238,
+    "monitored": true,
+    "name": "MSETHOMASMORE-02475",
+    "scid": "72e24bdb-782b-4fb0-a15d-33d0b1a6011c",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02475",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3.1035"
+      }
+    ],
+    "imsid": 661969,
+    "monitored": true,
+    "name": "SDN-BOD-BR53-OF-11-HOST-H-ETH4",
+    "scid": "72e7a073-2195-4d38-ba4e-9fd6342f56f7",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00755",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [],
+    "imsid": 742907,
+    "monitored": false,
+    "name": "GRNET-AP2-COPERNICUS",
+    "scid": "72faa69b-27f4-4b21-af00-2fc8c6302fbb",
+    "service_type": "L3-VPN",
+    "sid": "GS-00829",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae6"
+      }
+    ],
+    "imsid": 744976,
+    "monitored": true,
+    "name": "LIS-PAR-LAG",
+    "scid": "731660e9-1e8b-4b0e-84fb-889015fb1020",
+    "service_type": "ETHERNET",
+    "sid": "GA-02634",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ge-0/1/1"
+      }
+    ],
+    "imsid": 740536,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-1GBE-003(GEANT)",
+    "scid": "7335cfb2-1b8d-4b70-a35b-9bbd2f3bfc02",
+    "service_type": "ETHERNET",
+    "sid": "GA-01510",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.36/31",
+          "2001:798::41/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.667"
+      }
+    ],
+    "imsid": 661289,
+    "monitored": true,
+    "name": "RENATER-AP1-CLS",
+    "scid": "7351a9d7-f6b3-4492-92c8-d496824e3efb",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00618",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 717034,
+    "monitored": true,
+    "name": "LAG-MX2.BRA.SK_AE1",
+    "scid": "736304fa-de8f-433a-827a-bc4719a92e40",
+    "service_type": "ETHERNET",
+    "sid": "GA-02069",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae11"
+      }
+    ],
+    "imsid": 724970,
+    "monitored": true,
+    "name": "CESNET-AP1-LAG",
+    "scid": "737bd449-f9f5-49bf-9368-45a5e85623cd",
+    "service_type": "ETHERNET",
+    "sid": "GA-01829",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.146/31",
+          "2001:798:99:1::32/127"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae14.161"
+      }
+    ],
+    "imsid": 662958,
+    "monitored": true,
+    "name": "RENATER-RTBH-GENEVA",
+    "scid": "738bfc76-896a-491b-a4fd-f76dab21920d",
+    "service_type": "GEANT IP",
+    "sid": "GS-00504",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.237/30",
+          "2001:798:2c:10aa::1/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-22.100"
+      }
+    ],
+    "imsid": 744954,
+    "monitored": true,
+    "name": "MARNET-AP1",
+    "scid": "739c70df-82c4-4216-9a50-5390c0db8575",
+    "service_type": "GEANT IP",
+    "sid": "GS-00489",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679174,
+    "monitored": false,
+    "name": "NE-ESXI-FRA-DE-TNMS-VLAN10",
+    "scid": "73c8cf2d-715f-4c04-b529-9ae898c4520e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00256",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 719314,
+    "monitored": false,
+    "name": "BELNET-GCLOUD-EXPRESSROUTE-VLAN4087",
+    "scid": "73eb5bce-bfc1-4938-a8e6-d15658cb793e",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02160",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "UOM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.72/31",
+          "2001:798:99:1::111/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae19.100"
+      }
+    ],
+    "imsid": 720396,
+    "monitored": true,
+    "name": "UOM-AP2-100G",
+    "scid": "74016d70-cf1f-496a-ac93-cd1feb2df4f1",
+    "service_type": "GEANT IP",
+    "sid": "GS-02164",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.212/31",
+          "2001:798:1::19d/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae27.0"
+      }
+    ],
+    "imsid": 708328,
+    "monitored": true,
+    "name": "AKAMAI-20940-AT",
+    "scid": "74366bdf-758d-43e7-b872-bbd58ef08ac8",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00926",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HARNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.2242"
+      }
+    ],
+    "imsid": 740586,
+    "monitored": true,
+    "name": "NL-HARNET",
+    "scid": "746f621a-f876-44a7-9dde-2d7cc8048ce8",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02539",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 741126,
+    "monitored": true,
+    "name": "BRU-BRU-MGMT-LAG",
+    "scid": "7485a604-ce14-4366-a508-9217970f787f",
+    "service_type": "ETHERNET",
+    "sid": "GA-02569",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae31"
+      }
+    ],
+    "imsid": 732183,
+    "monitored": true,
+    "name": "MICROSOFT-EXPRESSROUTE-FRA-LAG2",
+    "scid": "749085e3-6229-4e49-8d0c-3a3c3e872765",
+    "service_type": "ETHERNET",
+    "sid": "GA-01963",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SUNET"
+    ],
+    "endpoints": [],
+    "imsid": 716308,
+    "monitored": true,
+    "name": "MD-VPN-VRR-PARIS 007B-SUNET-2-SE",
+    "scid": "74a5c1a1-3242-4108-a2be-14b3679b52cb",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01067",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661918,
+    "monitored": false,
+    "name": "PRA-GROOVE-2",
+    "scid": "74ac4be7-a871-4033-a134-b4a5633203a3",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00281",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662352,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10GBE-020(GEANT)",
+    "scid": "74b4fb1a-100a-4483-9535-621c4931f432",
+    "service_type": "ETHERNET",
+    "sid": "GA-01570",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 715109,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-10GBE-017(GEANT)",
+    "scid": "74ea1124-36a4-4f67-a112-727219e54238",
+    "service_type": "ETHERNET",
+    "sid": "GA-01551",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:3913"
+      }
+    ],
+    "imsid": 747629,
+    "monitored": true,
+    "name": "AMS-HAM-MSE-01154",
+    "scid": "74f08b13-cef5-404f-9e9d-d20a0ae93159",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-01154",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743128,
+    "monitored": true,
+    "name": "RIG-RIG-MGMT-LAG",
+    "scid": "74fa1aac-8d62-4a8a-a1e7-0a496b4a5d28",
+    "service_type": "ETHERNET",
+    "sid": "GA-02610",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "xe-5/0/0"
+      }
+    ],
+    "imsid": 738244,
+    "monitored": true,
+    "name": "ARELION-RENAM-GWS-LL",
+    "scid": "7548ce69-f9c1-4f23-81c7-ee465eb3997c",
+    "service_type": "ETHERNET",
+    "sid": "GA-02111",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae12"
+      }
+    ],
+    "imsid": 730091,
+    "monitored": true,
+    "name": "CARNET AP2-LAG",
+    "scid": "7564273b-1cd7-4903-827a-221a9ad786cf",
+    "service_type": "ETHERNET",
+    "sid": "GA-01739",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "URAN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.46/31",
+          "2001:798:111:1::d9/126"
+        ],
+        "hostname": "rt1.kie.ua.geant.net",
+        "interface": "ae10.360"
+      }
+    ],
+    "imsid": 714002,
+    "monitored": true,
+    "name": "URAN-AP1-LHCONE",
+    "scid": "757a54ac-3f3f-45da-ac14-1382d6763b1e",
+    "service_type": "L3-VPN",
+    "sid": "GS-00870",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT-IT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "xe-0/0/17"
+      },
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "xe-0/0/41"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-5/0/0.0"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/1/3.0"
+      }
+    ],
+    "imsid": 729477,
+    "monitored": true,
+    "name": "FRA-PAR-SUPERPOP-QFX-GEANT",
+    "scid": "758b1445-4391-4bff-813a-6938f2b97c95",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00078",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732404,
+    "monitored": true,
+    "name": "A10-DDOS-SCRUBBING-FRA-CLEAN-TRAFFIC-LAG",
+    "scid": "75b4e995-3595-43ce-b395-b3ef88c593f1",
+    "service_type": "ETHERNET",
+    "sid": "GA-01954",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "CESNET-GN-PRACE-VPN-Proxy-Prague-L3VPN",
+    "scid": "75c22339-119a-49c4-9b1f-3285a16252ce",
+    "service_type": null,
+    "sid": "GS-01061",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659189,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-1GBE-013(ETH)",
+    "scid": "75dfb7fd-7c3e-4088-a299-f1b22a9e63d1",
+    "service_type": "ETHERNET",
+    "sid": "GA-01439",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-2/0/0"
+      }
+    ],
+    "imsid": 658592,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-025(ETH)",
+    "scid": "75e31b91-b7ca-4ceb-96f0-356a273febdf",
+    "service_type": "ETHERNET",
+    "sid": "GA-01267",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658681,
+    "monitored": false,
+    "name": "LON2-PRD-ESX10-VSAN-LAG",
+    "scid": "75ea1b3b-197e-452e-96e5-ba79d2f20ad8",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01711",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [],
+    "imsid": 709726,
+    "monitored": false,
+    "name": "GEN2-LON-EEX-ESNET-2105",
+    "scid": "75fb8efa-0c75-4d59-a552-3273911fa200",
+    "service_type": "GEANT LAMBDA",
+    "sid": "GS-00797",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NETHERLIGHT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.3001"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.3001"
+      }
+    ],
+    "imsid": 736886,
+    "monitored": true,
+    "name": "LON-PAR-GEANTOPEN-NETHERLIGHT-QNREN-15032",
+    "scid": "7621166e-7d9b-4218-a0a2-a6bf198901f9",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00972",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.lis.pt - LIS-LON Multicast Traffic",
+    "scid": "76620bc1-1acb-4061-b4db-e9e64432b870",
+    "service_type": null,
+    "sid": "DS-13989",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ge-0/3/2"
+      }
+    ],
+    "imsid": 718799,
+    "monitored": true,
+    "name": "LONDON-LONDON-1GBE-002(GEANT)",
+    "scid": "766430a3-9ce2-4fa4-a67e-14013d737559",
+    "service_type": "ETHERNET",
+    "sid": "GA-01470",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732398,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-004(GEANT)",
+    "scid": "766b47e0-d1f9-4f65-8090-133a8daee4fb",
+    "service_type": "ETHERNET",
+    "sid": "GA-01617",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 709341,
+    "monitored": true,
+    "name": "KAU-KAU-IPTRUNK",
+    "scid": "768f6bce-1353-4a43-9794-fe0b6dc32a2c",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00042",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/3.203"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae13.203"
+      }
+    ],
+    "imsid": 721429,
+    "monitored": false,
+    "name": "PAR-PAR-SCION-SWITCH",
+    "scid": "769a1057-0d9a-4498-93a5-7e1be6d01f32",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02209",
+    "speed": 225485783040,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PSMP-GN-DRAC-LON2-UK.GEANT.ORG",
+        "port": "0-4"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/3/2.904"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.904"
+      }
+    ],
+    "imsid": 709300,
+    "monitored": true,
+    "name": "LON-LON2-MISC-GEANT-INTERNET2-9940525",
+    "scid": "76af9188-2250-4d65-911d-b88232992178",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00732",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.101/31",
+          "2001:798:cc::9a/126"
+        ],
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-5.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.100/31",
+          "2001:798:cc::99/126"
+        ],
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-5.0"
+      }
+    ],
+    "imsid": 745270,
+    "monitored": true,
+    "name": "MIL2-THE-IPTRUNK",
+    "scid": "76f20bf6-8554-4e0f-8f86-f02139d41841",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02609",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 735852,
+    "monitored": true,
+    "name": "LON2-LON2-10G-LINK1",
+    "scid": "76f45259-5cab-42a0-be06-d7e8cf8727dc",
+    "service_type": "ETHERNET",
+    "sid": "GA-01314",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae20"
+      }
+    ],
+    "imsid": 662487,
+    "monitored": true,
+    "name": "FRA-DE-CIX-LAG",
+    "scid": "76f816fc-aa96-496c-b5ad-cba93e6b0129",
+    "service_type": "ETHERNET",
+    "sid": "GA-01956",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 727986,
+    "monitored": true,
+    "name": "TARTU-TARTU-LAG-002(GEANT)",
+    "scid": "76fcb919-112d-4682-916e-bf6a8a24c310",
+    "service_type": "ETHERNET",
+    "sid": "GA-02055",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658437,
+    "monitored": false,
+    "name": "730XD-1-SLOT0-PORT1-VMNIC0-PAR",
+    "scid": "7716f6a0-2fc7-46e2-94a1-e9034a95cc46",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01290",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 712524,
+    "monitored": true,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-005(GEANT)",
+    "scid": "773566fc-7b07-45fa-b67d-7d87d8a7e930",
+    "service_type": "ETHERNET",
+    "sid": "GA-02065",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4073"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-125023"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.45"
+      }
+    ],
+    "imsid": 747544,
+    "monitored": false,
+    "name": "MSECREDENDO-02654",
+    "scid": "77371b44-1826-445b-944c-2641a042c66e",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02654",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "1/1/c2/3"
+      }
+    ],
+    "imsid": 747578,
+    "monitored": true,
+    "name": "HAM-DTN-IP1",
+    "scid": "776c933d-84f9-47f1-a566-44c0969a3dd5",
+    "service_type": "ETHERNET",
+    "sid": "GA-02286",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ACONET"
+    ],
+    "endpoints": [],
+    "imsid": 661509,
+    "monitored": true,
+    "name": "ACONET-AP2-EUMETCAST",
+    "scid": "77776106-932e-420f-9320-5301acc13ebc",
+    "service_type": "GEANT IP",
+    "sid": "GS-00424",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FACEBOOK"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae47"
+      }
+    ],
+    "imsid": 737787,
+    "monitored": true,
+    "name": "FACEBOOK-FRA-LAG-2",
+    "scid": "777ed6fa-60a3-40e0-9302-279d2a797746",
+    "service_type": "ETHERNET",
+    "sid": "GA-02482",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [],
+    "imsid": 669625,
+    "monitored": false,
+    "name": "AMS-GEN-EEX-ESNET-1425",
+    "scid": "77b54ec7-3c78-47c6-b843-b22a8acdd90d",
+    "service_type": "GEANT LAMBDA",
+    "sid": "GS-00778",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.poz.pl.geant.net",
+        "interface": "lag-6"
+      }
+    ],
+    "imsid": 746516,
+    "monitored": true,
+    "name": "KAU-POZ-LAG",
+    "scid": "77c38cd3-f042-4275-acc1-e640419ab8bf",
+    "service_type": "ETHERNET",
+    "sid": "GA-01812",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/1/5"
+      }
+    ],
+    "imsid": 733210,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-029(GEANT)",
+    "scid": "77cfebb2-a92a-4fcd-9efe-235d9e9065f7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01332",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661881,
+    "monitored": false,
+    "name": "LON-GROOVE-1-MANAGEMENT",
+    "scid": "77e31ca9-a387-4934-a497-1bb1a5a665f3",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00229",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [],
+    "imsid": 733112,
+    "monitored": false,
+    "name": "FRA-GEN-CERN-DFN-4",
+    "scid": "77e7fdcd-7b81-439d-b366-0fe8d5f4d9ab",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02446",
+    "speed": 536870912000,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 739435,
+    "monitored": true,
+    "name": "PAR-PAR-800G-LAG",
+    "scid": "784ab6cf-9efb-4dec-94f7-231c3a2cc04f",
+    "service_type": "ETHERNET",
+    "sid": "GA-02471",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PSMP-GN-DRAC-VIE-AT.GEANT.ORG",
+        "port": "10GE-1"
+      },
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "xe-11/0/1"
+      },
+      {
+        "addresses": [
+          "62.40.114.34/31",
+          "2001:798:bb:2::39/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "xe-11/0/1.0"
+      }
+    ],
+    "imsid": 661769,
+    "monitored": false,
+    "name": "PS-VIE-AT-MANAGEMENT",
+    "scid": "7896eeff-f28a-43c6-b996-2c0a2ca6589a",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00357",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/3.1303"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.1303"
+      }
+    ],
+    "imsid": 727383,
+    "monitored": true,
+    "name": "AMS-PAR-SCION-KREONET-SWITCH",
+    "scid": "789c62ae-17a7-4884-b568-0921e5c638d1",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02291",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707222,
+    "monitored": false,
+    "name": "PRA-GROOVE",
+    "scid": "78bd5147-7f53-4cdb-8d34-2b489bc00453",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00278",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 712092,
+    "monitored": false,
+    "name": "HA-3D08FA5333",
+    "scid": "792c63e1-34a5-4f56-b20c-4ed6c10d049b",
+    "service_type": "GTS",
+    "sid": "GS-01174",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663048,
+    "monitored": false,
+    "name": "PS-DUB2-IE-IDRAC-VLAN23",
+    "scid": "794891b4-c231-4c7f-ba4f-a2f0c421f615",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00297",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 728875,
+    "monitored": true,
+    "name": "BRATISLAVA-BRATISLAVA-LAG-002(GEANT)",
+    "scid": "797b1a41-d2cf-4fc2-a406-6c0fdbbe151c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01754",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PSMP-GN-DRAC-PAR-FR.GEANT.ORG",
+        "port": "10GE-2"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/2/7.908"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.908"
+      }
+    ],
+    "imsid": 705419,
+    "monitored": false,
+    "name": "AMS-PAR-MISC-GEANT-INTERNET2-9940543",
+    "scid": "799fd4a7-a656-43b1-9617-7ede82be5456",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00654",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "CESNET-AMS-IX 07021 1GE",
+    "scid": "79a2b749-6cbf-440c-ba20-8a20d0d6935c",
+    "service_type": null,
+    "sid": "DS-13265",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 734321,
+    "monitored": true,
+    "name": "THE-THE-LAG",
+    "scid": "79b8ced7-4635-47b3-9d85-731b8cd6e229",
+    "service_type": "ETHERNET",
+    "sid": "GA-02429",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ASNET-AM"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae17"
+      }
+    ],
+    "imsid": 732121,
+    "monitored": true,
+    "name": "ASNET-AM-FRA-LAG",
+    "scid": "79f6436e-0b9d-4cd7-a886-b63a2d5fb3ec",
+    "service_type": "ETHERNET",
+    "sid": "GA-01953",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae21"
+      }
+    ],
+    "imsid": 701605,
+    "monitored": true,
+    "name": "CERN-LHCONE-LAG#1",
+    "scid": "79fc266a-7cc1-4be6-abf0-45f6332ae4d4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01876",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.245/30",
+          "2001:798:1::39/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae11.333"
+      }
+    ],
+    "imsid": 743293,
+    "monitored": true,
+    "name": "DFN-AP1-IAS",
+    "scid": "7a260ace-c8dc-4aa9-871f-bb850f35476d",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00566",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-22"
+      }
+    ],
+    "imsid": 747785,
+    "monitored": true,
+    "name": "CARNET-AP1-LAG",
+    "scid": "7a528025-c883-4b84-8682-506beae8de8e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01865",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 743307,
+    "monitored": true,
+    "name": "JISC-AP2-LAG",
+    "scid": "7a72e854-71ee-4674-a11b-4fefb1451e99",
+    "service_type": "ETHERNET",
+    "sid": "GA-01760",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743167,
+    "monitored": true,
+    "name": "COR-COR-MGMT-LAG",
+    "scid": "7a7b34ba-5127-4e3a-8455-96cb5ccf7eeb",
+    "service_type": "ETHERNET",
+    "sid": "GA-02616",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [],
+    "imsid": 709009,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-NSOAS",
+    "scid": "7ae12882-a04c-45f4-a0ed-56e1b03c95fc",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01088",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.24.1/24"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae2.103"
+      }
+    ],
+    "imsid": 736086,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-AMS-NL",
+    "scid": "7ae8bd27-b3ef-42c4-8ba1-4fa84fa52076",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00115",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "MICROSOFT-LAG-1",
+    "scid": "7afb0afb-e1c6-4f1c-ae22-cb2f06fb4a4c",
+    "service_type": null,
+    "sid": "GA-01798",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SINGAREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "103.5.241.1/31",
+          "2401:c7c0:1:ffff::1/64"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/5.1000"
+      }
+    ],
+    "imsid": 661473,
+    "monitored": true,
+    "name": "UK-SINGAREN",
+    "scid": "7b155e69-a005-4e44-92f0-75e9fbb5f314",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00923",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663239,
+    "monitored": false,
+    "name": "KVMOIP-GEN-CH",
+    "scid": "7b24eac6-52f9-4746-b556-bfcea5c161fe",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00221",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.36"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4064"
+      }
+    ],
+    "imsid": 739666,
+    "monitored": true,
+    "name": "BELNET-MSER-ULB-EXPRESSROUTE-VLAN4064",
+    "scid": "7b596828-68b9-4f61-a528-86a41fa0e06e",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02364",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658672,
+    "monitored": false,
+    "name": "730XD-5-VSAN-TRAFFIC-LAG",
+    "scid": "7b7b5189-b528-4a5b-b8e7-8bd5db055dd5",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01688",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.2707"
+      },
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.954"
+      }
+    ],
+    "imsid": 739389,
+    "monitored": false,
+    "name": "PSNC-REDIRIS-SLICES-UPV/EHU",
+    "scid": "7b7c6053-e5aa-40d7-93a4-b6a460006d94",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02493",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 677778,
+    "monitored": false,
+    "name": "PRA OOB LINK",
+    "scid": "7b958e63-8d5e-45fb-ad02-60de254c7799",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00414",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658919,
+    "monitored": true,
+    "name": "ZAGREB-ZAGREB-1GBE-004(ETH)",
+    "scid": "7b9ecea1-76c7-4b9c-b137-67dac01774a0",
+    "service_type": "ETHERNET",
+    "sid": "GA-01493",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "CERN-GVA-ExpressRoute-Vlan496-Backup |",
+    "scid": "7bfb4e87-7889-42b2-af4f-d96604bd1f06",
+    "service_type": null,
+    "sid": "DS-53035",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae4"
+      }
+    ],
+    "imsid": 658522,
+    "monitored": false,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-063(GEANT)",
+    "scid": "7c17b242-19a2-46f9-a398-1c5f4601faf7",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01675",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "LIS-LON-IPTRUNK",
+    "scid": "7c5b783b-d0b0-40f7-9853-1d32a00adc06",
+    "service_type": null,
+    "sid": "DS-21969",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.242/31",
+          "2001:798:cc:1::cd/126"
+        ],
+        "hostname": "rt0.pra.cz.geant.net",
+        "interface": "lag-5.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.243/31",
+          "2001:798:cc:1::ce/126"
+        ],
+        "hostname": "rt0.vie.at.geant.net",
+        "interface": "lag-5.0"
+      }
+    ],
+    "imsid": 740751,
+    "monitored": true,
+    "name": "PRA-VIE-IPTRUNK",
+    "scid": "7c637317-27ad-4664-a891-07b87e18bf2b",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00059",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.3220"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3220"
+      }
+    ],
+    "imsid": 707007,
+    "monitored": true,
+    "name": "LON-POZ-GEANTOPEN-SINGAREN-CAE1-19113-VL3220-PIONIER",
+    "scid": "7c799a24-20a7-4f6b-8790-cfe023a70265",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00986",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 731189,
+    "monitored": false,
+    "name": "BUD-LJU-IPTRUNK",
+    "scid": "7c981d6b-2088-4829-92f0-a9c0b8f7e492",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00025",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "LIBNOVA-39743-DE",
+    "scid": "7ca61da3-b70a-4f35-a043-f9a26b3edf82",
+    "service_type": null,
+    "sid": "DS-53745",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/2.13"
+      }
+    ],
+    "imsid": 661561,
+    "monitored": false,
+    "name": "INFOBLOX-LON2-REPORTING-SERVER",
+    "scid": "7cc6392d-9e95-40fd-8113-2b7a2c9739b9",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00202",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "LON01-GRV4",
+        "port": "1/1/3"
+      }
+    ],
+    "imsid": 731736,
+    "monitored": true,
+    "name": "DUB-LON-NORDUNET-23005",
+    "scid": "7ceba7db-944a-4308-a3bd-6b8afd572c90",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02244",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "IUCC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.6/31",
+          "2001:798::11/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae21.667"
+      }
+    ],
+    "imsid": 661931,
+    "monitored": false,
+    "name": "IUCC-AP1-CLS",
+    "scid": "7d02a985-90f5-4691-83cb-240909f5e510",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00610",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 703117,
+    "monitored": true,
+    "name": "MAD-PAR-LAG",
+    "scid": "7d0caeb9-157d-42fb-93d5-dbff4ec9550e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01784",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae34.2282"
+      },
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "pwe-121097"
+      },
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-20:2282"
+      }
+    ],
+    "imsid": 747351,
+    "monitored": true,
+    "name": "HEANET-00630",
+    "scid": "7d1c5626-a05f-426e-9d37-21d2192a7467",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00630",
+    "speed": 0,
+    "status": "planned"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/2/3.370"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/1/3.370"
+      },
+      {
+        "addresses": [
+          "10.0.3.254/24"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "irb.370"
+      }
+    ],
+    "imsid": 723797,
+    "monitored": false,
+    "name": "SCION-SCION-GEN-INTERNAL-VPN-VL370",
+    "scid": "7d6a39ca-0ca5-4440-8976-8e8213974c7f",
+    "service_type": "L3-VPN",
+    "sid": "GS-02214",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae10.1945"
+      },
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.2"
+      }
+    ],
+    "imsid": 707126,
+    "monitored": true,
+    "name": "FCCN-NOVESBE-EXPRESSROUTE-VLAN1945",
+    "scid": "7d6b2364-5249-48a4-9276-8bd63d76fb94",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01142",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 732184,
+    "monitored": true,
+    "name": "MICROSOFT-EXPRESSROUTE-FRA-LAG1",
+    "scid": "7d97dff1-2b69-4b59-9322-bec626fa48da",
+    "service_type": "ETHERNET",
+    "sid": "GA-01958",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.1391"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae13.50"
+      }
+    ],
+    "imsid": 714182,
+    "monitored": false,
+    "name": "PAR-PAR-GRID5000-RENATER-SWITCH-20026",
+    "scid": "7db186a5-68cc-4d34-bbe1-848a8b4e5a1f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00750",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/3"
+      }
+    ],
+    "imsid": 733206,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-026(GEANT)",
+    "scid": "7e2e07a7-374e-462b-8140-5ad184a71bfd",
+    "service_type": "ETHERNET",
+    "sid": "GA-01328",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661997,
+    "monitored": false,
+    "name": "JUNOSSPACE-R720-DATA-PAR-FR",
+    "scid": "7e3c075c-8f4c-4add-bbe2-e748fb11ebd5",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00212",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661989,
+    "monitored": false,
+    "name": "JUNOSSPACE-R720-ESXI-PAR-FR",
+    "scid": "7e5db039-efa8-484c-ab75-8b386d199a6f",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00214",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 717189,
+    "monitored": true,
+    "name": "AMS-PAR-LOFAR-RENATER-NETHERLIGHT-10001-LL2",
+    "scid": "7e694f40-ed0f-499f-b0fb-81f8bfcd1219",
+    "service_type": "ETHERNET",
+    "sid": "GA-01212",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 659420,
+    "monitored": true,
+    "name": "JISC-AP1-LAG",
+    "scid": "7e755e02-c2ab-4ce9-ab3a-62f115c30632",
+    "service_type": "ETHERNET",
+    "sid": "GA-01845",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [],
+    "imsid": 705897,
+    "monitored": false,
+    "name": "PAR-LON-INTERNET2-SWITCH-19117",
+    "scid": "7e8f5fd8-e1dd-4bec-96a7-88622197ada0",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00746",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae18"
+      }
+    ],
+    "imsid": 658657,
+    "monitored": false,
+    "name": "LON2-PRD-ESX12-VM-TRAFFIC",
+    "scid": "7ea43b05-0983-4b9b-b7cd-aea816792e0a",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01695",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708174,
+    "monitored": true,
+    "name": "BUDAPEST-BUDAPEST-ETHS-002(GEANT)",
+    "scid": "7ea4f007-e6b0-44c1-971c-c25e3c8d4585",
+    "service_type": "ETHERNET",
+    "sid": "GS-00295",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae21.121"
+      },
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae11.121"
+      }
+    ],
+    "imsid": 713980,
+    "monitored": true,
+    "name": "GEN-LIS-CERN-REDCLARA-21073",
+    "scid": "7ef74bbc-99fe-45ba-9225-81c59a2f8bca",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00710",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/1/6.2703"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae22.2703"
+      }
+    ],
+    "imsid": 737890,
+    "monitored": false,
+    "name": "FRA-LON-SCION-WACREN",
+    "scid": "7f01dc1e-40d1-46e8-93b4-09936fb7b1eb",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02496",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.fra.de.geant.net",
+        "interface": "lag-6"
+      }
+    ],
+    "imsid": 740464,
+    "monitored": true,
+    "name": "FRA-PRA-LAG",
+    "scid": "7f2fbdd3-4fc7-41fb-83f8-d0bd73a31373",
+    "service_type": "ETHERNET",
+    "sid": "GA-01944",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "109.105.102.98/30",
+          "2001:948:3:9::3/127"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.4001"
+      }
+    ],
+    "imsid": 660550,
+    "monitored": true,
+    "name": "UK-NORDUNET-IX-2603",
+    "scid": "7f3748e7-5b19-4335-8d0d-479fe054cb24",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00944",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/2"
+      },
+      {
+        "addresses": [
+          "62.40.106.146/31",
+          "2001:798:bb:2::59/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/2.0"
+      }
+    ],
+    "imsid": 708299,
+    "monitored": false,
+    "name": "PSMP-GN-MANAGEMENT-LON-UK-VLAN0",
+    "scid": "7f37a9cd-5b31-4271-a180-3597bbc505d8",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00358",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMT1.LON2.UK",
+        "port": "AE1.0"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae7.0"
+      }
+    ],
+    "imsid": 744437,
+    "monitored": true,
+    "name": "LON2-LON2-AMT-RELAYLINK",
+    "scid": "7f86c2cc-f2f9-4882-ba99-67a6cfc5a243",
+    "service_type": "SERVER LINK",
+    "sid": "GS-02304",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "UTIC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.140/31",
+          "2001:798:99:1::121/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae1.100"
+      }
+    ],
+    "imsid": 739336,
+    "monitored": true,
+    "name": "BUD-UTIC",
+    "scid": "7f87c2ff-d735-47da-b710-5b3bfcf5f6f7",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02232",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "OMREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.3333"
+      }
+    ],
+    "imsid": 734554,
+    "monitored": true,
+    "name": "NL-OMREN",
+    "scid": "7f8b26e4-e32f-495e-9c02-4d167fa77f16",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00900",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.9/30",
+          "2001:798:1::d/126"
+        ],
+        "hostname": "rt0.lju.si.geant.net",
+        "interface": "lag-20.333"
+      }
+    ],
+    "imsid": 745717,
+    "monitored": true,
+    "name": "ARNES-AP1-IAS",
+    "scid": "7f93759e-916e-4aaa-a2de-bbfccd7f0726",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00552",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:3911"
+      }
+    ],
+    "imsid": 747632,
+    "monitored": true,
+    "name": "AMS-HAM-MSE-01150",
+    "scid": "7f99f83b-4ce6-4168-8671-5918d557d8fe",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-01150",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21"
+      }
+    ],
+    "imsid": 735621,
+    "monitored": true,
+    "name": "NL-MICROSOFT-EXPRESSROUTE-LAG",
+    "scid": "7fadc83e-cee2-4288-88f8-07fe110fdfe2",
+    "service_type": "ETHERNET",
+    "sid": "GA-01911",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "LAT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.2301"
+      },
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "pwe-219052"
+      },
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-20:2301"
+      }
+    ],
+    "imsid": 745938,
+    "monitored": true,
+    "name": "LOFAR-02584",
+    "scid": "7fe192d4-ecab-4382-9730-643794f8e21d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02584",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743328,
+    "monitored": true,
+    "name": "TAR-TAR-MGMT-LAG",
+    "scid": "7ffceedc-1b62-447c-9d68-6d654cc39ca0",
+    "service_type": "ETHERNET",
+    "sid": "GA-50005",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [],
+    "imsid": 659378,
+    "monitored": true,
+    "name": "RENATER-AP1-LAG",
+    "scid": "8004d11b-3eee-4f73-824f-23b1cccf510f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01822",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 746052,
+    "monitored": true,
+    "name": "KAU-KAU-MGMT-LAG",
+    "scid": "802087d4-7a06-42e7-8f98-29705d05b803",
+    "service_type": "ETHERNET",
+    "sid": "GA-50065",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.25/30",
+          "2001:798:1::1d/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-22.333"
+      }
+    ],
+    "imsid": 747859,
+    "monitored": true,
+    "name": "CARNET-AP1-IAS",
+    "scid": "802da75d-9d40-41dd-8680-770942d47b8b",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00559",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.21.3.1/24"
+        ],
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae1.998"
+      }
+    ],
+    "imsid": 709869,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-BIL-ES",
+    "scid": "80302663-1ba2-4077-ae12-b40ecbaa450e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00148",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "WP6T3"
+    ],
+    "endpoints": [],
+    "imsid": 677361,
+    "monitored": true,
+    "name": "PARIS-BMS-SRV6-10GBE-001",
+    "scid": "804639ce-6e63-4398-ac41-8d3c70129578",
+    "service_type": "ETHERNET",
+    "sid": "GA-01380",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 723849,
+    "monitored": false,
+    "name": "ETHS-MX1.AMS.NL_GE-0/3/6.1000-MX1.LON.UK_GE-0/3/2.1000",
+    "scid": "805808b4-314b-4a1c-ae6d-468b60809575",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-02219",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658984,
+    "monitored": true,
+    "name": "ATHENS-ATHENS-1GBE-005(ETH)",
+    "scid": "80818260-983d-4ae0-af01-4f0a7183148e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01365",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ASREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae17"
+      }
+    ],
+    "imsid": 659401,
+    "monitored": true,
+    "name": "UK-ASREN-LAG",
+    "scid": "8081ca8f-a9a0-4698-b5b5-bc23a8fbbb13",
+    "service_type": "ETHERNET",
+    "sid": "GA-01758",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661483,
+    "monitored": false,
+    "name": "LON-GROOVE-1",
+    "scid": "809a2673-e63a-4a10-9640-f2ec0c61e643",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00228",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ams.nl.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 744126,
+    "monitored": true,
+    "name": "AMS-BRU-LAG",
+    "scid": "80de734d-161a-4d9f-9dde-8f23d04df002",
+    "service_type": "ETHERNET",
+    "sid": "GA-01922",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.61/30",
+          "2001:798::75/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae22.668"
+      }
+    ],
+    "imsid": 701590,
+    "monitored": false,
+    "name": "CERN-AP1-EXT2-CLS",
+    "scid": "80e3b0e3-eb93-460a-81b3-f7389142051e",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00599",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [],
+    "imsid": 712376,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-KIFU-HU",
+    "scid": "80ec59e4-cb51-4261-915c-fd96aebbf819",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01046",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RESTENA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.56/31",
+          "2001:798::6d/126"
+        ],
+        "hostname": "mx1.fra.de.geant.net",
+        "interface": "ae18.667"
+      }
+    ],
+    "imsid": 677335,
+    "monitored": false,
+    "name": "RESTENA-AP1-CLS",
+    "scid": "8104ba0d-2bff-4f27-976c-24612171213b",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00620",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.249/30",
+          "2001:798:1::3d/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-20.333"
+      }
+    ],
+    "imsid": 745580,
+    "monitored": true,
+    "name": "DFN-AP2-IAS",
+    "scid": "810b158c-2010-45e0-9124-0cc2372542ef",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00567",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-20:354"
+      }
+    ],
+    "imsid": 745578,
+    "monitored": true,
+    "name": "AMS-HAM-JAXA-SINET-DFN-00640",
+    "scid": "813352cd-ae30-49d4-b589-60c56a4aceb1",
+    "service_type": "ETHERNET",
+    "sid": "GS-00640",
+    "speed": 644245094400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/1"
+      }
+    ],
+    "imsid": 727948,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-014(GEANT)",
+    "scid": "8134740b-7497-4398-ac94-7c1ba8564303",
+    "service_type": "ETHERNET",
+    "sid": "GA-01394",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.176/31",
+          "2001:798:99:1::101/126"
+        ],
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae10.100"
+      }
+    ],
+    "imsid": 714072,
+    "monitored": true,
+    "name": "RENAM-AP1",
+    "scid": "81673258-0f12-44c4-b5bb-4b7fb25761a9",
+    "service_type": "GEANT IP",
+    "sid": "GS-00500",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [],
+    "imsid": 663038,
+    "monitored": true,
+    "name": "KIFU-BGP-LU-COC",
+    "scid": "8167bb93-f7da-4157-89a5-68a04e1d5b72",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01010",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SINGAREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/5"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/5.3174"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.3174"
+      }
+    ],
+    "imsid": 746484,
+    "monitored": true,
+    "name": "SINGAREN-02647",
+    "scid": "816b7cf6-9aea-4717-b053-1027251e2aed",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02647",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ROEDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae21"
+      }
+    ],
+    "imsid": 679566,
+    "monitored": true,
+    "name": "ROEDUNET-AP2-LAG",
+    "scid": "819988f7-c21a-4aa4-afab-ca4249174180",
+    "service_type": "ETHERNET",
+    "sid": "GA-01850",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "FCCN_IPP_ExpressRoute_Vlan1943",
+    "scid": "81c847b7-a7b7-4d55-b9a3-9f964f1fd66f",
+    "service_type": null,
+    "sid": "DS-51606",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662327,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-10GBE-006(GEANT)",
+    "scid": "81cadb43-1e06-42f0-9d2e-91b3a2cdcf0b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01539",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 745052,
+    "monitored": true,
+    "name": "LJU-LJU-MGMT-LAG",
+    "scid": "81ccb3e9-3f68-4e3f-8731-7e50454f12ea",
+    "service_type": "ETHERNET",
+    "sid": "GA-50059",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ACONET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.1/30",
+          "2001:798:0010:10dd::1/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae15.51"
+      }
+    ],
+    "imsid": 660433,
+    "monitored": true,
+    "name": "ACONET-AP1",
+    "scid": "81e28a44-51a9-4147-a14e-da736ab89266",
+    "service_type": "GEANT IP",
+    "sid": "GS-00422",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.vie.at.geant.net",
+        "interface": "lag-8"
+      }
+    ],
+    "imsid": 740789,
+    "monitored": true,
+    "name": "BRA-VIE-LAG",
+    "scid": "81edaf42-703d-4eaf-a043-00e6e52b0bbc",
+    "service_type": "ETHERNET",
+    "sid": "GA-01868",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.vie.at - Traffic - ae22.0 - SRV_CLS PRIVATE MICROSOFT SRF9937989 | ASN8075",
+    "scid": "8206b4ab-163a-4edb-97cf-0b6852ca5865",
+    "service_type": null,
+    "sid": "DS-37989",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.70/31",
+          "2001:798:111:1::99/126"
+        ],
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-22.111"
+      }
+    ],
+    "imsid": 745496,
+    "monitored": true,
+    "name": "GRNET-ATH-LHCONE",
+    "scid": "8225dec7-027c-41c0-94a4-0d24eb5214f7",
+    "service_type": "L3-VPN",
+    "sid": "GS-00827",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 658529,
+    "monitored": false,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-050(GEANT)",
+    "scid": "822aec85-d3c6-4d0a-94a0-230f31b967f7",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01673",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "URAN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.kie.ua.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 713991,
+    "monitored": true,
+    "name": "URAN-AP1-LAG",
+    "scid": "822e2451-8daa-4786-a150-c2840385d01f",
+    "service_type": "ETHERNET",
+    "sid": "GA-02024",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [],
+    "imsid": 708703,
+    "monitored": false,
+    "name": "CYNET-GN-PRACE-VPN-PROXY-FRANKFURT-L3VPN_BACKUP",
+    "scid": "8259c10d-2364-48be-a449-111aae20b778",
+    "service_type": "MD-VPN (PROXY)",
+    "sid": "GS-01064",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/24"
+      }
+    ],
+    "imsid": 658647,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-042(ETH)",
+    "scid": "825f9ca7-1d86-432c-a268-3e04e24f2ba9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01225",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [],
+    "imsid": 663023,
+    "monitored": false,
+    "name": "RENAM-AP3",
+    "scid": "8267cffd-de38-488b-9965-8ae48fb1f628",
+    "service_type": "GEANT IP",
+    "sid": "GS-00502",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708271,
+    "monitored": false,
+    "name": "FLOWMON-DDOS-FRA-DE-MANAGEMENT",
+    "scid": "8270bae9-a9ca-450d-bce2-c3478231f6a8",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00164",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.44/31",
+          "2001:798:1::209/126"
+        ],
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae10.333"
+      }
+    ],
+    "imsid": 712361,
+    "monitored": true,
+    "name": "FCCN-AP2-IAS",
+    "scid": "827acbd6-7a54-4605-a645-4d5ff4e8e618",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00528",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-1/3/2"
+      }
+    ],
+    "imsid": 658729,
+    "monitored": true,
+    "name": "POZNAN-POZNAN-10GBE-001(ETH)",
+    "scid": "82821bae-91ef-400c-87e0-43008fd38005",
+    "service_type": "ETHERNET",
+    "sid": "GA-01372",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "pre-prod-rr-20210716-2 |",
+    "scid": "82bc6112-854a-409c-a41c-70d70ff9ae76",
+    "service_type": null,
+    "sid": "GS-01163",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ge-0/0/4"
+      }
+    ],
+    "imsid": 658774,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-007(ETH)",
+    "scid": "82eba9c4-6ad2-476e-b76b-4c9a8fb75974",
+    "service_type": "ETHERNET",
+    "sid": "GA-01505",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.3240"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3240"
+      }
+    ],
+    "imsid": 742671,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-HARNET-NORDUNET",
+    "scid": "83025ba4-4006-4e68-b646-340840256434",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-02606",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3.1025"
+      }
+    ],
+    "imsid": 661571,
+    "monitored": true,
+    "name": "SDN-BOD-BR53-OF-8-HOST-G-ETH4",
+    "scid": "83076978-7838-4341-9f6a-497228bd39cd",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00759",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CSTNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.1009"
+      }
+    ],
+    "imsid": 734574,
+    "monitored": true,
+    "name": "NL-NETHERLIGHT-CSTNET-KAUST-2",
+    "scid": "830b6f63-d7e8-4a29-9cf7-65e4d5121b37",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02393",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "AARNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-1/3/0.3920"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.3920"
+      }
+    ],
+    "imsid": 728403,
+    "monitored": true,
+    "name": "AMS-LON-AARNET-SINGAREN-23049",
+    "scid": "8354ba35-2896-49d8-9835-fdd00ef3c5fe",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02342",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/1/6"
+      }
+    ],
+    "imsid": 732318,
+    "monitored": true,
+    "name": "SCION1ILO.FRA.DE-EXTERNAL-LL",
+    "scid": "835770d2-6495-48db-b20e-adb021d580c7",
+    "service_type": "ETHERNET",
+    "sid": "GA-02196",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 709429,
+    "monitored": true,
+    "name": "LAG-SW1.BIL.ES_AE1",
+    "scid": "837678ea-80c6-4770-a213-31e4e76dc100",
+    "service_type": "ETHERNET",
+    "sid": "GA-02070",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732469,
+    "monitored": false,
+    "name": "VEEAMSERVER-BRA",
+    "scid": "837d3bd7-e184-43a0-b069-f2c3901dcd0d",
+    "service_type": "POP LAN LINK",
+    "sid": "GS-00082",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.3250"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae10.3250"
+      }
+    ],
+    "imsid": 732708,
+    "monitored": true,
+    "name": "AMS-LON-GEANTOPEN-JISC-NEA3R",
+    "scid": "83847c9b-4410-4ae9-844f-fa4f24f1d012",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-02400",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661481,
+    "monitored": false,
+    "name": "PS-PRA-CZ-IDRAC",
+    "scid": "839429c4-c3f1-414f-8111-bf0e9bbd6084",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00348",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [],
+    "imsid": 679360,
+    "monitored": true,
+    "name": "GEANT-CORPORATE-VIAVODAFONE",
+    "scid": "83a1be36-14a0-4802-ab33-0f60d5b5e33c",
+    "service_type": "CORPORATE",
+    "sid": "GS-00467",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3.1033"
+      }
+    ],
+    "imsid": 662000,
+    "monitored": true,
+    "name": "SDN-BOD-BR53-OF-9-HOST-H-ETH2",
+    "scid": "83bac9ec-0015-431a-981c-2e5fb3697a96",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00760",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [],
+    "imsid": 715058,
+    "monitored": false,
+    "name": "AMS-FRA-DFN-SURF-21092",
+    "scid": "83c84616-5c2b-45b8-96af-fc63bd1a42b2",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00634",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.bra.sk.geant.net",
+        "interface": "ae13"
+      }
+    ],
+    "imsid": 733186,
+    "monitored": true,
+    "name": "SANET-AP2-LAG",
+    "scid": "83e725fb-28c5-4cf4-b7a4-da09b96ccd46",
+    "service_type": "ETHERNET",
+    "sid": "GA-02437",
+    "speed": 0,
+    "status": "planned"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae0"
+      }
+    ],
+    "imsid": 658684,
+    "monitored": true,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-057(GEANT)",
+    "scid": "83f1f939-e914-456e-9170-0f88335c7019",
+    "service_type": "ETHERNET",
+    "sid": "GA-01672",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.3506"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.3506"
+      }
+    ],
+    "imsid": 745530,
+    "monitored": false,
+    "name": "RARE-02643",
+    "scid": "83f68ac7-b9e4-4dbc-b44f-3f838ef20e6f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02643",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ULAKBIM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.129/30",
+          "2001:798:2c:10aa::5/126"
+        ],
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-21.100"
+      }
+    ],
+    "imsid": 745292,
+    "monitored": true,
+    "name": "ULAKBIM-AP1",
+    "scid": "83f7a1e5-7ad0-433f-9841-f8b72286767c",
+    "service_type": "GEANT IP",
+    "sid": "GS-00517",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ROEDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 724164,
+    "monitored": false,
+    "name": "BUC-CHI-EAP-RENAM-ROEDUNET-22088",
+    "scid": "83ff3a93-e82c-44c5-bbe1-aa45ccb40f88",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-02213",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658938,
+    "monitored": true,
+    "name": "MILAN 2 CALDERA-MILAN 2 CALDERA-1GBE-007(ETH)",
+    "scid": "84162e9d-1aaa-46f0-852e-d811bcba2e36",
+    "service_type": "ETHERNET",
+    "sid": "GA-01523",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae1.3005"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae1.3502"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.3502"
+      }
+    ],
+    "imsid": 732564,
+    "monitored": false,
+    "name": "RARE-P4-B1-FRA",
+    "scid": "841a43e5-7bf9-417f-94f0-27ebacd071a2",
+    "service_type": "L2SERVICES",
+    "sid": "GS-02640",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [],
+    "imsid": 705435,
+    "monitored": true,
+    "name": "ATH-LON-CONTENT-GRNET-JANET-15031",
+    "scid": "843457e2-f26c-46ad-b3a3-32c357754143",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00665",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.41"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4068"
+      }
+    ],
+    "imsid": 740640,
+    "monitored": true,
+    "name": "BELNET-AZDELTA-EXPRESSROUTE-VLAN4068",
+    "scid": "843c1da0-49e7-47ff-823e-12955c336e10",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02565",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658687,
+    "monitored": false,
+    "name": "730XD-2-VM-TRAFFIC-LAG-PAR",
+    "scid": "844c2d7d-6a47-4803-8d50-c77572e8be0d",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01724",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658567,
+    "monitored": false,
+    "name": "730XD-3-SLOT0-PORT1-VMNIC0-PAR",
+    "scid": "844f2cc4-d54b-47ea-b222-9cf6b9cd5c3b",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01288",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-1/0/5"
+      }
+    ],
+    "imsid": 658392,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-008(ETH)",
+    "scid": "845412e3-ef2b-40fe-a3ec-56d2b2ffad0d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01273",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MARNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-23"
+      }
+    ],
+    "imsid": 747905,
+    "monitored": true,
+    "name": "MARNET-AP2-LAG",
+    "scid": "845c8c48-949a-4d95-8afb-8b0e1ffd7b05",
+    "service_type": "ETHERNET",
+    "sid": "GA-01862",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KANREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.156/31",
+          "2001:798:dd:a::1/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.24"
+      }
+    ],
+    "imsid": 732676,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-KANREN",
+    "scid": "84aea626-8928-4959-a0dc-5c153c17cb5c",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02377",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708204,
+    "monitored": false,
+    "name": "PS-LHCONE-BWCTL-AMS-NL",
+    "scid": "84c7914c-e298-4f0f-8f70-f78b591031ca",
+    "service_type": "L3-VPN",
+    "sid": "GS-00845",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/2/4.1629"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.1629"
+      }
+    ],
+    "imsid": 736653,
+    "monitored": false,
+    "name": "GEN-PAR-SCION-SCION-INTERNET2-2",
+    "scid": "84cd86c9-63bc-422c-907f-6b9b4896000b",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02311",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT-IT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.101"
+      },
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae31.0"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae16.101"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae34.101"
+      }
+    ],
+    "imsid": 705901,
+    "monitored": true,
+    "name": "AMS-OFFICE-TO-LON2-(FOR-EDUVPN)-L2CIRCUIT",
+    "scid": "84d8b53e-8337-4044-bc02-60a111eb20ac",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00652",
+    "speed": 150323855360,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [],
+    "imsid": 712363,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-DFN-1-DE",
+    "scid": "851b5aa9-3607-4451-874a-8c30ca7691bc",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01015",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.86/31",
+          "2001:798:cc::91/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae5.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.87/31",
+          "2001:798:cc::92/126"
+        ],
+        "hostname": "rt0.mar.fr.geant.net",
+        "interface": "lag-5.0"
+      }
+    ],
+    "imsid": 742606,
+    "monitored": false,
+    "name": "MAR-MAR-IPTRUNK",
+    "scid": "851d5330-924d-4e40-ac64-033e077afee4",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02590",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MARWAN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae15"
+      }
+    ],
+    "imsid": 733854,
+    "monitored": true,
+    "name": "UK-MARWAN-LAG",
+    "scid": "853f0c33-24fc-491d-9e62-2680657113b5",
+    "service_type": "ETHERNET",
+    "sid": "GA-02449",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 730601,
+    "monitored": true,
+    "name": "COR-COR-LAG",
+    "scid": "85585083-26d0-47ea-a18c-b7b98e3e9bb1",
+    "service_type": "ETHERNET",
+    "sid": "GA-02405",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "equipment": "MIL01-GRV1",
+        "port": "1/1/5"
+      },
+      {
+        "equipment": "GEN01-GRV3",
+        "port": "1/1/5"
+      }
+    ],
+    "imsid": 669629,
+    "monitored": true,
+    "name": "GEN-MIL1-LHC-CERN-GARR-18061",
+    "scid": "855d1ab8-fa8d-4e25-9bac-006cca9eb287",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-00795",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/0/0.1200"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae12.1200"
+      }
+    ],
+    "imsid": 706977,
+    "monitored": true,
+    "name": "GEN-GEN-GARR-CERNLIGHT-CERN-GARR-16034",
+    "scid": "856b4cd2-49dc-480b-9c68-d795fe3cd58b",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00709",
+    "speed": 332859965440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.kau.lt.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 746515,
+    "monitored": true,
+    "name": "KAU-RIG-LAG",
+    "scid": "85813ab7-6ef9-43ed-846b-7ea903a71b74",
+    "service_type": "ETHERNET",
+    "sid": "GA-02021",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae4"
+      }
+    ],
+    "imsid": 712768,
+    "monitored": true,
+    "name": "LIS-MAD-LAG-200G",
+    "scid": "85afcdd4-6536-41fb-b1f4-606089b144b7",
+    "service_type": "ETHERNET",
+    "sid": "GA-02002",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [],
+    "imsid": 661259,
+    "monitored": true,
+    "name": "RENATER-BGP-LU-COC-AP1",
+    "scid": "85b359e9-e675-4f03-bff8-a25b492e821b",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01058",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 678860,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10GBE-043(GTS)",
+    "scid": "85dc5dd0-f41e-4b12-bbd9-e005d8125d78",
+    "service_type": "ETHERNET",
+    "sid": "GA-01568",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708185,
+    "monitored": true,
+    "name": "PHY INFRASTRUCTURE | TO SRX2",
+    "scid": "85e09623-a596-4319-a3b4-c991620ccb1e",
+    "service_type": "ETHERNET",
+    "sid": "GS-00382",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708710,
+    "monitored": false,
+    "name": "POZ-VIE-IPTRUNK",
+    "scid": "860f1798-281f-49ef-be97-e4d8e632c78e",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00058",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662191,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-1GBE-007(ETH)",
+    "scid": "86161523-6643-4977-bbf4-307f4bcc2957",
+    "service_type": "ETHERNET",
+    "sid": "GA-01641",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.28.1/24"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.991"
+      }
+    ],
+    "imsid": 714243,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-COP-DK",
+    "scid": "8621135c-0ecb-4968-8c69-4f871ff9560b",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00129",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 745463,
+    "monitored": true,
+    "name": "ATH2-THE-LAG",
+    "scid": "862588c4-e0cd-459a-9b2d-15ddec230fb4",
+    "service_type": "ETHERNET",
+    "sid": "GA-02423",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 678077,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10GBE-038(GEANT)",
+    "scid": "86296664-ec93-43c4-b286-63f42c968431",
+    "service_type": "ETHERNET",
+    "sid": "GA-01753",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/2/5"
+      }
+    ],
+    "imsid": 727946,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-013(GEANT)",
+    "scid": "862d832f-f24b-4b65-9c98-6611d980af8c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01399",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "2001:798:99:1::15/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae30.106"
+      }
+    ],
+    "imsid": 734114,
+    "monitored": true,
+    "name": "NL-ESNET-IPV6",
+    "scid": "86397a41-6ca8-4da8-9381-1995a90aeb23",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00890",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658525,
+    "monitored": false,
+    "name": "LON2-PRD-ESX02-VSAN-LAG",
+    "scid": "865c4406-4d6a-4d7d-b3e5-d51459d6cf11",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01707",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [],
+    "imsid": 736760,
+    "monitored": false,
+    "name": "EUMET-JEUNO-PAR-DENV-16026",
+    "scid": "865ed9a1-705f-4e63-800f-6dfa5db0391c",
+    "service_type": "EUMETSAT INTERNATIONAL",
+    "sid": "GS-00456",
+    "speed": 429496729600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.16.253/24"
+        ],
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae2.103"
+      }
+    ],
+    "imsid": 713270,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-CHI1-MD",
+    "scid": "86684d3e-9313-4f58-9997-94935d72bb72",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00127",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658960,
+    "monitored": true,
+    "name": "LONDON-LONDON-1GBE-006(ETH)",
+    "scid": "86af0281-3c8e-4f33-91d4-2f8d561af21b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01473",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661895,
+    "monitored": false,
+    "name": "PS-LON2-UK-IDRAC",
+    "scid": "86b5db5a-3d25-420c-b04b-aee87f8b552d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00324",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GRENA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.184/31",
+          "2001:798:99:1::a9/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae20.200"
+      }
+    ],
+    "imsid": 718130,
+    "monitored": true,
+    "name": "GRENA-AP1",
+    "scid": "86ba43f3-8267-4f28-9d71-3ea838f87436",
+    "service_type": "GEANT IP",
+    "sid": "GS-01178",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662509,
+    "monitored": true,
+    "name": "TELIA-BUD-LAG",
+    "scid": "86beccbc-6d0f-4c0b-a25d-9d1f607ba103",
+    "service_type": "ETHERNET",
+    "sid": "GA-01901",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 658520,
+    "monitored": true,
+    "name": "LAG-QFX.PAR.FR_AE3",
+    "scid": "86db4eba-8291-4a14-8c83-f8cdbc5eddb9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01716",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/13"
+      }
+    ],
+    "imsid": 658494,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-022(ETH)",
+    "scid": "86f708d9-b46e-4a66-bf38-5b21f2a85b51",
+    "service_type": "ETHERNET",
+    "sid": "GA-01223",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 747266,
+    "monitored": true,
+    "name": "COR-DUB-LAG",
+    "scid": "871a8735-441a-45dd-8e51-b8301f9574a5",
+    "service_type": "ETHERNET",
+    "sid": "GA-02385",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ACONET"
+    ],
+    "endpoints": [],
+    "imsid": 709734,
+    "monitored": true,
+    "name": "ACONET EUMETCAST AP2",
+    "scid": "873267c4-c27f-4101-b531-9f947a4a1a14",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01093",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ge-0/1/0"
+      }
+    ],
+    "imsid": 732266,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-1GBE-009(GEANT)",
+    "scid": "874145d3-c8bc-47dc-b4d0-9938acded641",
+    "service_type": "ETHERNET",
+    "sid": "GA-01508",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.69/31",
+          "2001:798:cc::6e/126"
+        ],
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-5.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.68/31",
+          "2001:798:cc::6d/126"
+        ],
+        "hostname": "rt0.cor.ie.geant.net",
+        "interface": "lag-2.0"
+      }
+    ],
+    "imsid": 747412,
+    "monitored": true,
+    "name": "COR-PAR-IPTRUNK",
+    "scid": "8785501b-61c0-4b90-8bf3-e81f266c1a2e",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02477",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [],
+    "imsid": 718080,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-PIONIER-TENET-18067",
+    "scid": "87991956-7e39-43c3-bf51-0ad7b91fb582",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00980",
+    "speed": 118111600640,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732322,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-100MB-001(GEANT)",
+    "scid": "87a0d9f4-1988-4041-ba04-9949493b7efe",
+    "service_type": "ETHERNET",
+    "sid": "GA-01613",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/14"
+      }
+    ],
+    "imsid": 658388,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-003(ETH)",
+    "scid": "87cc0d51-5aa3-430b-9bfa-971da7f4dac3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01224",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.102/31",
+          "2001:798:cc::9d/126"
+        ],
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae4.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.103/31",
+          "2001:798:cc::9e/126"
+        ],
+        "hostname": "rt0.por.pt.geant.net",
+        "interface": "lag-4.0"
+      }
+    ],
+    "imsid": 742668,
+    "monitored": false,
+    "name": "POR-POR-IPTRUNK",
+    "scid": "87d24d3e-1355-400f-9563-b0c9f5c2194c",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02587",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.3921"
+      },
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:3921"
+      }
+    ],
+    "imsid": 747548,
+    "monitored": false,
+    "name": "AMS-HAM-02430",
+    "scid": "87d940f2-109f-4227-ab60-b9fdd5fad208",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02430",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMS01-GRV4",
+        "port": "1/2/3"
+      },
+      {
+        "equipment": "FRA01-GRV4",
+        "port": "1/2/3"
+      },
+      {
+        "equipment": "FRA01-GRV4",
+        "port": "1/2/5"
+      },
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "NL261248"
+      },
+      {
+        "equipment": "DIGITAL REALTY Z-END",
+        "port": "NL261248"
+      }
+    ],
+    "imsid": 739820,
+    "monitored": true,
+    "name": "AMS-POZ-PSNC-24052-1",
+    "scid": "87e98ecc-ec65-4b29-a485-9c5ef70ed5fd",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02549",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.vie.at.geant.net",
+        "interface": "lag-9"
+      }
+    ],
+    "imsid": 740788,
+    "monitored": true,
+    "name": "BUD-VIE-LAG",
+    "scid": "881bb349-3edf-449d-8289-cd17c2b2cfdb",
+    "service_type": "ETHERNET",
+    "sid": "GA-01853",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.29"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4088"
+      }
+    ],
+    "imsid": 739665,
+    "monitored": true,
+    "name": "BELNET-UCLOUVAIN-EXPRESSROUTE-VLAN4088",
+    "scid": "881d13f0-688a-40f3-83cf-487b2736fadb",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02161",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663177,
+    "monitored": false,
+    "name": "FRA-GROOVE-1",
+    "scid": "884a6a26-f185-4159-a5a8-e0a744ef2980",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00172",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.125/30",
+          "2001:798:1::99/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-22.334"
+      }
+    ],
+    "imsid": 747602,
+    "monitored": true,
+    "name": "PIONIER-AP2-IAS",
+    "scid": "8856e1cf-135a-458b-b3f7-42bf9622aacf",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00580",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-22"
+      }
+    ],
+    "imsid": 745465,
+    "monitored": true,
+    "name": "GRNET-LHCONE-LAG",
+    "scid": "8875d1b6-8980-4862-a0a7-9f36675817ac",
+    "service_type": "ETHERNET",
+    "sid": "GA-01364",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743133,
+    "monitored": true,
+    "name": "DUB-DUB-MGMT-LAG",
+    "scid": "88880cd3-6ba5-41ac-9d2f-7c7da0a7e651",
+    "service_type": "ETHERNET",
+    "sid": "GA-02619",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx2.am.office.geant.net",
+        "interface": "fxp0"
+      },
+      {
+        "addresses": [
+          "172.18.1.2/24"
+        ],
+        "hostname": "srx2.am.office.geant.net",
+        "interface": "fxp0.0"
+      }
+    ],
+    "imsid": 708157,
+    "monitored": false,
+    "name": "SRX2-AMS-FXP0",
+    "scid": "888bb836-5328-43d7-bcf7-055af16308c3",
+    "service_type": "CORPORATE",
+    "sid": "GS-01749",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.60/31",
+          "2001:798:111:1::55/126"
+        ],
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae10.1990"
+      }
+    ],
+    "imsid": 730599,
+    "monitored": true,
+    "name": "FCCN-AP2-POR-LHCONE",
+    "scid": "889e2ed8-43d6-42b2-b14c-4e634a625915",
+    "service_type": "L3-VPN",
+    "sid": "GS-02402",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [
+      {
+        "equipment": "MX1.LIS.PT",
+        "port": "AE0.0"
+      },
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae1.0"
+      }
+    ],
+    "imsid": 708718,
+    "monitored": false,
+    "name": "LIS-LIS-IPTRUNK",
+    "scid": "88adf39a-8218-4139-811f-10be7cdd8289",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00047",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.RIG.LV.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 677780,
+    "monitored": false,
+    "name": "RIG OOB LINK",
+    "scid": "88b08e3e-1131-45be-95d5-6626c18e15c9",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00415",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [],
+    "imsid": 663201,
+    "monitored": true,
+    "name": "GARR-BGP-LU-COC-AP2",
+    "scid": "88c1c92d-5a7d-4952-8786-e3cc0ac9fa38",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01006",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732263,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-1GBE-028(GEANT)",
+    "scid": "88cdb942-9fc7-470b-9b06-3fe706893e9c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01405",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.34"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-124051"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4068"
+      }
+    ],
+    "imsid": 744225,
+    "monitored": true,
+    "name": "MSERIZIV-02520",
+    "scid": "88d17665-1901-4efc-aadc-3a1750cc4582",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02520",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.1/31",
+          "2001:798:cc::2/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae7.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.0/31",
+          "2001:798:cc::1/126"
+        ],
+        "hostname": "rt1.buc.ro.geant.net",
+        "interface": "ae7.0"
+      }
+    ],
+    "imsid": 730444,
+    "monitored": true,
+    "name": "BUC-BUD-IPTRUNK",
+    "scid": "88df9c5e-1866-4a07-9012-846e2192d7ca",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00021",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FACEBOOK"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "157.240.84.129/31",
+          "2620:0:1cff:dead:beee::14b3/127"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae47.0"
+      }
+    ],
+    "imsid": 737788,
+    "monitored": true,
+    "name": "FACEBOOK-32934-FRA-PCDE-90606625",
+    "scid": "89192920-9efd-4f50-9f0d-48abcf8863d3",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-02484",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662199,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-1GBE-005(ETH)",
+    "scid": "896b4047-82bf-408c-a2b5-cf1b875a4e3f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01542",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661417,
+    "monitored": false,
+    "name": "ETHS-MX1.LON2.UK_GE-0/0/2.22",
+    "scid": "89700494-98f1-486e-b5b9-f1703bc05989",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00326",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.15.254/24"
+        ],
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "ae2.103"
+      }
+    ],
+    "imsid": 715041,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-KIE2-UA",
+    "scid": "898c618e-da1d-45d6-9b04-82f0b37bcdab",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00132",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "LAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.149/30",
+          "2001:798:1::b5/126"
+        ],
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-20.33"
+      }
+    ],
+    "imsid": 745986,
+    "monitored": true,
+    "name": "LAT-AP1-IAS",
+    "scid": "8997b807-296d-4f5a-8a74-24f55020dd51",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00577",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.1125"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-115008"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:cp-1125"
+      }
+    ],
+    "imsid": 744066,
+    "monitored": false,
+    "name": "IMINDS-00681",
+    "scid": "89b10159-9590-4fcb-a9e7-a4f807f63b44",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00681",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707412,
+    "monitored": true,
+    "name": "KAU-KAU-LAG",
+    "scid": "89b96363-a534-4bf8-86bf-3fe56c67ba23",
+    "service_type": "ETHERNET",
+    "sid": "GA-02041",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.LON2.UK.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 677767,
+    "monitored": false,
+    "name": "LON2 EUNET OOB IP LINK (S00242664)",
+    "scid": "89d17ae0-acd2-49fc-b83d-c69be2e1a0b2",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00405",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "equipment": "LON01-GRV4",
+        "port": "1/2/3"
+      },
+      {
+        "equipment": "GEN01-GRV6",
+        "port": "1/2/3"
+      }
+    ],
+    "imsid": 680167,
+    "monitored": true,
+    "name": "GEN-LON-LHC-CERN-JISC-20040",
+    "scid": "89db048f-810e-4b94-8308-68c97300274b",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-00794",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae16"
+      }
+    ],
+    "imsid": 658674,
+    "monitored": false,
+    "name": "LON2-PRD-ESX10-VM-TRAFFIC",
+    "scid": "89f10438-66ad-4e5b-9f64-2112af2904ed",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01704",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HBKU"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.229/30",
+          "2001:798:99:1::ad/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/5.2100"
+      }
+    ],
+    "imsid": 661713,
+    "monitored": true,
+    "name": "FR-HBKU",
+    "scid": "89f49535-510b-44b1-8222-c36fb794b6fa",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00879",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659148,
+    "monitored": true,
+    "name": "LJUBLJANA-LJUBLJANA-1GBE-003(ETH)",
+    "scid": "89f53c56-3c77-4be6-9951-ac51e0c9e73e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01495",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.2010"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-4/1/4.2010"
+      }
+    ],
+    "imsid": 738645,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-ESNET-NORDUNET-15039-2",
+    "scid": "8a48c70f-4c71-4bf8-956d-d2f4874bdffc",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00964",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.13/30",
+          "2001:798:18:10aa::15/126"
+        ],
+        "hostname": "rt0.cor.ie.geant.net",
+        "interface": "lag-20.12"
+      }
+    ],
+    "imsid": 747414,
+    "monitored": true,
+    "name": "HEANET-AP2",
+    "scid": "8a5756bb-5876-4315-9b54-c187b504dbc4",
+    "service_type": "GEANT IP",
+    "sid": "GS-00474",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732393,
+    "monitored": true,
+    "name": "BUDAPEST-BUDAPEST-1GBE-003(GEANT)",
+    "scid": "8a659fdb-ca49-44c4-b9ef-a07e21305ea5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01565",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "UOM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.130/31",
+          "2001:798:1::a1/126"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae11.333"
+      }
+    ],
+    "imsid": 722111,
+    "monitored": true,
+    "name": "UOM-AP1-IAS",
+    "scid": "8a66b8d4-2a6f-4e15-93f5-085efdff7a6a",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00548",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/2"
+      }
+    ],
+    "imsid": 727936,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-012(GEANT)",
+    "scid": "8aafc220-da5f-4290-a9e7-d5df1f0e49cc",
+    "service_type": "ETHERNET",
+    "sid": "GA-01391",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/13"
+      }
+    ],
+    "imsid": 658463,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-018(ETH)",
+    "scid": "8ab264f8-51f9-47c8-9233-6f2b71a15048",
+    "service_type": "ETHERNET",
+    "sid": "GA-01215",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.117.90/31"
+        ],
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae2.998"
+      }
+    ],
+    "imsid": 713271,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-CHI-MD",
+    "scid": "8ab91ec7-b126-4c2b-807b-d400b95072a9",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00150",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "VERIZON"
+    ],
+    "endpoints": [],
+    "imsid": 724329,
+    "monitored": true,
+    "name": "VIENNA-VERIZON-2-LAG",
+    "scid": "8ac22948-774b-4e52-a29f-4ad2455b8060",
+    "service_type": "ETHERNET",
+    "sid": "GA-02223",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.24"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4083"
+      }
+    ],
+    "imsid": 739677,
+    "monitored": true,
+    "name": "BELNET-STADKORTRIJK-EXPRESSROUTE-VLAN-4083",
+    "scid": "8ac85ffe-60b7-48a5-885e-59b85b069e1d",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01128",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.46/31",
+          "2001:798::59/126"
+        ],
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "ae10.667"
+      }
+    ],
+    "imsid": 714071,
+    "monitored": true,
+    "name": "RENAM-AP2-CLS",
+    "scid": "8ad9440b-a6f6-48dd-aac3-68ea010093b3",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00616",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SINGAREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "203.30.38.113/31",
+          "2001:df0:21a:ffe9:0:20:965:1/64"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.2160"
+      }
+    ],
+    "imsid": 708101,
+    "monitored": false,
+    "name": "UK-SINGAREN-AER-VLAN2160",
+    "scid": "8b10fe6f-4af5-4592-b093-845b809ba60e",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00908",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/18"
+      }
+    ],
+    "imsid": 658386,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-001(ETH)",
+    "scid": "8b2ca47a-8bff-4407-90cc-623b5427f95d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01216",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURFNET"
+    ],
+    "endpoints": [],
+    "imsid": 720481,
+    "monitored": true,
+    "name": "SURFNET-TEMP-EXPRESSROUTE-VLAN3751",
+    "scid": "8b366817-0ab6-4a12-adb5-93e35bc6b225",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02201",
+    "speed": 64424509440,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 733969,
+    "monitored": true,
+    "name": "LAG-SW2.PAR.FR_AE1",
+    "scid": "8b4bebc7-1ed7-4d06-8860-0484f21276f5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01826",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661251,
+    "monitored": false,
+    "name": "LON-SINET-HOST-DEVICE-IDRAC",
+    "scid": "8b5b2aaf-bbf1-4ea1-a86b-1fb7a6189a3c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00235",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658983,
+    "monitored": true,
+    "name": "LJUBLJANA-LJUBLJANA-1GBE-002(ETH)",
+    "scid": "8b93f169-4870-44d3-b053-38c57e1f31ee",
+    "service_type": "ETHERNET",
+    "sid": "GA-01496",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662246,
+    "monitored": true,
+    "name": "DUBLIN (CITY WEST)-DUBLIN (CITY WEST)-1GBE-005(ETH)",
+    "scid": "8bbd2591-d606-4034-84db-0bc2653a0f98",
+    "service_type": "ETHERNET",
+    "sid": "GA-01596",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-4/1/4.411"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.411"
+      }
+    ],
+    "imsid": 738643,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-ESNET-ESNET-170391",
+    "scid": "8bd8b9b3-6985-4201-ae90-c95456fee925",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00962",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-1/0/3"
+      }
+    ],
+    "imsid": 658391,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-007(ETH)",
+    "scid": "8c17ccc8-0f60-4348-9ac4-a2a215350044",
+    "service_type": "ETHERNET",
+    "sid": "GA-01275",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 721147,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-004(GEANT)",
+    "scid": "8c212fd1-818d-425a-bfdf-1a18047f0e01",
+    "service_type": "ETHERNET",
+    "sid": "GA-01392",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.44/31",
+          "2001:798::55/126"
+        ],
+        "hostname": "mx1.buc.ro.geant.net",
+        "interface": "ae12.667"
+      }
+    ],
+    "imsid": 677400,
+    "monitored": true,
+    "name": "RENAM-AP1-CLS",
+    "scid": "8c53c525-2496-4091-ab3b-49b8eb10beba",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00615",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "lon-lon2_GEANT_SURFNET-SINET_16007",
+    "scid": "8c9a63d1-947e-4681-8efe-c617971f7b56",
+    "service_type": null,
+    "sid": "DS-33355",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "LITNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.161/30",
+          "2001:798:1f:10aa::9/126"
+        ],
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae10.100"
+      }
+    ],
+    "imsid": 745339,
+    "monitored": true,
+    "name": "LITNET-AP2",
+    "scid": "8cc820be-62a1-4682-a42b-5193743aeabb",
+    "service_type": "GEANT IP",
+    "sid": "GS-00487",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 658673,
+    "monitored": true,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-060(GEANT)",
+    "scid": "8ccb1cd8-5e4e-4015-b264-4732c5eb5028",
+    "service_type": "ETHERNET",
+    "sid": "GA-01682",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "xe-5/0/0.0"
+      },
+      {
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae10.110"
+      }
+    ],
+    "imsid": 738245,
+    "monitored": true,
+    "name": "BUD-CHI-EAP-RENAM-ARELION-24033",
+    "scid": "8ceca1cd-f5a1-483b-b2ab-756ab0da26f1",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02110",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "2001:798:99:1::d/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae13.106"
+      }
+    ],
+    "imsid": 730105,
+    "monitored": true,
+    "name": "CH-ESNET-IPV6",
+    "scid": "8cf48638-518e-4f78-8dd4-5546c1d3d94b",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00873",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662217,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-1GBE-013(ETH)",
+    "scid": "8cfb4a66-1809-4896-bdde-4dd65db6e64f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01644",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae10.1947"
+      },
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.10"
+      }
+    ],
+    "imsid": 707124,
+    "monitored": true,
+    "name": "FCCN-IPP-EXPRESSROUTE-VLAN1947",
+    "scid": "8d25144c-32f2-40ee-b627-6aca9d1fd0cc",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01141",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.2265"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae20.2265"
+      }
+    ],
+    "imsid": 721397,
+    "monitored": true,
+    "name": "AMS-LON-SINET-SINET-22074",
+    "scid": "8d52a5da-2212-4696-b4c6-f5f1f35ebf5b",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02207",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RESTENA"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.854"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae18.854"
+      }
+    ],
+    "imsid": 733000,
+    "monitored": false,
+    "name": "FRA-PAR-MISC-RESTENA-RENATER-20030",
+    "scid": "8d703367-935c-4c79-a13c-38e861d2861a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00704",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658164,
+    "monitored": false,
+    "name": "AMS OOB LINK",
+    "scid": "8d922910-904c-4977-815e-9eb3b07afd5f",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00389",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.KAU.LT(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 658233,
+    "monitored": false,
+    "name": "KAU OOB LINK",
+    "scid": "8dc7382b-de26-430b-880c-41b62099f755",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00402",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "WP6T3"
+    ],
+    "endpoints": [],
+    "imsid": 678790,
+    "monitored": false,
+    "name": "LON2-PRA-WP6-GTS-20064",
+    "scid": "8dd962d2-b900-4cd2-87f8-68d0ac03424d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00718",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "17.1.172.201/31",
+          "2a01:b740:1:8c10::201/127"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae45.0"
+      }
+    ],
+    "imsid": 730364,
+    "monitored": false,
+    "name": "DE-APPLE-IAS",
+    "scid": "8de489a7-3153-4167-8c4a-e6beaaab2653",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-02395",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/1/6.1003"
+      }
+    ],
+    "imsid": 661658,
+    "monitored": false,
+    "name": "JRA1-SDN-BOD-PILOT-BR53",
+    "scid": "8df58728-575d-4bbe-8f93-cfe0db46b83d",
+    "service_type": "L3-VPN",
+    "sid": "GS-02122",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "T-SYSTEMS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "80.158.74.245/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae21.4002"
+      }
+    ],
+    "imsid": 728924,
+    "monitored": true,
+    "name": "DE-T-SYSTEMS-R&E",
+    "scid": "8e577713-0de2-453f-a4dd-4f17d153ada6",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02330",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661310,
+    "monitored": false,
+    "name": "PS-MAD-ES-MANAGEMENT",
+    "scid": "8e61e130-d04f-44ed-82c3-135061f62b2e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00329",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/3"
+      }
+    ],
+    "imsid": 723722,
+    "monitored": true,
+    "name": "LONDON-LONDON-10GBE-014(GEANT)",
+    "scid": "8e731536-f401-4ae7-8044-13cecf8d24f2",
+    "service_type": "ETHERNET",
+    "sid": "GA-01532",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "CYNET LAG",
+    "scid": "8e8e040d-d3d5-4b4b-bd78-c650cd952d2f",
+    "service_type": null,
+    "sid": "GA-01950",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.28"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4066"
+      }
+    ],
+    "imsid": 739660,
+    "monitored": true,
+    "name": "BELNET-ONDD-EXPRESSROUTE-VLAN4066",
+    "scid": "8e944086-e92f-4d59-beee-3970a6f7278a",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02390",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae10.114"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae19.114"
+      }
+    ],
+    "imsid": 705442,
+    "monitored": true,
+    "name": "FRA-GEN-ORACLE-CERN-20094",
+    "scid": "8e9d94a9-6bbf-4e83-aba4-49d4891c944a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00698",
+    "speed": 450971566080,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 747826,
+    "monitored": true,
+    "name": "BUD-ZAG-LAG",
+    "scid": "8eab03c0-40f2-4b92-a699-a5d392a53048",
+    "service_type": "ETHERNET",
+    "sid": "GA-01909",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SUNET"
+    ],
+    "endpoints": [],
+    "imsid": 715307,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-SUNET-2-SE",
+    "scid": "8ebd1a42-7a1a-4355-911e-36667d34e044",
+    "service_type": "MD-VPN (PROXY)",
+    "sid": "GS-01066",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "WP6T3"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/8"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/0/6"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/8.11"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/0/6.11"
+      }
+    ],
+    "imsid": 715036,
+    "monitored": false,
+    "name": "LON2-LON2-WP7T2SF-BMS8-JRA2T4-21089",
+    "scid": "8ec5c1d7-fa53-4ee4-900b-cd8a37e4de0a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00740",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.46/31",
+          "2001:798:1::16d/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae13.0"
+      }
+    ],
+    "imsid": 733783,
+    "monitored": true,
+    "name": "GOOGLE-15169-NL",
+    "scid": "8ed7798c-34f0-4e0f-8c77-1389086c961c",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-02451",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.26"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4063"
+      }
+    ],
+    "imsid": 739662,
+    "monitored": true,
+    "name": "BELNET-JUST-EXPRESSROUTE-VLAN4063",
+    "scid": "8ef1b7bc-c825-4f7b-82b6-405c2b7ae2c8",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02319",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/46"
+      }
+    ],
+    "imsid": 658980,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-063(ETH)",
+    "scid": "8f046b8b-a734-4422-b426-d21a16282266",
+    "service_type": "ETHERNET",
+    "sid": "GA-01229",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 659361,
+    "monitored": true,
+    "name": "FCCN-AP1-LAG",
+    "scid": "8f36dfef-9675-4fee-99ef-9c7de29e1627",
+    "service_type": "ETHERNET",
+    "sid": "GA-01786",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CSTNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae12.3552"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae21.3552"
+      }
+    ],
+    "imsid": 732309,
+    "monitored": true,
+    "name": "GEN-MAR-IHEP-CERN-CSTNET",
+    "scid": "8f385fb8-9070-4944-81cf-1fdc0117ffd1",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02414",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662306,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-10GBE-058(GEANT)",
+    "scid": "8f42060a-c71b-46bf-aa0d-7063b5599155",
+    "service_type": "ETHERNET",
+    "sid": "GA-01603",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-22"
+      }
+    ],
+    "imsid": 747272,
+    "monitored": true,
+    "name": "NRENBBEXT-JISC-LAG",
+    "scid": "8f498cb0-f916-4847-9f30-77a9a7f0974d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01550",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.77/30",
+          "2001:798:1::61/126"
+        ],
+        "hostname": "rt0.cor.ie.geant.net",
+        "interface": "lag-20.333"
+      }
+    ],
+    "imsid": 747415,
+    "monitored": true,
+    "name": "HEANET-AP2-IAS",
+    "scid": "8f70add2-850b-404a-b5ac-0459957c3d09",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00573",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.2.1/24"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae1.103"
+      }
+    ],
+    "imsid": 733980,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-PAR-FR",
+    "scid": "8f7f92c5-6968-4369-aa3b-dc23445bc0a1",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00124",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae4"
+      }
+    ],
+    "imsid": 658685,
+    "monitored": false,
+    "name": "LON2-SEC-ESX20-ESXI-TRAFFIC",
+    "scid": "8f80b196-5332-40b2-a35b-2ce2133e5f29",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01692",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-1/0/0"
+      }
+    ],
+    "imsid": 658623,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-028(ETH)",
+    "scid": "8f8a29bd-9e22-4bab-86a1-a5371ec1c500",
+    "service_type": "ETHERNET",
+    "sid": "GA-01277",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [],
+    "imsid": 712364,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-RENATER-1-FR",
+    "scid": "8f998db0-fd16-44d7-9cda-d93ed41ff347",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01051",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708252,
+    "monitored": false,
+    "name": "PS-LIS-PT-BWCTL",
+    "scid": "8fa15d2c-0e3c-4551-8912-65aa3b185e01",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00315",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RARE"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-1/0/2"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-1/0/2.702"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.702"
+      }
+    ],
+    "imsid": 736105,
+    "monitored": false,
+    "name": "LON-AMS-DTN-GENERATOR",
+    "scid": "8fc6c7fd-c9a7-4d89-a699-bd4244d08950",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00722",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMS01-GRV2",
+        "port": "1/1/6"
+      },
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "DE258134"
+      },
+      {
+        "equipment": "DIGITAL REALTY Z-END",
+        "port": "DE258134"
+      }
+    ],
+    "imsid": 739363,
+    "monitored": true,
+    "name": "AMS-FRA-NORDUNET-24054-2",
+    "scid": "8fea8bde-f20a-4737-aaa6-b16f895f7e2d",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02530",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.30"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4089"
+      }
+    ],
+    "imsid": 739664,
+    "monitored": true,
+    "name": "BELNET-MOBILIT-EXPRESSROUTE-VLAN4089",
+    "scid": "8fead412-5c89-4ddf-88ce-caa11fd6a796",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02170",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662243,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-056(ETH)",
+    "scid": "8ff0150a-47bd-42ba-bacf-8f6548e177ff",
+    "service_type": "ETHERNET",
+    "sid": "GA-01630",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "DFN-AP1-CLS|ASN680",
+    "scid": "90234395-1165-4501-b037-4d67a3591aef",
+    "service_type": null,
+    "sid": "DS-33539",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae22"
+      }
+    ],
+    "imsid": 701583,
+    "monitored": true,
+    "name": "CERN-AP1-EXT2-LAG",
+    "scid": "90723412-846b-48ee-8ed5-4bf72c225dc0",
+    "service_type": "ETHERNET",
+    "sid": "GA-02089",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 658807,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-1GBE-006(ETH)",
+    "scid": "908575d2-2a4c-4717-9c09-14428ca5abb9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01442",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708236,
+    "monitored": false,
+    "name": "VEEAM-BACKUP-2-MAR-FR",
+    "scid": "90e175bf-dbc0-45e6-9515-7f7a45bc5602",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00378",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.gen.ch.geant.net",
+        "interface": "lag-7"
+      }
+    ],
+    "imsid": 739695,
+    "monitored": true,
+    "name": "GEN-PAR-1.6T-LAG",
+    "scid": "90e775c1-c48d-426c-b9a4-6c412ddff754",
+    "service_type": "ETHERNET",
+    "sid": "GA-01887",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ge-0/0/1"
+      }
+    ],
+    "imsid": 732259,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-1GBE-008(GEANT)",
+    "scid": "91008b81-04a7-43d4-89cc-1140244d2487",
+    "service_type": "ETHERNET",
+    "sid": "GA-01512",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 746140,
+    "monitored": true,
+    "name": "LON2-PAR-ROLR-LAG",
+    "scid": "9107e4f3-cb9d-4c23-a356-2aecf0974f4a",
+    "service_type": "ETHERNET",
+    "sid": "GA-50067",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.248/31",
+          "2001:798:cc:1::105/126"
+        ],
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-4.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.249/31",
+          "2001:798:cc:1::106/126"
+        ],
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "lag-3.0"
+      }
+    ],
+    "imsid": 746458,
+    "monitored": true,
+    "name": "RIG-TAR-IPTRUNK",
+    "scid": "915247f2-026d-407e-bdb5-e5d272de411b",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02345",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 715097,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-1GBE-010(ETH)",
+    "scid": "916bd190-edf7-430c-810c-4783aa38d978",
+    "service_type": "ETHERNET",
+    "sid": "GA-01509",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "addresses": [
+          "62.40.116.121/29",
+          "2001:798:ee:10::1/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30.3007"
+      },
+      {
+        "addresses": [
+          "62.40.104.29/30",
+          "2001:798:6:4::1/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30.3015"
+      }
+    ],
+    "imsid": 712154,
+    "monitored": false,
+    "name": "INFOBLOX-VPAR-PAR-FR",
+    "scid": "916d1762-c571-4dbf-baf4-6a28c2f691ad",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00205",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661620,
+    "monitored": false,
+    "name": "PS-LON-UK-PSMP-BWCTL-VLAN23",
+    "scid": "91760f01-4e5c-44ce-bd1c-c294ca8506f9",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00322",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.57/31",
+          "2001:798:cc::5a/126"
+        ],
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-6.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.56/31",
+          "2001:798:cc::59/126"
+        ],
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-2.0"
+      }
+    ],
+    "imsid": 745507,
+    "monitored": true,
+    "name": "ATH2-MIL2-IPTRUNK",
+    "scid": "917627fa-d842-4216-b637-a60d4ffee805",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00014",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.112.41/30",
+          "2001:799:cb2:3::1/64"
+        ],
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/1.10"
+      }
+    ],
+    "imsid": 662954,
+    "monitored": false,
+    "name": "SRX1-SRX2-CH-OFFICE",
+    "scid": "917bf593-fd77-47e3-84cf-cf95cefe96da",
+    "service_type": "CORPORATE",
+    "sid": "GS-01646",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-23"
+      }
+    ],
+    "imsid": 747582,
+    "monitored": true,
+    "name": "HAM-DTN-LAG",
+    "scid": "91ec5940-45f6-4372-9f88-0b8dbf90b5af",
+    "service_type": "ETHERNET",
+    "sid": "GA-50069",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662224,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-1GBE-015(ETH)",
+    "scid": "922eabaf-3cec-4d7a-8964-26c7cb86b8d6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01649",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "IRANET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.85/30",
+          "2001:798:99:1::81/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.50"
+      }
+    ],
+    "imsid": 732661,
+    "monitored": false,
+    "name": "DE-IRANET",
+    "scid": "923321c4-d3d9-4e95-9b63-d60f897bf720",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-01169",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-3/0/2"
+      }
+    ],
+    "imsid": 658856,
+    "monitored": true,
+    "name": "POZNAN-POZNAN-10GBE-004(ETH)",
+    "scid": "924d8f89-e625-408c-9c00-4f98283d6911",
+    "service_type": "ETHERNET",
+    "sid": "GA-02139",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.buc.ro.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 745567,
+    "monitored": true,
+    "name": "BUC-BUC-MGMT-LAG",
+    "scid": "92512f10-1f81-4902-bbb6-09242f8bbb82",
+    "service_type": "ETHERNET",
+    "sid": "GA-50061",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708751,
+    "monitored": true,
+    "name": "TAL-TAL-IPTRUNK",
+    "scid": "92592767-8522-4492-808f-e3775461377e",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00062",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 715163,
+    "monitored": true,
+    "name": "DUB2-LON-LAG",
+    "scid": "9274fc90-45e9-46ae-8d5e-0b6f9e42d8cc",
+    "service_type": "ETHERNET",
+    "sid": "GA-01847",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660719,
+    "monitored": false,
+    "name": "ASREN-EDGE-DEVICE-VLAN505",
+    "scid": "928c7cf3-0e2c-4dc2-ba59-6afe83b008be",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00099",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "DS-09233",
+    "scid": "929eb4c1-1fa1-4de3-9646-6d49cb97f798",
+    "service_type": null,
+    "sid": "DS-09233",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/2"
+      }
+    ],
+    "imsid": 662513,
+    "monitored": true,
+    "name": "PHY CONNECTION TO SWITCH CLUSTER VME.0 - SWITCH CHASSIS 0 MGMT - PRIMARY",
+    "scid": "92cbb48c-6658-4a43-8d41-114d0f4f489a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01281",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RASH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-24"
+      }
+    ],
+    "imsid": 744994,
+    "monitored": true,
+    "name": "RASH-AP2-LAG",
+    "scid": "92ddf792-8433-4c93-9168-87bc6a314426",
+    "service_type": "ETHERNET",
+    "sid": "GA-01768",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.22.1/24"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae1.103"
+      }
+    ],
+    "imsid": 729104,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-FRA-DE",
+    "scid": "93055442-d0a4-4fd5-b62e-b618140d5d7f",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00117",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-2/0/47"
+      }
+    ],
+    "imsid": 658594,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-027(ETH)",
+    "scid": "93112d2e-d9b6-4e16-a007-2d735a0201ef",
+    "service_type": "ETHERNET",
+    "sid": "GA-01261",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 658664,
+    "monitored": false,
+    "name": "LON2-PRD-ESX02-ESXI-TRAFFIC",
+    "scid": "93138f6d-c0f7-403e-b3ea-faa694106c5d",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01696",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "195.169.24.10/28",
+          "2001:610:9d8::a/64"
+        ],
+        "hostname": "srx1.am.office.geant.net",
+        "interface": "ge-0/0/0.10"
+      }
+    ],
+    "imsid": 663032,
+    "monitored": false,
+    "name": "SRX1-AMS-INFRASTRUCTURE-MANAGEMENT",
+    "scid": "9315df0b-3984-4e2a-b3de-77df4720efaf",
+    "service_type": "CORPORATE",
+    "sid": "GS-00380",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.144/31",
+          "2001:798:99:1::e9/126"
+        ],
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae10.1931"
+      }
+    ],
+    "imsid": 712362,
+    "monitored": true,
+    "name": "FCCN-AP2",
+    "scid": "931ba49d-f849-4277-9820-bc22a7719a6f",
+    "service_type": "GEANT IP",
+    "sid": "GS-00460",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.3906"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.8"
+      }
+    ],
+    "imsid": 706994,
+    "monitored": true,
+    "name": "NORDUNET-AALTO-EXPRESSROUTE-VLAN3906",
+    "scid": "933cbcbd-11ed-4e5a-9d19-78d122cfa02b",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01155",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "IUCC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae22"
+      }
+    ],
+    "imsid": 729994,
+    "monitored": true,
+    "name": "IUCC-AP2-LAG",
+    "scid": "9344e3d4-0995-4dee-8ee9-e70ed3e738e1",
+    "service_type": "ETHERNET",
+    "sid": "GA-01940",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NIX"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae12"
+      }
+    ],
+    "imsid": 724675,
+    "monitored": true,
+    "name": "PRA-NIX-LAG",
+    "scid": "934b5710-520d-4c56-968d-8476eb301870",
+    "service_type": "ETHERNET",
+    "sid": "GA-01828",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ACONET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.133/30",
+          "2001:0798:001e:10aa::d/126"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae18.53"
+      }
+    ],
+    "imsid": 661508,
+    "monitored": true,
+    "name": "ACONET-AP2",
+    "scid": "935b6fd4-14e0-4faa-ab4c-4bdf120fade2",
+    "service_type": "GEANT IP",
+    "sid": "GS-00423",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "LINX"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae20"
+      }
+    ],
+    "imsid": 659363,
+    "monitored": true,
+    "name": "LINX-LAG",
+    "scid": "938b2901-6630-4f0b-8c1f-5e00b66ebb7c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01839",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658504,
+    "monitored": false,
+    "name": "730XD-4-SLOT0-PORT1-VMNIC0-PAR",
+    "scid": "93a0cd7d-6c43-49e0-a5ed-93ecef672d30",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01286",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PSMP-GN-DRAC-LIS-PT.GEANT.ORG",
+        "port": "IDRAC"
+      },
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ge-0/3/7"
+      },
+      {
+        "addresses": [
+          "62.40.118.76/31",
+          "2001:798:ee:b::25/126"
+        ],
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ge-0/3/7.0"
+      }
+    ],
+    "imsid": 708306,
+    "monitored": false,
+    "name": "PS-LIS-PT-IDRAC",
+    "scid": "93a29f43-8d40-414d-820a-6a3e09052c8b",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00316",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 727155,
+    "monitored": true,
+    "name": "BRU-BRU-IPTRUNK",
+    "scid": "93db3ebc-37cb-428c-8f66-2e21ce28ab9c",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02277",
+    "speed": 128849018880,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.kau.lt.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 746516,
+    "monitored": true,
+    "name": "KAU-POZ-LAG",
+    "scid": "93eebe3a-4fdd-4d4a-9e81-ca23690ee5ed",
+    "service_type": "ETHERNET",
+    "sid": "GA-02044",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663066,
+    "monitored": false,
+    "name": "IPCAMERA-BUD-HU",
+    "scid": "93ffba14-5e4d-4cbd-a800-b90bc1613735",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00208",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658531,
+    "monitored": false,
+    "name": "730XD-1-VSAN-TRAFFIC-LAG",
+    "scid": "94026e49-10dd-4d4a-99d0-27c836060c16",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01679",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.1501"
+      },
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:1501"
+      }
+    ],
+    "imsid": 747551,
+    "monitored": true,
+    "name": "HAM-LON-00719",
+    "scid": "940cf557-39dc-4140-a2e5-df9871cca828",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00719",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 728725,
+    "monitored": true,
+    "name": "KAU-RIG-IP1",
+    "scid": "9437476e-6c71-4b6d-88a2-c5f5d2b9a33d",
+    "service_type": "ETHERNET",
+    "sid": "GA-D00012    ---TEMP",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 744015,
+    "monitored": true,
+    "name": "BRUSSELS-BRUSSELS-LAG-002(GEANT)",
+    "scid": "943fee4a-a595-4e5e-ac96-282dd07a0ec0",
+    "service_type": "ETHERNET",
+    "sid": "GA-02570",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ge-0/0/6"
+      }
+    ],
+    "imsid": 659219,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-022(ETH)",
+    "scid": "9448d35b-055a-4c9a-9e93-c62b4d0753e6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01506",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/1/6.1728"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.1728"
+      }
+    ],
+    "imsid": 744389,
+    "monitored": false,
+    "name": "AMS-FRA-KAUST-SCION",
+    "scid": "9468c829-37b0-44b9-b661-d5567b753654",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02417",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662221,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-014(ETH)",
+    "scid": "9478eadd-5a52-4ab9-8bfb-8ab6bf9c0b96",
+    "service_type": "ETHERNET",
+    "sid": "GA-01609",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661612,
+    "monitored": false,
+    "name": "XANTARO-SERVICE-ENGINE-ETH1-NETDEVICES-LON2-VLAN946",
+    "scid": "948054e3-e0bb-481e-b9cd-1b2dbfdf7bbb",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00387",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "198.124.80.30/30",
+          "2001:400:f003:d::3/127"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.2013"
+      }
+    ],
+    "imsid": 709643,
+    "monitored": true,
+    "name": "ESNET-NEA3R-LON-LHCONE",
+    "scid": "94d4cda8-8527-4e9d-bb01-9769c302f118",
+    "service_type": "L3-VPN",
+    "sid": "GS-00822",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 701854,
+    "monitored": true,
+    "name": "LISBON-LISBON-1GBE-001(ETH)",
+    "scid": "94e3b74f-1a5a-4d55-be40-ea7c8a4b6a83",
+    "service_type": "ETHERNET",
+    "sid": "GA-01527",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.3005"
+      }
+    ],
+    "imsid": 726619,
+    "monitored": false,
+    "name": "RARE-BIL-REDIRIS",
+    "scid": "952a8701-3ca0-45ee-9b6a-a2890581bc23",
+    "service_type": "L2SERVICES",
+    "sid": "GS-02290",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 735853,
+    "monitored": true,
+    "name": "LON2-LON2-10G-LINK2",
+    "scid": "952ab172-3e07-4fc3-976c-b46fbfd816a9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01324",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.bra.sk.geant.net",
+        "interface": "ae6"
+      }
+    ],
+    "imsid": 729435,
+    "monitored": true,
+    "name": "BRA-BUD LAG 100G",
+    "scid": "9535fce0-e586-420b-a044-f24df712a585",
+    "service_type": "ETHERNET",
+    "sid": "GA-01756",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae44"
+      }
+    ],
+    "imsid": 731226,
+    "monitored": true,
+    "name": "GOOGLE-FRA15-LAG2",
+    "scid": "95433ca9-9978-4791-844a-64e3f8e2296b",
+    "service_type": "ETHERNET",
+    "sid": "GA-02225",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.105/30"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae30.104"
+      }
+    ],
+    "imsid": 734112,
+    "monitored": true,
+    "name": "NL-ESNET-IPV4",
+    "scid": "954f1e38-cabb-4cf8-aa16-32fa65314c32",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00889",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.18"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240594"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4089"
+      }
+    ],
+    "imsid": 744264,
+    "monitored": true,
+    "name": "MSEPREMIER-01137",
+    "scid": "9562b13c-43a3-4e63-8b59-77a18b7e8602",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01137",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HBKU"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.225/30"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/2.2200"
+      }
+    ],
+    "imsid": 661378,
+    "monitored": true,
+    "name": "UK-HBKU",
+    "scid": "957ef638-c8c8-41cb-a2db-26a431b253c9",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00907",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ASREN",
+    "scid": "95961283-cc7f-428f-b137-90b66f2f654e",
+    "service_type": null,
+    "sid": "GA-01319",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "DUB2-LON2 LAG",
+    "scid": "95a17705-7a97-4335-a2b9-986bdfc75228",
+    "service_type": null,
+    "sid": "GA-01890",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [],
+    "imsid": 712401,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-DFN-2-DE",
+    "scid": "95b6144a-03ea-4036-b670-de841b79384b",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01037",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661677,
+    "monitored": false,
+    "name": "KVMOIP-PRA-CZ",
+    "scid": "95cec409-80ad-4d50-a8ad-795ef8938026",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00222",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lon.uk.geant.net",
+        "interface": "lag-6"
+      }
+    ],
+    "imsid": 747277,
+    "monitored": true,
+    "name": "DUB-LON-LAG",
+    "scid": "95d88f6d-70d5-4c17-8f0b-38c15c6aa57d",
+    "service_type": "ETHERNET",
+    "sid": "GA-02006",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.33"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240589"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4082"
+      }
+    ],
+    "imsid": 744267,
+    "monitored": true,
+    "name": "MSEKULEUVEN-01134",
+    "scid": "95ed5990-332b-49eb-87e8-beafde03260a",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01134",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708208,
+    "monitored": false,
+    "name": "PS-LON2-UK-BWCTL",
+    "scid": "95edd24e-8c6b-4f8d-bf6d-b30569ec013a",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00323",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.BUC-NEW",
+        "port": "GI0/0"
+      }
+    ],
+    "imsid": 677552,
+    "monitored": false,
+    "name": "BUC OOB LINK",
+    "scid": "95ee36f4-9ed8-47e0-9cd0-cc9e0a8c53b6",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00394",
+    "speed": 10485760,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.mad.es - Traffic - ae12 - LAG CUSTOMER REDIRIS SRF9926947 |",
+    "scid": "95f1df21-a239-4b1d-b1dc-832de292af1b",
+    "service_type": null,
+    "sid": "GA-01781",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-99514671"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:1176"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae13.37"
+      }
+    ],
+    "imsid": 745322,
+    "monitored": true,
+    "name": "GEANT_EPIPE_99514671",
+    "scid": "9622bc35-cc9c-4c41-8b12-cfef77399a13",
+    "service_type": "ETHERNET",
+    "sid": "GS-00682",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708257,
+    "monitored": false,
+    "name": "PS-PRA-CZ-OWAMP",
+    "scid": "9633657b-9418-4104-9c79-0cb0a6742662",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00350",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.32/31",
+          "2001:798::39/126"
+        ],
+        "hostname": "mx1.ams.nl.geant.net",
+        "interface": "ae15.667"
+      }
+    ],
+    "imsid": 662996,
+    "monitored": false,
+    "name": "SURFNET-AP1-CLS",
+    "scid": "965a18db-e915-4235-a0a4-67335029d23f",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00622",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [],
+    "imsid": 712400,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-DFN-1-DE",
+    "scid": "9664eb14-aeb9-4172-b87d-7d21d7efe83a",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01036",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660429,
+    "monitored": false,
+    "name": "TAAS-CONTROL-LONDON",
+    "scid": "9672fb48-5ce4-4c69-bcdf-b8850880ead9",
+    "service_type": "GTS",
+    "sid": "GS-01188",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae33"
+      }
+    ],
+    "imsid": 739552,
+    "monitored": true,
+    "name": "NORDUNET-AP3-LAG",
+    "scid": "968d6d88-88b8-4238-a46b-d927fc259148",
+    "service_type": "ETHERNET",
+    "sid": "GA-02480",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659017,
+    "monitored": true,
+    "name": "PARIS-FLOWMON-MGMT-1GBE-004(ETH)",
+    "scid": "96bcab6c-ad79-4217-aff1-008413162519",
+    "service_type": "ETHERNET",
+    "sid": "GA-01400",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.300"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-113012"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:cp-300"
+      }
+    ],
+    "imsid": 744064,
+    "monitored": true,
+    "name": "GENI-00628",
+    "scid": "96fb0fd8-3a12-409d-99fa-c50dd0d3aea9",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00628",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.3005"
+      }
+    ],
+    "imsid": 712147,
+    "monitored": false,
+    "name": "RARE-PAR-RENATER",
+    "scid": "9704ae6b-f7d1-458a-b07f-3e44409e1e34",
+    "service_type": "L2SERVICES",
+    "sid": "GS-00776",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658658,
+    "monitored": false,
+    "name": "730XD-1-VSAN-TRAFFIC-LAG-PAR",
+    "scid": "9705a881-a490-4d31-ac78-efd1111490ef",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01721",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx2.am.office.geant.net",
+        "interface": "ge-0/0/1"
+      },
+      {
+        "addresses": [
+          "195.169.24.50/30"
+        ],
+        "hostname": "srx2.am.office.geant.net",
+        "interface": "ge-0/0/1.0"
+      }
+    ],
+    "imsid": 708319,
+    "monitored": false,
+    "name": "SRX2-SRX1-AMS-OFFICE",
+    "scid": "973c5570-4763-413f-910d-76aa459b8ccd",
+    "service_type": "CORPORATE",
+    "sid": "GS-01750",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.550"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-23:550"
+      }
+    ],
+    "imsid": 744235,
+    "monitored": true,
+    "name": "GRID5K-02234",
+    "scid": "975af3bd-a397-49cc-8065-88e13f9f800a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02234",
+    "speed": 343597383680,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "1/1/c25/1"
+      },
+      {
+        "addresses": [
+          "62.40.125.170/31",
+          "2001:798:18:10aa::11/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-20.100"
+      }
+    ],
+    "imsid": 669674,
+    "monitored": true,
+    "name": "DFN-AP2-400G-1",
+    "scid": "975d5c74-2359-4e29-81f7-34397dbee8e7",
+    "service_type": "ETHERNET",
+    "sid": "GS-00453",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 728949,
+    "monitored": true,
+    "name": "TAR-TAR-LAG",
+    "scid": "977a37ee-b099-472a-881e-394f9bb38472",
+    "service_type": "ETHERNET",
+    "sid": "GA-02352",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EENET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.53/30",
+          "2001:798:1::41/126"
+        ],
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "lag-20.200"
+      }
+    ],
+    "imsid": 746448,
+    "monitored": true,
+    "name": "EENET-AP1-IAS",
+    "scid": "977c1df1-97f8-4e9b-a373-59f68fc961cb",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00568",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662324,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-10GBE-008(GEANT)",
+    "scid": "97920589-e14b-4f37-84aa-d7b49552ff70",
+    "service_type": "ETHERNET",
+    "sid": "GA-01561",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 746140,
+    "monitored": true,
+    "name": "LON2-PAR-ROLR-LAG",
+    "scid": "97c84b65-35e7-4bb3-8302-937ea8918d3e",
+    "service_type": "ETHERNET",
+    "sid": "GA-50068",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30.3002"
+      },
+      {
+        "addresses": [
+          "62.40.106.91/29",
+          "2001:798:bb:9::3/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "irb.3002"
+      }
+    ],
+    "imsid": 712150,
+    "monitored": false,
+    "name": "PS-LATENCY-NETWORK-PAR-FR",
+    "scid": "97d2f1b1-a483-4737-a2f5-a42a803e6bd1",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00313",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.9"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240595"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4086"
+      }
+    ],
+    "imsid": 744263,
+    "monitored": true,
+    "name": "MSEFGOV-01132",
+    "scid": "981b4457-5638-489b-b34d-bc90993efcff",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01132",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NETHERLIGHT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.701"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.701"
+      }
+    ],
+    "imsid": 736101,
+    "monitored": false,
+    "name": "AMS-AMS-NETHERLIGHT-RARE-9952733",
+    "scid": "9827f13b-e691-4c0f-90b4-ba2fac8512f5",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00626",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMT1.AMS.NL",
+        "port": "AE1.10"
+      },
+      {
+        "addresses": [
+          "62.40.98.118/31",
+          "2001:798:cc:1::c1/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae7.10"
+      }
+    ],
+    "imsid": 744359,
+    "monitored": true,
+    "name": "AMS-AMS-AMT-RELAYLINK",
+    "scid": "9835c83b-698e-424d-9f5c-2ce55aa04b72",
+    "service_type": "SERVER LINK",
+    "sid": "GS-02305",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/1/4.1627"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.1627"
+      }
+    ],
+    "imsid": 736637,
+    "monitored": false,
+    "name": "GEN-PAR-SCION-SCION-INTERNET2-1",
+    "scid": "983bd0c5-b104-4588-9883-63090595a48d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02297",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "LAT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.kau.lt.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 746517,
+    "monitored": true,
+    "name": "LAT-AP2-LAG",
+    "scid": "9872666b-3b5c-431f-ac3e-42d979418bcb",
+    "service_type": "ETHERNET",
+    "sid": "GA-02074",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661478,
+    "monitored": false,
+    "name": "PAR-GROOVE-2-MANAGEMENT",
+    "scid": "987b97dd-5354-45f7-86d6-c982f7fd04c8",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00275",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae24"
+      }
+    ],
+    "imsid": 719259,
+    "monitored": true,
+    "name": "UK-ORACLE-IAS-LAG",
+    "scid": "987c3d30-3dde-4ea3-8fd0-946278c26264",
+    "service_type": "ETHERNET",
+    "sid": "GA-02082",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EENET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 746437,
+    "monitored": true,
+    "name": "EENET-AP1-LAG",
+    "scid": "98b9312c-12e8-4ffd-a1b5-adabb93dd1cd",
+    "service_type": "ETHERNET",
+    "sid": "GA-02053",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.177/30",
+          "2001:798:23:10aa::1/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-22.320"
+      }
+    ],
+    "imsid": 747601,
+    "monitored": true,
+    "name": "PIONIER-AP2",
+    "scid": "98d4b8ea-6b9d-44a0-be08-96b26cfbe6ac",
+    "service_type": "GEANT IP",
+    "sid": "GS-00496",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662196,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-1GBE-008(ETH)",
+    "scid": "99223166-d39a-44b4-b432-99826d1b4b09",
+    "service_type": "ETHERNET",
+    "sid": "GA-01648",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 720343,
+    "monitored": true,
+    "name": "FR-ORANGE-LL #1",
+    "scid": "9930c564-c59c-4b2d-ba73-86811cffa2d2",
+    "service_type": "ETHERNET",
+    "sid": "GA-01389",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-0/0/4"
+      }
+    ],
+    "imsid": 658591,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-024(ETH)",
+    "scid": "993a9c60-52b3-4503-95e9-45b135a5fede",
+    "service_type": "ETHERNET",
+    "sid": "GA-01257",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708158,
+    "monitored": false,
+    "name": "NETRONOME-IDRAC-LON2-UK",
+    "scid": "99404c1f-776f-4e52-a896-5c469d6521b6",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00189",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [],
+    "imsid": 712371,
+    "monitored": true,
+    "name": "MD-VPN-VRR-PARIS-PSNC-PL",
+    "scid": "994d2974-f5c1-475a-95f5-7479f896c4cd",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01049",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.cor.ie.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 738857,
+    "monitored": true,
+    "name": "COR-LON2-LAG",
+    "scid": "999bff17-ee62-4159-b308-f628b969d11c",
+    "service_type": "ETHERNET",
+    "sid": "GA-02387",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURFNET"
+    ],
+    "endpoints": [],
+    "imsid": 709774,
+    "monitored": true,
+    "name": "SURFNET EUMETCAST AP1",
+    "scid": "999edf24-acea-45c5-9e12-017994f4c46a",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01118",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.bud.hu - Telia Multicast Traffic",
+    "scid": "99ad5f17-7ef9-48bb-8809-27ac0b2a0701",
+    "service_type": null,
+    "sid": "DS-40475",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.409"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.6"
+      }
+    ],
+    "imsid": 708369,
+    "monitored": true,
+    "name": "REDIRIS-USC-EXPRESSROUTE-VLAN409",
+    "scid": "99b3ff19-c603-4bb9-b3f9-baa332d17668",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01167",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.1"
+      }
+    ],
+    "imsid": 709259,
+    "monitored": true,
+    "name": "NEA3R-LAG",
+    "scid": "99cad702-0337-407d-8ee8-99944be56e9f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01970",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661249,
+    "monitored": false,
+    "name": "PS-MIL2-IT-MANAGEMENT",
+    "scid": "99eab051-56a3-4ef8-9d1f-77ef1af8d5f8",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00336",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lju.si.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 745704,
+    "monitored": true,
+    "name": "ARNES-AP1-LAG",
+    "scid": "99fae9f9-ebd0-4249-b514-debd4f8c53c7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01742",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.152/31",
+          "2001:798:111:1::2d/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae13.111"
+      }
+    ],
+    "imsid": 730103,
+    "monitored": true,
+    "name": "ESNET-GEN-LHCONE",
+    "scid": "9a256c19-4882-49c8-981e-cf901d29049c",
+    "service_type": "L3-VPN",
+    "sid": "GS-00820",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663209,
+    "monitored": false,
+    "name": "FRANKFURT-DRAC",
+    "scid": "9a4ac853-8812-4a33-86cb-5ef077169a75",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00179",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 724614,
+    "monitored": false,
+    "name": "GEN-LON-400G-IPTRUNK",
+    "scid": "9ad82e63-c60d-4df7-83df-02775669cc5f",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02229",
+    "speed": 429496729600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:3508"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-34173"
+      }
+    ],
+    "imsid": 747534,
+    "monitored": false,
+    "name": "BRU-HAM-02519",
+    "scid": "9addc483-3867-425e-b25d-095b96d2ceaf",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02519",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 708924,
+    "monitored": true,
+    "name": "BIL-POR-LAG",
+    "scid": "9affe5a5-f371-4a4e-8ecc-610008067eb7",
+    "service_type": "ETHERNET",
+    "sid": "GA-02077",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732387,
+    "monitored": true,
+    "name": "LONDON-LONDON-1GBE-011(GEANT)",
+    "scid": "9b0b2c64-68d8-4bb2-a8cc-11c2f3bf703a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01471",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/2/6"
+      }
+    ],
+    "imsid": 727934,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-011(GEANT)",
+    "scid": "9b10ab6d-ac6a-4999-ab32-b81bd54413fd",
+    "service_type": "ETHERNET",
+    "sid": "GA-01393",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743396,
+    "monitored": true,
+    "name": "THE-THE-MGMT-IPTRUNK",
+    "scid": "9b6752b2-887c-4702-a4d0-a4401922f06c",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02627",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 729433,
+    "monitored": true,
+    "name": "BRA-BRA-LAG",
+    "scid": "9bedca61-682b-4dc8-822d-a643f0b39986",
+    "service_type": "ETHERNET",
+    "sid": "GA-02148",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [],
+    "imsid": 712388,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-GARR-2-IT",
+    "scid": "9c192536-832f-4179-aa7f-0677afbbd90e",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01043",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "lon-lon2_GEANTOpen_INTERNET2-SINET_06002",
+    "scid": "9c4971b5-b8d9-49f6-a0c7-9ffa003cb612",
+    "service_type": null,
+    "sid": "DS-33151",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679313,
+    "monitored": false,
+    "name": "NE-ESXI-FRA-DE-TNMS-VLAN11",
+    "scid": "9c5d3e38-d735-47be-ab54-8aebf71a3971",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00257",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661735,
+    "monitored": false,
+    "name": "PS-LON2-UK-MANAGEMENT",
+    "scid": "9d0a3d9b-d9e9-4d2d-93c9-c05956790bec",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00325",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.189/30"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.10"
+      }
+    ],
+    "imsid": 732666,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-INPE",
+    "scid": "9d127fd3-05d2-40a9-9eea-0a236f1ee65f",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01080",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/0/6"
+      }
+    ],
+    "imsid": 658905,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-060(ETH)",
+    "scid": "9d24ca58-1eb8-4465-89d7-b1b6ab69e62c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01318",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "CERN-GVA-ExpressRoute-VLAN496",
+    "scid": "9d5f6dbd-cca7-449a-998d-803f720ddc96",
+    "service_type": null,
+    "sid": "DS-52997",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [],
+    "imsid": 735201,
+    "monitored": true,
+    "name": "GRNET-AP1-LAG",
+    "scid": "9d857ce8-3384-43a3-86f0-79df2425f0fa",
+    "service_type": "ETHERNET",
+    "sid": "DA-01929",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.21.4.1/24"
+        ],
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae1.998"
+      }
+    ],
+    "imsid": 712190,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-POR-PT",
+    "scid": "9d8d7def-8883-4db7-8d7a-34b17ad0efff",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00158",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 738848,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-LJU-SI",
+    "scid": "9da73917-07db-47be-8a7e-36d683c9ddec",
+    "service_type": "SERVER LINK",
+    "sid": "GS-??????",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "et-8/0/2"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae13"
+      }
+    ],
+    "imsid": 733499,
+    "monitored": true,
+    "name": "RENATER 100GB-LL4",
+    "scid": "9dd89ef5-b26a-4f63-aa08-ab3a3b0b9de1",
+    "service_type": "ETHERNET",
+    "sid": "GA-01549",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 745053,
+    "monitored": true,
+    "name": "LJU-LJU-IPTRUNK",
+    "scid": "9df51263-91e8-466c-92e8-d836ea61856a",
+    "service_type": "IP TRUNK",
+    "sid": "GS-50057",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae17"
+      }
+    ],
+    "imsid": 658659,
+    "monitored": false,
+    "name": "LON2-PRD-ESX11-VM-TRAFFIC",
+    "scid": "9df568bd-ca1a-4c27-b183-f1d4fbfb178b",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01705",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.198/31",
+          "2001:798:1::1a5/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae14.333"
+      }
+    ],
+    "imsid": 733815,
+    "monitored": true,
+    "name": "CYNET-AP1-IAS",
+    "scid": "9e0297f7-e544-48f7-97f3-f3476967ff78",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-02442",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [],
+    "imsid": 669436,
+    "monitored": true,
+    "name": "INEX-10G-3",
+    "scid": "9e0b5a24-1201-4f58-a9ef-8672355a66d3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01639",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ROEDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.248/31",
+          "2001:798:99:1::d9/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae21.100"
+      }
+    ],
+    "imsid": 679571,
+    "monitored": true,
+    "name": "ROEDUNET-AP2",
+    "scid": "9e27aae3-41f4-4bc5-8159-718a51569501",
+    "service_type": "GEANT IP",
+    "sid": "GS-00510",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FACEBOOK"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae14"
+      }
+    ],
+    "imsid": 738663,
+    "monitored": true,
+    "name": "VIE-FACEBOOK-LAG-1",
+    "scid": "9e6e1a2a-afb6-47d2-a9c8-0a4828adac66",
+    "service_type": "ETHERNET",
+    "sid": "GA-01852",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ge-0/3/2.402"
+      }
+    ],
+    "imsid": 661430,
+    "monitored": false,
+    "name": "VIE-GROOVE-2-MANAGEMENT",
+    "scid": "9e757aa2-31b7-4a9d-801c-5d6ba551c72c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00383",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.kie.ua.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 740198,
+    "monitored": true,
+    "name": "KIE-POZ-LAG",
+    "scid": "9e8a8143-bdee-431e-80e8-6b8d01d9ba82",
+    "service_type": "ETHERNET",
+    "sid": "GA-02026",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708991,
+    "monitored": false,
+    "name": "EUMETSAT-GRE-DWD",
+    "scid": "9e8cdad7-50a8-4cb6-ab61-c1e3a503eff7",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01075",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.184/31",
+          "2001:798:111:1::31/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae11.111"
+      }
+    ],
+    "imsid": 743292,
+    "monitored": true,
+    "name": "DFN-AP1-LHCONE",
+    "scid": "9eac97b5-b3a8-4031-9a50-6925259a3cbf",
+    "service_type": "L3-VPN",
+    "sid": "GS-00816",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.210/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.26"
+      }
+    ],
+    "imsid": 736888,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-UTWENTE",
+    "scid": "9ee39dd4-eb34-41f1-a4bd-6de95361aca8",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-02448",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "BUD.KIFU.OOB.ACCESS.ROUTER",
+        "port": "ETH"
+      },
+      {
+        "equipment": "TS1.BUD.HU.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 677556,
+    "monitored": true,
+    "name": "BUD OOB LINK",
+    "scid": "9efa712a-81f8-4a05-831d-d5fca0d48a62",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00396",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.vie.at.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 740946,
+    "monitored": true,
+    "name": "MIL2-VIE-LAG",
+    "scid": "9efecc9d-f8d5-4fcb-8d4d-8e8b9e864fa5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01854",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "GEN01-GRV4",
+        "port": "1/2/5"
+      },
+      {
+        "equipment": "AMS01-GRV2",
+        "port": "1/2/5"
+      }
+    ],
+    "imsid": 739639,
+    "monitored": true,
+    "name": "AMS-GEN1-SURF-24056-2",
+    "scid": "9f21fd55-2923-4c07-b5f4-9b103cc5d50b",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02534",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 703027,
+    "monitored": true,
+    "name": "SOF-VIE-LAG",
+    "scid": "9f25c285-dcd2-483f-9145-34c6bac8229e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01855",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [],
+    "imsid": 736762,
+    "monitored": false,
+    "name": "EUMET-JEUNO-LON-CLPK-16027",
+    "scid": "9f299c1e-d893-417a-a6df-e70bee94a01b",
+    "service_type": "EUMETSAT INTERNATIONAL",
+    "sid": "GS-01092",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [],
+    "imsid": 709298,
+    "monitored": false,
+    "name": "GEN-LON-MISC-SWITCH-INTERNET2-18045",
+    "scid": "9f55eb6f-3f83-4260-91c3-1e1b2f3e1377",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00711",
+    "speed": 536870912000,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 744408,
+    "monitored": false,
+    "name": "ZAG-ZAG-IPTRUNK",
+    "scid": "9f6dcc3a-a075-415b-b4fd-ff1c2e1f6cee",
+    "service_type": "IP TRUNK",
+    "sid": "GS-50045",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [],
+    "imsid": 712407,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-RENATER-FR",
+    "scid": "9fac3f99-40ab-4daa-8fcd-bd89e36177a6",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01030",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "lon-lon_GEANTOPEN_NORDUNET-TENET_18075",
+    "scid": "9fc8c366-35ff-42cd-a177-cbc5bc61dc2e",
+    "service_type": null,
+    "sid": "DS-43529",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 712357,
+    "monitored": true,
+    "name": "FCCN-AP2-LAG",
+    "scid": "a0335d99-4571-4769-8377-590ce191c564",
+    "service_type": "ETHERNET",
+    "sid": "GA-02072",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "UOM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.128/31",
+          "2001:798:1::9d/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae19.333"
+      }
+    ],
+    "imsid": 720397,
+    "monitored": true,
+    "name": "UOM-AP2-100G-IAS",
+    "scid": "a0728b5d-5a68-4b81-8c38-6360a1b0ff62",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-02165",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [],
+    "imsid": 709759,
+    "monitored": true,
+    "name": "KIFU EUMETCAST AP2",
+    "scid": "a0995ce1-d736-4217-a0ab-91cc913e1825",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01112",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 740788,
+    "monitored": true,
+    "name": "BUD-VIE-LAG",
+    "scid": "a09dda66-6143-4e0a-a4b9-deb8db939104",
+    "service_type": "ETHERNET",
+    "sid": "GA-01907",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 701541,
+    "monitored": true,
+    "name": "AMS-LON-LAG",
+    "scid": "a09f0004-8b07-406e-b417-3dfd82e7a749",
+    "service_type": "ETHERNET",
+    "sid": "GA-01833",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/40"
+      }
+    ],
+    "imsid": 717050,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-005(GEANT)",
+    "scid": "a0b6b955-bdc4-4170-a324-6af417268420",
+    "service_type": "ETHERNET",
+    "sid": "GA-01665",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ams-bru_Belnet_iMINDS-GTS_15002",
+    "scid": "a0c2e873-cce4-4e40-9da4-dcd88ae08580",
+    "service_type": null,
+    "sid": "DS-28665",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.156/31",
+          "2001:798:cc:1::f9/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-4.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.157/31",
+          "2001:798:cc:1::fa/126"
+        ],
+        "hostname": "rt0.poz.pl.geant.net",
+        "interface": "lag-4.0"
+      }
+    ],
+    "imsid": 740148,
+    "monitored": true,
+    "name": "HAM-POZ-IPTRUNK",
+    "scid": "a0d133c9-4497-4d9d-bf01-3993cb69217e",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02339",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "WP6T3"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-11/0/0"
+      }
+    ],
+    "imsid": 659088,
+    "monitored": true,
+    "name": "PARIS-BMS-SRV4-10GBE-001",
+    "scid": "a0f039ab-d90d-4271-bcb8-ab4a96687db6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01381",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.3"
+      },
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.412"
+      }
+    ],
+    "imsid": 707138,
+    "monitored": true,
+    "name": "REDIRIS-UCLM-EXPRESSROUTE-VLAN412",
+    "scid": "a0f73cb8-d5bf-4b4f-baf7-2cd94ff3acac",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01164",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx2.am.office.geant.net",
+        "interface": "ge-0/0/2"
+      },
+      {
+        "addresses": [
+          "145.145.4.187/31",
+          "2001:610:fc7:0:145:145:4:187/127"
+        ],
+        "hostname": "srx2.am.office.geant.net",
+        "interface": "ge-0/0/2.0"
+      }
+    ],
+    "imsid": 708260,
+    "monitored": false,
+    "name": "SRX2-AMS-TO-SURFNET-SECONDARY",
+    "scid": "a1015a70-0db4-4c21-bc9b-b4dcb63771a9",
+    "service_type": "CORPORATE",
+    "sid": "GS-00002",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.lis.pt - Traffic - ae10 - LAG CUSTOMER FCT SRF9928603 | aka FCCN",
+    "scid": "a108c692-9c44-4667-9d7e-b0ece3419f14",
+    "service_type": null,
+    "sid": "GA-01765",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 731512,
+    "monitored": false,
+    "name": "NORDUNET-LAUREA-EXPRESSROUTE-VLAN3901",
+    "scid": "a10eeca9-66a8-48f3-a1a6-0dd814acdbec",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01152",
+    "speed": 118111600640,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.85/30",
+          "2001:798:1::69/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae18.333"
+      }
+    ],
+    "imsid": 734862,
+    "monitored": true,
+    "name": "KIFU-AP2-IAS",
+    "scid": "a11214f3-cb4f-47fe-a55f-85877a35cc58",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00576",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "AfgREN AP1 IAS",
+    "scid": "a13afd7e-a798-40ad-b530-30e380f853c3",
+    "service_type": null,
+    "sid": "DS-40165",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.217/30",
+          "2001:0798:0014:10aa::9/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae11.100"
+      }
+    ],
+    "imsid": 743295,
+    "monitored": true,
+    "name": "DFN-AP1",
+    "scid": "a13b95b3-aa03-496e-9c8b-acc50fbacb99",
+    "service_type": "GEANT IP",
+    "sid": "GS-00452",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 740147,
+    "monitored": true,
+    "name": "POZ-POZ-LAG",
+    "scid": "a13bc58d-b6d4-4356-9583-96669d1ad485",
+    "service_type": "ETHERNET",
+    "sid": "GA-02526",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:3903"
+      }
+    ],
+    "imsid": 747628,
+    "monitored": true,
+    "name": "AMS-HAM-MSE-01151",
+    "scid": "a14205cc-9bb6-421c-a796-2b1195f41e56",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-01151",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 707340,
+    "monitored": true,
+    "name": "LIS-POR-LAG",
+    "scid": "a147c6bc-88ae-41f3-8a49-93083ef267a8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01787",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 738841,
+    "monitored": true,
+    "name": "LON2-LON2-800G-LAG",
+    "scid": "a1518382-42c3-4387-ad7b-070f2b02a342",
+    "service_type": "ETHERNET",
+    "sid": "GA-02468",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 703050,
+    "monitored": true,
+    "name": "HAM-TAL-LAG",
+    "scid": "a1639b57-1dbc-4554-a726-a1e88e875313",
+    "service_type": "ETHERNET",
+    "sid": "GA-01895",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [],
+    "imsid": 709755,
+    "monitored": true,
+    "name": "GRNET EUMETCAST AP2",
+    "scid": "a175ebed-8b61-4433-aac6-e28fc5b02bff",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01108",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "UBUNTUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/3/2.401"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.401"
+      }
+    ],
+    "imsid": 709304,
+    "monitored": true,
+    "name": "LON-LON-MISC-UBUNTUNET-CANARIE-170351",
+    "scid": "a181a454-92a0-4415-887a-f88e829e9778",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00727",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [],
+    "imsid": 709744,
+    "monitored": true,
+    "name": "CESNET EUMETCAST AP2",
+    "scid": "a1ac42e6-b6da-493e-b73c-f364d9b2b3c6",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01100",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.121/30",
+          "2001:798:1::95/126"
+        ],
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.333"
+      }
+    ],
+    "imsid": 660626,
+    "monitored": true,
+    "name": "PIONIER-AP1-IAS",
+    "scid": "a1bfe136-6c25-4349-8ba3-46d23c2e76e1",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00539",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.229/30",
+          "2001:0798:0029:10aa::9/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.212"
+      }
+    ],
+    "imsid": 661489,
+    "monitored": true,
+    "name": "FR-ESNET",
+    "scid": "a1cdca5b-85e1-45a0-85dc-688ffdacc959",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00878",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "pwe-113015"
+      },
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-22:3015"
+      }
+    ],
+    "imsid": 747355,
+    "monitored": true,
+    "name": "GEANT_EPIPE_113015",
+    "scid": "a1e14ab7-d48d-444b-99ff-9357dd028650",
+    "service_type": "ETHERNET",
+    "sid": "GS-00690",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 659040,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-1GBE-010(ETH)",
+    "scid": "a1e3c639-3ac5-4e04-9e7d-3b09d3aa1218",
+    "service_type": "ETHERNET",
+    "sid": "GA-01441",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662947,
+    "monitored": false,
+    "name": "GEN-GROOVE-2",
+    "scid": "a1fabce4-772f-4453-bcda-726ac1e1f65c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00183",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732265,
+    "monitored": true,
+    "name": "ZAGREB 1-ZAGREB 1-1GBE-026(GEANT)",
+    "scid": "a20aab85-341e-4c78-96eb-0fb927cb79f1",
+    "service_type": "ETHERNET",
+    "sid": "GA-01492",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663246,
+    "monitored": false,
+    "name": "PS-DUB-IE-IDRAC-VLAN23",
+    "scid": "a223642b-be91-4fcb-8845-fff522a5a267",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00296",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.180/31"
+        ],
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.88"
+      }
+    ],
+    "imsid": 721130,
+    "monitored": true,
+    "name": "EUMET-BUCC-BIL-20117",
+    "scid": "a240aa5d-cc1d-4b60-9f7a-11637797c670",
+    "service_type": "GEANT IP",
+    "sid": "GS-00458",
+    "speed": 430570471424,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661499,
+    "monitored": false,
+    "name": "LON-GROOVE-2",
+    "scid": "a249a0fc-3b67-48dc-b1a4-31c5d45ab554",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00230",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "KREONET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.8/31",
+          "2001:798:111:1::89/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.111"
+      }
+    ],
+    "imsid": 734566,
+    "monitored": false,
+    "name": "NL-KREONET-LHCONE",
+    "scid": "a26cad83-788b-441d-a3d8-aa5efd763613",
+    "service_type": "L3-VPN",
+    "sid": "GS-00837",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "RedIRIS-GN-XiFi-VPN-Proxy-Marseille-L3VPN",
+    "scid": "a29773b4-bf38-4e13-a220-3cf690c4ee22",
+    "service_type": null,
+    "sid": "DS-27547",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 745431,
+    "monitored": false,
+    "name": "ATH2-ATH2-MGMT-IPTRUNK",
+    "scid": "a29c38c4-3fcf-48c6-a87c-ee6da97f0368",
+    "service_type": "IP TRUNK",
+    "sid": "GS-50006",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 710811,
+    "monitored": true,
+    "name": "BUC-FRA-LAG",
+    "scid": "a2a6e1c9-a992-4edb-8921-7a2d5ee8b803",
+    "service_type": "ETHERNET",
+    "sid": "GA-01995",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "192.168.150.2/30"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.500"
+      }
+    ],
+    "imsid": 677814,
+    "monitored": false,
+    "name": "INTERNET2-TESTVLAN-RTT",
+    "scid": "a2d826bf-fe04-48a3-b0e2-36fa514d77dc",
+    "service_type": "GEANT IP",
+    "sid": "GS-00475",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 742923,
+    "monitored": true,
+    "name": "BRA-BRA-MGMT-LAG",
+    "scid": "a2ec23d0-56dd-4896-84df-c01501760271",
+    "service_type": "ETHERNET",
+    "sid": "GA-02600",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.92/31",
+          "2001:798:cc:1::6d/126"
+        ],
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.93/31",
+          "2001:798:cc:1::6e/126"
+        ],
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae3.0"
+      }
+    ],
+    "imsid": 708705,
+    "monitored": true,
+    "name": "LIS-POR-IPTRUNK",
+    "scid": "a3005403-d0de-4025-b0dd-1e8a35ac3962",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00050",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "TENET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae24"
+      }
+    ],
+    "imsid": 732993,
+    "monitored": true,
+    "name": "NL-TENET-LAG",
+    "scid": "a322c093-b337-4680-a25a-1f0465b080ff",
+    "service_type": "ETHERNET",
+    "sid": "GA-02142",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.233/30"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.111"
+      }
+    ],
+    "imsid": 661194,
+    "monitored": true,
+    "name": "NORDUNET-AP1-IPV4-LHCONE",
+    "scid": "a33c7189-776e-4d9d-897c-9add7ed7e206",
+    "service_type": "L3-VPN",
+    "sid": "GS-00841",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663147,
+    "monitored": false,
+    "name": "DASHBOARD-SERVER-LON2-VLAN50",
+    "scid": "a37c049d-6265-4146-8356-9fc64cf152a9",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00113",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [],
+    "imsid": 659340,
+    "monitored": true,
+    "name": "ARNES-AP3-LAG",
+    "scid": "a3a0f413-ad56-4c50-9b14-8f055086606a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01767",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CSTNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.2000"
+      }
+    ],
+    "imsid": 738711,
+    "monitored": true,
+    "name": "CSTNET-AMS-LHCONE",
+    "scid": "a3a4e4ed-a33c-4120-afef-fe5361718758",
+    "service_type": "L3-VPN",
+    "sid": "GS-02537",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663194,
+    "monitored": false,
+    "name": "AMS-GROOVE-2-MANAGEMENT",
+    "scid": "a3aabf40-8493-4aaf-8f15-f38ce8636584",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00094",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SETCOR"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-26"
+      }
+    ],
+    "imsid": 747906,
+    "monitored": true,
+    "name": "SETCOR-HR-LAG",
+    "scid": "a3af7ce3-592e-4fd4-a0a2-91dd653e174e",
+    "service_type": "ETHERNET",
+    "sid": "GA-02000",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679156,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-024(ETH)",
+    "scid": "a3eb91fa-7d24-43f5-9e27-bf479d896dff",
+    "service_type": "ETHERNET",
+    "sid": "GA-01622",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.104.233/30"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae2.15"
+      }
+    ],
+    "imsid": 740679,
+    "monitored": true,
+    "name": "LON-EUMETSAT-SERVER-DATA-TRAFFIC",
+    "scid": "a3ee647f-7a30-461f-af23-e5c3a74ea6d9",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02313",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/1/6.1624"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.1624"
+      }
+    ],
+    "imsid": 736667,
+    "monitored": false,
+    "name": "FRA-PAR-SCION-SCION-INTERNET2-1",
+    "scid": "a4109552-ba22-4eb4-b8dd-05245f4e8497",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02296",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662253,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-022(ETH)",
+    "scid": "a4456592-8c34-434f-98fe-fdf6394a6e09",
+    "service_type": "ETHERNET",
+    "sid": "GA-01608",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "AT-Microsoft LAG",
+    "scid": "a4a62413-ac98-4038-96b5-2cb1b02039b8",
+    "service_type": null,
+    "sid": "DS-37947",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ROEDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.buc.ro.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 747888,
+    "monitored": true,
+    "name": "ROEDUNET-AP1-LAG",
+    "scid": "a4bb6f71-c439-4238-8305-2c490249c613",
+    "service_type": "ETHERNET",
+    "sid": "GA-01934",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [],
+    "imsid": 708231,
+    "monitored": false,
+    "name": "LON-EEX-ESNET-1G",
+    "scid": "a4e49a3d-44be-4cf5-a2db-5d61c2865483",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00887",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.200/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.18"
+      }
+    ],
+    "imsid": 732669,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-IMPA",
+    "scid": "a4eeaed6-709e-4797-ac64-ab1c83a0af32",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01079",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/6"
+      }
+    ],
+    "imsid": 732310,
+    "monitored": true,
+    "name": "FRANKFURT 15-FRANKFURT 15-10GBE-049(GEANT)",
+    "scid": "a4f32340-4b35-4b4a-b1b3-7b15bf515bb4",
+    "service_type": "ETHERNET",
+    "sid": "GA-02198",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CLOUDFERRO"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "45.92.241.127/31",
+          "2a01:9aa0:beef::127/127"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae35.0"
+      }
+    ],
+    "imsid": 708235,
+    "monitored": true,
+    "name": "DE-CLOUDFERRO-IAS",
+    "scid": "a4f4719c-a4fc-417f-b0df-545dd950111d",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00603",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx1.am.office.geant.net",
+        "interface": "ge-0/0/15"
+      },
+      {
+        "addresses": [
+          "145.145.4.185/31",
+          "2001:610:fc7:0:145:145:4:185/127"
+        ],
+        "hostname": "srx1.am.office.geant.net",
+        "interface": "ge-0/0/15.0"
+      }
+    ],
+    "imsid": 708298,
+    "monitored": false,
+    "name": "SRX1-AMS-TO-SURFNET-PRIMARY",
+    "scid": "a53344f7-59bc-40f0-84a8-9602bf99098d",
+    "service_type": "CORPORATE",
+    "sid": "GS-00001",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-114016"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:705"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-114016"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-22:705"
+      }
+    ],
+    "imsid": 744022,
+    "monitored": true,
+    "name": "GEANT_EPIPE_114016",
+    "scid": "a5534a2b-2df7-414c-aa73-fd4d75992a68",
+    "service_type": "ETHERNET",
+    "sid": "GS-00668",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "UBUNTUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.802"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae17.802"
+      }
+    ],
+    "imsid": 735619,
+    "monitored": true,
+    "name": "AMS-LON-MISC-UBUNTUNET-INTERNET2-170342",
+    "scid": "a558186a-95f8-4346-88c0-f155536f10f8",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00647",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:3060"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-125006"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae23.3060"
+      }
+    ],
+    "imsid": 744345,
+    "monitored": true,
+    "name": "OFCFODMOB-02630",
+    "scid": "a5a37a30-24f5-44f2-976e-61eb41565abf",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02630",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/4.1623"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.1623"
+      }
+    ],
+    "imsid": 736659,
+    "monitored": false,
+    "name": "PAR-PAR-SCION-INTERNET2-SCION-2",
+    "scid": "a5ceb962-4a11-43a5-b568-ce9b94899a0a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02309",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 706154,
+    "monitored": false,
+    "name": "MIL2 OOB LINK",
+    "scid": "a5ff5567-1125-4de9-b016-2fd7cdfdc3e7",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00410",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658515,
+    "monitored": false,
+    "name": "730XD-3-VSAN-TRAFFIC-LAG",
+    "scid": "a6410ba1-5717-46cc-b0a7-12097816639f",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01677",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "UOM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.74/31",
+          "2001:798:99:1::115/126"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae11.100"
+      }
+    ],
+    "imsid": 722110,
+    "monitored": true,
+    "name": "UOM-AP1",
+    "scid": "a644191f-4b58-4549-8bef-d6ff8c40f226",
+    "service_type": "GEANT IP",
+    "sid": "GS-00519",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CAREN"
+    ],
+    "endpoints": [],
+    "imsid": 662501,
+    "monitored": true,
+    "name": "DE-CAREN-LAG",
+    "scid": "a661ff93-b40d-4df3-8aeb-7da22c002976",
+    "service_type": "ETHERNET",
+    "sid": "GA-01942",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-5"
+      }
+    ],
+    "imsid": 747403,
+    "monitored": true,
+    "name": "COR-PAR-LAG",
+    "scid": "a6a14251-41a4-4b8d-95d5-b6537c5b3348",
+    "service_type": "ETHERNET",
+    "sid": "GA-02479",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "xe-7/0/0"
+      }
+    ],
+    "imsid": 742610,
+    "monitored": true,
+    "name": "MAD-MAD-MGMT-LINK-1",
+    "scid": "a6bf1f39-68b7-4d24-8a2f-22f6548e48c9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01661",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "2001:798:111:1::5/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.116"
+      }
+    ],
+    "imsid": 661664,
+    "monitored": false,
+    "name": "RENATER-AP1-IPV6-LHCONE",
+    "scid": "a6eb401d-8a68-42d2-8158-6119257850e8",
+    "service_type": "L3-VPN",
+    "sid": "GS-00854",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661572,
+    "monitored": false,
+    "name": "SDX-L2-PILOT-BR51-OF-P3-MIL2",
+    "scid": "a6f77830-ec28-46f9-b5a5-e8ce976f38fe",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00761",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.lon.uk - DE-NISN - Multicast Traffic",
+    "scid": "a73f487f-b9ff-40e1-b770-80ddae228d95",
+    "service_type": null,
+    "sid": "DS-11633",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.buc.ro.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 745567,
+    "monitored": true,
+    "name": "BUC-BUC-MGMT-LAG",
+    "scid": "a7509de9-1932-4c0b-a413-e24a4b7e68e7",
+    "service_type": "ETHERNET",
+    "sid": "GA-50062",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.144/31",
+          "2001:798:cc::e1/126"
+        ],
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.145/31",
+          "2001:798:cc::e2/126"
+        ],
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-3.0"
+      }
+    ],
+    "imsid": 746141,
+    "monitored": true,
+    "name": "LON2-PAR-ROLR-IPTRUNK$GS-50066",
+    "scid": "a78018dc-65d8-458d-86c8-d2f821983bf8",
+    "service_type": "IP TRUNK",
+    "sid": "GS-50066",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 658877,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-1GBE-007(ETH)",
+    "scid": "a7830e42-93f2-4d00-8508-9788dcdfafb7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01434",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae20.420"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae11.420"
+      }
+    ],
+    "imsid": 724886,
+    "monitored": true,
+    "name": "FRA-GEN-DFN-NKN-22079",
+    "scid": "a7a623f6-90f0-4997-b9f7-2b1de49e23ae",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02210",
+    "speed": 450971566080,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/2.2210"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.2210"
+      }
+    ],
+    "imsid": 736739,
+    "monitored": true,
+    "name": "LON-PAR-GEANTOPEN-HBKU-INTERNET2-190091",
+    "scid": "a7b7c01b-f359-470b-afa9-69c9f236d7f6",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00967",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663141,
+    "monitored": false,
+    "name": "AMS-SINET-INTERNET-ACCESS",
+    "scid": "a7c775cc-0d11-4c73-8fed-aab5148c43bb",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00098",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663172,
+    "monitored": false,
+    "name": "GIDP-BUD-HU-VLAN93",
+    "scid": "a7d36adf-1fe0-44a2-afd9-d96b87bf702b",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00188",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661231,
+    "monitored": false,
+    "name": "KVMOIP-ATH2-GR",
+    "scid": "a7fa137c-d28b-44c0-89d8-62603b7c367f",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00217",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 729572,
+    "monitored": true,
+    "name": "LJU01-MIL2-IPTRUNK",
+    "scid": "a82a1580-c1b0-453e-b53c-44e0cbf4c60f",
+    "service_type": "IP TRUNK",
+    "sid": "DS-00032",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.21.22.1/24"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae1.998"
+      },
+      {
+        "addresses": [
+          "62.40.117.14/31"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae1.998"
+      }
+    ],
+    "imsid": 729100,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-FRA-DE",
+    "scid": "a8302418-4619-41bf-9c31-9182e70709eb",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00151",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 744407,
+    "monitored": true,
+    "name": "ZAG-ZAG-MGMT-LAG",
+    "scid": "a83fa432-e088-4946-9dc5-981b5f78316b",
+    "service_type": "ETHERNET",
+    "sid": "GA-50047",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-0/0/1"
+      }
+    ],
+    "imsid": 658359,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-004(ETH)",
+    "scid": "a8838a0f-8c0a-405a-975e-4d5750d08e7d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01253",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0"
+      }
+    ],
+    "imsid": 712106,
+    "monitored": true,
+    "name": "LAG-QFX.PAR.FR_AE0",
+    "scid": "a8ca2183-dd11-4476-b725-c35e6c640a95",
+    "service_type": "ETHERNET",
+    "sid": "GA-01714",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.18"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4093"
+      }
+    ],
+    "imsid": 739681,
+    "monitored": true,
+    "name": "BELNET-PREMIER-EXPRESSROUTE-VLAN4093",
+    "scid": "a8d29b87-062a-47ad-be96-c114c1cd6fde",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01127",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMT1.AMS.NL",
+        "port": "AE1.20"
+      },
+      {
+        "addresses": [
+          "83.97.90.38/31"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae7.20"
+      }
+    ],
+    "imsid": 744351,
+    "monitored": false,
+    "name": "AMS-AMS-AMT-RELAYLINK-IAS",
+    "scid": "a8f1ecdd-e452-4ccd-be49-faa493755704",
+    "service_type": "SERVER LINK",
+    "sid": "GS-02636",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661268,
+    "monitored": false,
+    "name": "LON2-GROOVE-2",
+    "scid": "a8fabcf5-9b04-4748-b51d-c9b2101fc87d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00240",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.9/30",
+          "2001:798:10:10aa::9/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-22.100"
+      }
+    ],
+    "imsid": 747838,
+    "monitored": true,
+    "name": "CARNET-AP1",
+    "scid": "a90abebc-5c17-4fe9-8d23-31712fb9e2e0",
+    "service_type": "GEANT IP",
+    "sid": "GS-00440",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.13/30",
+          "2001:798:1::11/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-20.333"
+      }
+    ],
+    "imsid": 747852,
+    "monitored": true,
+    "name": "ARNES-AP2-IAS",
+    "scid": "a928a705-e4aa-456e-a3e3-ea6ecd698db6",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00553",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "LAT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 745953,
+    "monitored": true,
+    "name": "LAT-AP1-LAG",
+    "scid": "a9382674-1185-4571-b783-45564390b5fe",
+    "service_type": "ETHERNET",
+    "sid": "GA-02073",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ge-0/3/2.21"
+      }
+    ],
+    "imsid": 661748,
+    "monitored": false,
+    "name": "HADES-VIE-AT-DRAC",
+    "scid": "a95e2b40-8dbf-43d6-9059-0325cd790cda",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00198",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ge-0/3/2"
+      }
+    ],
+    "imsid": 659059,
+    "monitored": true,
+    "name": "VIENNA-VIENNA-1GBE-006(ETH)",
+    "scid": "a9785dd1-f731-41b7-8ca9-08d520d4f7b9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01485",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CNGI-6IX"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.10/31",
+          "2001:798:111:1::a1/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-1/0/0.111"
+      }
+    ],
+    "imsid": 661398,
+    "monitored": true,
+    "name": "UK-CNGI-6IX-CERNET-LHCONE",
+    "scid": "a98466d5-82c1-4359-98ab-d3b050eb58b0",
+    "service_type": "L3-VPN",
+    "sid": "GS-00815",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [],
+    "imsid": 712144,
+    "monitored": true,
+    "name": "GEANT-CORPORATE-VIAVODAFONE-VRF",
+    "scid": "a9bfad01-08a5-4331-9f5d-9b6ff80f8d1c",
+    "service_type": "CORPORATE",
+    "sid": "GS-00465",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 739044,
+    "monitored": true,
+    "name": "FRA-FRA-800G-LAG",
+    "scid": "a9e64dc1-a71c-4818-aaf4-9272bf61f66f",
+    "service_type": "ETHERNET",
+    "sid": "GA-02459",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 746143,
+    "monitored": true,
+    "name": "LJU-MIL2-LAG",
+    "scid": "a9ff049e-d47c-4063-a72f-c360bcab9870",
+    "service_type": "ETHERNET",
+    "sid": "GA-01775",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.FRA.DE.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/2"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/2.1213"
+      },
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "pwe-120062"
+      },
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-20:1213"
+      }
+    ],
+    "imsid": 747360,
+    "monitored": false,
+    "name": "DUB-FRA-HEANET-RARE-20062",
+    "scid": "aa102f6c-4e74-40ac-8925-dd0343e7d15f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00689",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 734735,
+    "monitored": true,
+    "name": "ATH2-MIL2-LAG",
+    "scid": "aa2c87a7-9646-4d09-b168-6a2f454b6caf",
+    "service_type": "ETHERNET",
+    "sid": "DA-000197",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "AMS-HAM-SCION-GTS-20054",
+    "scid": "aa466f4f-425e-4cf7-80b8-5ea78301fdeb",
+    "service_type": null,
+    "sid": "DS-51656",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662997,
+    "monitored": true,
+    "name": "SURFNET VLAN 100 - FOR LINK TO GEANT IT VRF VIA MX1.AMS - SURFNET SERVICE ID: 5836",
+    "scid": "aa7eb1d5-6812-40f0-b6fc-a7af8dfd7c15",
+    "service_type": "ETHERNET",
+    "sid": "GS-00372",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 740146,
+    "monitored": true,
+    "name": "HAM-POZ-LAG",
+    "scid": "aa8edd2c-9e45-4b24-9a72-6bdaecdf5614",
+    "service_type": "ETHERNET",
+    "sid": "GA-02340",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662297,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10GBE-007(GEANT)",
+    "scid": "aac991d8-0363-4af1-81f2-888ada477c53",
+    "service_type": "ETHERNET",
+    "sid": "GA-01751",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 738105,
+    "monitored": true,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-019(GEANT)",
+    "scid": "aaea7fdd-77a7-4a7e-86e7-2a953c1003a5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01968",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659066,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-018(ETH)",
+    "scid": "ab1e47f4-46ce-4f33-b475-55007fac35ca",
+    "service_type": "ETHERNET",
+    "sid": "GA-01504",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 738584,
+    "monitored": true,
+    "name": "LON-LON-800G-LAG",
+    "scid": "ab39ba80-4b82-45d6-b9e7-223277434c1f",
+    "service_type": "ETHERNET",
+    "sid": "GA-02465",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMT1.FRA.DE",
+        "port": "AE1"
+      }
+    ],
+    "imsid": 744378,
+    "monitored": true,
+    "name": "FRA-AMT-LAG",
+    "scid": "ab3b2b55-98b2-451f-ae6c-f1e51151dbed",
+    "service_type": "ETHERNET",
+    "sid": "GA-02300",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/0/2"
+      }
+    ],
+    "imsid": 740086,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-10GBE-006(GEANT)",
+    "scid": "ab442769-0f3d-449b-a781-5bf65210fe8b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01538",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae32"
+      }
+    ],
+    "imsid": 720097,
+    "monitored": true,
+    "name": "FR-ORANGE-LAG-3",
+    "scid": "ab75ebca-c7cb-4c7c-8519-f2c6a3a51c6d",
+    "service_type": "ETHERNET",
+    "sid": "GA-02179",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae5"
+      }
+    ],
+    "imsid": 744731,
+    "monitored": true,
+    "name": "BUC2-CHI-LAG",
+    "scid": "ab91e089-80e9-467e-87ce-8c6f017ddd0d",
+    "service_type": "ETHERNET",
+    "sid": "GA-02018",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708278,
+    "monitored": false,
+    "name": "FLOWMON-PAR-FR-IDRAC",
+    "scid": "aba3a178-0aca-45c1-91cd-280efc25990e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00167",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11"
+      }
+    ],
+    "imsid": 659367,
+    "monitored": true,
+    "name": "PIONIER-AP1-LAG",
+    "scid": "abb1d5dc-6b67-4747-9dd4-5459a56710bc",
+    "service_type": "ETHERNET",
+    "sid": "GA-01811",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.150/31",
+          "2001:798:111:1::29/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae13.111"
+      }
+    ],
+    "imsid": 730146,
+    "monitored": true,
+    "name": "ESNET-LON-LHCONE",
+    "scid": "abc51e3b-812b-40d8-b7d3-20f41b255d32",
+    "service_type": "L3-VPN",
+    "sid": "GS-00821",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 658679,
+    "monitored": false,
+    "name": "LON2-PRD-ESX03-ESXI-TRAFFIC",
+    "scid": "abdc166d-3307-4e19-afe7-b1021a32168b",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01691",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661299,
+    "monitored": false,
+    "name": "PS-LON-UK-PSMP-BWCTL-VLAN21",
+    "scid": "abf4169e-5c61-41f3-80f7-0f646ba5a83b",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00321",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FACEBOOK"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "103.4.98.47/31",
+          "2620:0:1cff:dead:beee::105/127"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae16.0"
+      }
+    ],
+    "imsid": 738665,
+    "monitored": true,
+    "name": "FACEBOOK-32934-VIE-FC-203126783",
+    "scid": "ac0304e0-00a2-498a-9d5a-7465209de37a",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00930",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-824045"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:3504"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.2702"
+      }
+    ],
+    "imsid": 745319,
+    "monitored": true,
+    "name": "GEANT_EPIPE_824045",
+    "scid": "ac2034f1-4d6d-42b4-bddd-f1c49e399d22",
+    "service_type": "ETHERNET",
+    "sid": "GS-02487",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ge-0/2/3"
+      }
+    ],
+    "imsid": 732264,
+    "monitored": true,
+    "name": "VIENNA-VIENNA-1GBE-002(GEANT)",
+    "scid": "ac276944-85ac-4d5b-be6a-d32e66f55964",
+    "service_type": "ETHERNET",
+    "sid": "GA-01486",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659290,
+    "monitored": true,
+    "name": "LONDON-LONDON-1GBE-015(ETH)",
+    "scid": "ac2e3522-40e1-4d1b-97bb-dd481515b92b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01475",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.2709"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-224045"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-20:716"
+      }
+    ],
+    "imsid": 745409,
+    "monitored": true,
+    "name": "SLCUTH-02490",
+    "scid": "ac33812b-305f-410c-992c-4fc6ef3dd83e",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02490",
+    "speed": 171798691840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.1"
+      }
+    ],
+    "imsid": 659121,
+    "monitored": true,
+    "name": "NORDUNET-GEO-LL",
+    "scid": "ac537ea8-8eab-4e83-96fb-29a03bb6b176",
+    "service_type": "CBL1",
+    "sid": "GA-01447",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RASH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae16"
+      }
+    ],
+    "imsid": 727798,
+    "monitored": true,
+    "name": "RASH-AP1-100G-LAG",
+    "scid": "ac540183-b1ff-476a-b605-5ce8aecc527a",
+    "service_type": "ETHERNET",
+    "sid": "GA-02324",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ge-0/3/2.25"
+      }
+    ],
+    "imsid": 718923,
+    "monitored": false,
+    "name": "DDOS-DET1-VIE-AT-IDRAC",
+    "scid": "ac5c7167-50cd-43a9-ab25-a6f6d5826fb6",
+    "service_type": "SERVER LINK",
+    "sid": "GS-01284",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.5/30",
+          "2001:798:10:10aa::5/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-20.100"
+      }
+    ],
+    "imsid": 747839,
+    "monitored": true,
+    "name": "ARNES-AP2",
+    "scid": "ac74f2ce-e7ae-4296-8f64-05e3f171218d",
+    "service_type": "GEANT IP",
+    "sid": "GS-00427",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.510"
+      }
+    ],
+    "imsid": 734549,
+    "monitored": true,
+    "name": "NL-INTERNET2-VLAN510",
+    "scid": "ac87d316-bdb0-4044-b4cf-651addb274c1",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00894",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 719129,
+    "monitored": false,
+    "name": "NORDU-TO-NETHERLIGHT-TEST",
+    "scid": "ac9b7b4c-b85b-44dd-9a39-aaf2ee16d1fa",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00742",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.208/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.25"
+      }
+    ],
+    "imsid": 733837,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-UNI-OF-CHILE",
+    "scid": "aca4be6f-7d5a-48d0-8d3b-b94dc8e5cd94",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-02447",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.CHI.MD",
+        "port": "AE3"
+      }
+    ],
+    "imsid": 713247,
+    "monitored": true,
+    "name": "LAG-RT2.CHI.MD_AE2-SW1.CHI.MD_AE3",
+    "scid": "acbcff11-be99-43c9-b097-baa0ad300145",
+    "service_type": "ETHERNET",
+    "sid": "GA-02084",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 658772,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-005(ETH)",
+    "scid": "acceebf7-4a3d-40dc-a9e0-fd4f1c5109c7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01511",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.cor.ie.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 747403,
+    "monitored": true,
+    "name": "COR-PAR-LAG",
+    "scid": "ad1c671f-deb6-47ce-9ed3-984663ee7c65",
+    "service_type": "ETHERNET",
+    "sid": "GA-02478",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [],
+    "imsid": 719488,
+    "monitored": false,
+    "name": "LON-MAD-OFELIA-JISC-REDIRIS-13013",
+    "scid": "ad3485ed-b969-4532-97aa-c38feb7cb454",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00733",
+    "speed": 332859965440,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "138.44.226.9/31"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3102"
+      }
+    ],
+    "imsid": 661897,
+    "monitored": true,
+    "name": "AARNET-LON-LHCONE",
+    "scid": "ad57018a-3fa1-491e-827a-b843124c62a9",
+    "service_type": "L3-VPN",
+    "sid": "GS-00805",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.158/31",
+          "2001:798:cc:1::c5/126"
+        ],
+        "hostname": "rt0.fra.de.geant.net",
+        "interface": "lag-6.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.159/31",
+          "2001:798:cc:1::c6/126"
+        ],
+        "hostname": "rt0.pra.cz.geant.net",
+        "interface": "lag-6.0"
+      }
+    ],
+    "imsid": 740465,
+    "monitored": true,
+    "name": "FRA-PRA-IPTRUNK",
+    "scid": "ad5ac8d9-a6f1-452a-862a-cf992362cb62",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00033",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FACEBOOK"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae16"
+      }
+    ],
+    "imsid": 738662,
+    "monitored": true,
+    "name": "VIE-FACEBOOK-LAG-2",
+    "scid": "ad65cd41-e1ff-4618-9526-c210fdbafa74",
+    "service_type": "ETHERNET",
+    "sid": "GA-01863",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658669,
+    "monitored": true,
+    "name": "730XD-2-VSAN-TRAFFIC-LAG-PAR",
+    "scid": "ad7152e8-e3c2-4ec9-9b29-1294ea365581",
+    "service_type": "ETHERNET",
+    "sid": "GA-01718",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae6"
+      }
+    ],
+    "imsid": 719610,
+    "monitored": true,
+    "name": "BIL-MAD-LAG",
+    "scid": "ad8287ff-0a1e-44fd-9f90-26c0ad5a56ad",
+    "service_type": "ETHERNET",
+    "sid": "GA-02204",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 727426,
+    "monitored": true,
+    "name": "V-LAN_1003_RT2.BRU.BE_XE-0/1/0_",
+    "scid": "ad858cfc-dee8-45e0-8188-0d878e3e33e7",
+    "service_type": "ETHERNET",
+    "sid": "GS-00676",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.254.1/30"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "gr-1/3/0.0"
+      }
+    ],
+    "imsid": 717895,
+    "monitored": false,
+    "name": "FORTIGATE-TUNNEL-TO-CH-LON-UK",
+    "scid": "ad9488d1-f973-4301-81ac-25d690ddeef7",
+    "service_type": "L3-VPN",
+    "sid": "GS-02125",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NKN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.34/31",
+          "2001:798:111:1::cd/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae20.111"
+      }
+    ],
+    "imsid": 678079,
+    "monitored": true,
+    "name": "NKN-GEN-LHCONE",
+    "scid": "ae0df7b5-31d2-407d-817a-3a5a7907886e",
+    "service_type": "L3-VPN",
+    "sid": "GS-00833",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae9"
+      }
+    ],
+    "imsid": 739650,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-LAG-010(GEANT)",
+    "scid": "ae137ca3-c132-4c9e-902e-231ff0dc511b",
+    "service_type": "ETHERNET",
+    "sid": "GA-TBA",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.96/31"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae2.108"
+      }
+    ],
+    "imsid": 736093,
+    "monitored": false,
+    "name": "AMS-EUMETSAT-SERVER-DATA-TRAFFIC",
+    "scid": "ae20d05c-36bd-4a38-afd4-e15377b69d9d",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02312",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.138/31"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/2.19"
+      }
+    ],
+    "imsid": 707142,
+    "monitored": false,
+    "name": "DASHBOARD-TEST-SERVICE-LON2-VIRGIN(DO-NOT-OPEN-TICKET)",
+    "scid": "ae2605a4-a078-4811-8800-2b2d4412c3e7",
+    "service_type": "CORPORATE",
+    "sid": "GS-00006",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae49"
+      }
+    ],
+    "imsid": 745908,
+    "monitored": true,
+    "name": "GOOGLE-FRA-LAG",
+    "scid": "ae305595-159b-46ee-b7ca-fe1bb8d7c17f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01943",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "LJU-VIE-TRUNK",
+    "scid": "ae4a4d79-2019-4022-8221-bd1178a1717f",
+    "service_type": null,
+    "sid": "DS-19925",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.BUD.HU.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/7"
+      },
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/7.500"
+      },
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "xe-3/0/2.500"
+      }
+    ],
+    "imsid": 744388,
+    "monitored": false,
+    "name": "BUD-POZ-RARE-BMS8",
+    "scid": "ae4fcd56-4d4c-4521-981d-98860735981f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02629",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [],
+    "imsid": 709745,
+    "monitored": true,
+    "name": "FCCN EUMETCAST AP1",
+    "scid": "ae5d7970-892b-428e-8709-63028bd431a7",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01103",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-424046"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-20:715"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-39082"
+      }
+    ],
+    "imsid": 745450,
+    "monitored": true,
+    "name": "GEANT_EPIPE_424046",
+    "scid": "ae684268-ad51-4ffd-a1c0-b7aa5b4cdd90",
+    "service_type": "ETHERNET",
+    "sid": "GS-02500",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661196,
+    "monitored": false,
+    "name": "VM-LON2-UK-IDRACS-250",
+    "scid": "ae818e45-5e84-4021-8ec2-54a127fd4ea1",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00385",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 718936,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-ZAG-HR",
+    "scid": "ae8381e5-c76e-4d04-a77b-f25adad39b7f",
+    "service_type": "SERVER LINK",
+    "sid": "GA-01459",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ANKABUT"
+    ],
+    "endpoints": [],
+    "imsid": 720034,
+    "monitored": false,
+    "name": "ANKABUT-GEO-UK-1",
+    "scid": "aebf89ff-6183-4e33-bd7f-49c982401d5b",
+    "service_type": "GEANT OPEN PORT",
+    "sid": "GA-01836",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/1"
+      }
+    ],
+    "imsid": 662517,
+    "monitored": true,
+    "name": "PHY CONNECTION TO SRX2",
+    "scid": "aec58254-b34a-4e82-83b3-dadacf9e49a1",
+    "service_type": "ETHERNET",
+    "sid": "GA-01283",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/0/6"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/0/6.3"
+      }
+    ],
+    "imsid": 661923,
+    "monitored": true,
+    "name": "SDX-L2-HOSTC-TO-BR52",
+    "scid": "aec97668-5500-49a6-bac8-a65df11fef83",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00763",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 718916,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-POZ1-PL",
+    "scid": "aec9d26b-4160-4ed5-9a39-02786fd71b3d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-01172",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 714886,
+    "monitored": true,
+    "name": "HEANET-AP2-100G-LL1",
+    "scid": "aee66f60-c921-41d9-bda9-9f2ac824f622",
+    "service_type": "ETHERNET",
+    "sid": "GA-01666",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.101/30",
+          "2001:798:1b:10aa::5/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae10.100"
+      }
+    ],
+    "imsid": 663051,
+    "monitored": true,
+    "name": "KIFU-AP1",
+    "scid": "af143114-ae97-469b-a33f-fcf643bb1c76",
+    "service_type": "GEANT IP",
+    "sid": "GS-00481",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "equipment": "MIL02-GRV3",
+        "port": "1/1/3"
+      },
+      {
+        "equipment": "GEN02-GRV-1",
+        "port": "1/1/3"
+      }
+    ],
+    "imsid": 669632,
+    "monitored": true,
+    "name": "GEN2-MIL2-LHC-CERN-GARR-18105",
+    "scid": "af35fd01-7aac-4a08-b0dc-e26c7fcd727f",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-00798",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660431,
+    "monitored": true,
+    "name": "OCVM-LON-UK-ESXI",
+    "scid": "af3a73ca-29fb-43b4-9f9c-e3c6871826a0",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00138",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.134/31",
+          "2001:798:22::1/126"
+        ],
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20.2"
+      }
+    ],
+    "imsid": 744240,
+    "monitored": true,
+    "name": "BELNET-AP1",
+    "scid": "af59171b-0ecc-4b67-ac16-8fbe30589afd",
+    "service_type": "GEANT IP",
+    "sid": "GS-00437",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.221/30"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae14.111"
+      }
+    ],
+    "imsid": 733481,
+    "monitored": true,
+    "name": "RENATER-AP2-IPV4-LHCONE",
+    "scid": "afa8ca87-db65-4b19-8514-b5345abef9bb",
+    "service_type": "L3-VPN",
+    "sid": "GS-00855",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.83/31",
+          "2001:798:cc::8a/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.82/31",
+          "2001:798:cc::89/126"
+        ],
+        "hostname": "rt0.vie.at.geant.net",
+        "interface": "lag-3.0"
+      }
+    ],
+    "imsid": 740752,
+    "monitored": true,
+    "name": "VIE-VIE-IPTRUNK",
+    "scid": "afe48180-19e0-48c5-8c92-eac23febfab1",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02563",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.66/31",
+          "2001:798:cc:1::d1/126"
+        ],
+        "hostname": "rt0.ams.nl.geant.net",
+        "interface": "lag-9.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.67/31",
+          "2001:798:cc:1::d2/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-9.0"
+      }
+    ],
+    "imsid": 739970,
+    "monitored": true,
+    "name": "AMS-HAM-IPTRUNK",
+    "scid": "afeb63dd-fcfd-49db-9e87-29e537e6fd6b",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00010",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660640,
+    "monitored": false,
+    "name": "HADES-MIL2-IT-DRAC",
+    "scid": "aff7c214-034a-40bd-95dc-e34cf0b4db76",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00195",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.3912"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.14"
+      }
+    ],
+    "imsid": 707047,
+    "monitored": true,
+    "name": "NORDUNET-TUNI-EXPRESSROUTE-VLAN3912",
+    "scid": "b00c9ff4-6a3f-4475-af17-32042185da5f",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01162",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661728,
+    "monitored": false,
+    "name": "HADES-PRA-CZ-DRAC",
+    "scid": "b00debcd-1ce8-4e1b-89fc-12c21dc30bd1",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00197",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [],
+    "imsid": 738648,
+    "monitored": true,
+    "name": "UK-ESNET-EEX-OPEN",
+    "scid": "b01450d5-c784-49fc-8e3a-dbcd6d061a26",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00917",
+    "speed": 429496729600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679116,
+    "monitored": true,
+    "name": "ATH2-VIE-LAG",
+    "scid": "b014661b-6ba6-469d-b67c-fd25cd41ae22",
+    "service_type": "ETHERNET",
+    "sid": "GA-01930",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.2/31",
+          "2001:798:cc::d/126"
+        ],
+        "hostname": "rt0.poz.pl.geant.net",
+        "interface": "lag-3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.3/31",
+          "2001:798:cc::e/126"
+        ],
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae3.0"
+      }
+    ],
+    "imsid": 740149,
+    "monitored": true,
+    "name": "POZ-POZ-IPTRUNK",
+    "scid": "b0250d18-e8de-406c-9956-851ecd2dc0f6",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02528",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [],
+    "imsid": 728422,
+    "monitored": false,
+    "name": "DFN-BGP-LU-COC-AP1",
+    "scid": "b025fe43-620c-40c5-903f-221fce8c42c5",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01001",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.36"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-123062"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4063"
+      }
+    ],
+    "imsid": 744144,
+    "monitored": true,
+    "name": "MSEULB-02363",
+    "scid": "b031653d-0746-4a53-bcb0-17735a60d939",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02363",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 712353,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-BELNET-BE-1",
+    "scid": "b0714f27-1eeb-423f-9bd4-853c66c28933",
+    "service_type": "MD-VPN (PROXY)",
+    "sid": "GS-01012",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae17"
+      }
+    ],
+    "imsid": 658518,
+    "monitored": true,
+    "name": "LAG-QFX.PAR.FR_AE17",
+    "scid": "b0ae383b-27c5-4b7e-8617-86e4e1544e50",
+    "service_type": "ETHERNET",
+    "sid": "GA-01730",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae12"
+      }
+    ],
+    "imsid": 662478,
+    "monitored": true,
+    "name": "GARR-AP2-LAG",
+    "scid": "b0cc2e3b-9f09-446e-a960-6a62abcdff7f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01883",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-7"
+      }
+    ],
+    "imsid": 739695,
+    "monitored": true,
+    "name": "GEN-PAR-1.6T-LAG",
+    "scid": "b0d6ff8f-f763-4b11-a0ec-767db94a4cdc",
+    "service_type": "ETHERNET",
+    "sid": "GA-01823",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 745806,
+    "monitored": true,
+    "name": "LJUBLJANA 1-LJUBLJANA 1-LAG-006(GEANT)",
+    "scid": "b1025b55-9aee-4bf0-ac90-9fcb6a18beaf",
+    "service_type": "ETHERNET",
+    "sid": "GA-50058",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ASNET-AM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.17/30",
+          "2001:798:1::cd/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae17.433"
+      }
+    ],
+    "imsid": 747039,
+    "monitored": false,
+    "name": "ASNET-AM-AP2-IAS",
+    "scid": "b14195c8-ccd2-4095-bba9-1e1e04760574",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-02651",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.947"
+      },
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:947"
+      }
+    ],
+    "imsid": 747550,
+    "monitored": true,
+    "name": "HAM-MAD-02183",
+    "scid": "b1710dc3-6b76-4402-8d76-24af9e21a0c4",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02183",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663003,
+    "monitored": false,
+    "name": "FRA-GROOVE-3",
+    "scid": "b17cbfbe-a721-4ca6-9479-487339c25f4a",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00176",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [],
+    "imsid": 709646,
+    "monitored": false,
+    "name": "SWITCH-GN-PRACE-VPN-PROXY-GENEVA-L3VPN",
+    "scid": "b186f976-88c1-49c3-af9e-79809ced5e9f",
+    "service_type": "MD-VPN (PROXY)",
+    "sid": "GS-01071",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.16/31",
+          "2001:798:111:1::51/126"
+        ],
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae10.1990"
+      }
+    ],
+    "imsid": 730596,
+    "monitored": true,
+    "name": "FCCN-AP1-LIS-LHCONE",
+    "scid": "b19d79ee-cffd-44d7-8792-604caf241411",
+    "service_type": "L3-VPN",
+    "sid": "GS-02401",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.196/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.13"
+      }
+    ],
+    "imsid": 732667,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-ECMWF",
+    "scid": "b1ba457f-ff1c-439e-ba25-1e52076bec93",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01076",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "et-3/0/4"
+      }
+    ],
+    "imsid": 734041,
+    "monitored": true,
+    "name": "BOD-PAR-INTERNET2-23089",
+    "scid": "b1da962b-0830-4706-a89c-2b2ca82faa2a",
+    "service_type": "ETHERNET",
+    "sid": "GS-02398",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CSTNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.62/31",
+          "2001:798:111:1::e1/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae12.111"
+      }
+    ],
+    "imsid": 729627,
+    "monitored": true,
+    "name": "CSTNET-MAR-LHCONE-PRIMARY",
+    "scid": "b1e2393e-5749-4bb8-b9c3-6dbcdfa78557",
+    "service_type": "L3-VPN",
+    "sid": "GS-00814",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661719,
+    "monitored": false,
+    "name": "PS-VIE-AT-IDRAC",
+    "scid": "b1f015b9-d936-43e3-8d39-743ea1795640",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00356",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743398,
+    "monitored": true,
+    "name": "COR-COR-MGMT-IPTRUNK",
+    "scid": "b1f50754-8459-4099-892c-c99787131412",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02618",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.25.1/24"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae2.991"
+      }
+    ],
+    "imsid": 745871,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-LON",
+    "scid": "b2003241-e0bd-4734-93d6-92fc0f6ac4fe",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00119",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658721,
+    "monitored": true,
+    "name": "BRUSSELS-BRUSSELS-1GBE-004(ETH)",
+    "scid": "b2894ff8-4f5c-4ed3-bbf2-ec545b8680d9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01361",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "equipment": "MIL01-GRV1",
+        "port": "1/2/3"
+      },
+      {
+        "equipment": "GEN01-GRV3",
+        "port": "1/2/3"
+      }
+    ],
+    "imsid": 734724,
+    "monitored": true,
+    "name": "GEN1-MIL1-ECMWF-SWITCH-GARR-23109-1",
+    "scid": "b28dce6f-bb4c-4fd4-8c6f-33063dddcd59",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02419",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.21.33.1/24"
+        ],
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae3.998"
+      }
+    ],
+    "imsid": 731619,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-BRA-SK",
+    "scid": "b2918a27-23fc-4fb0-ba9e-6d32f63977b2",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00149",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 709270,
+    "monitored": false,
+    "name": "RIG-TAL-IPTRUNK",
+    "scid": "b2ca6e36-1008-49ae-b29f-f00f83586fb3",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00061",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 719645,
+    "monitored": false,
+    "name": "UAT-TEST-GPLUS",
+    "scid": "b2ee6ce8-8d98-41e6-895d-abed7b531642",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-11112",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 734325,
+    "monitored": true,
+    "name": "THE-THE-IPTRUNK",
+    "scid": "b2faef2d-0abf-4145-b4c7-5f59c5bb914c",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02427",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 735696,
+    "monitored": true,
+    "name": "V-LAN_4_MX1.AMS.NL_AE21_",
+    "scid": "b30460fd-d894-4a60-beb5-50ac0bc561cf",
+    "service_type": "ETHERNET",
+    "sid": "GS-01158",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "TWAREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "211.79.48.146/30",
+          "2001:e10:ffff:30c::2/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.221"
+      }
+    ],
+    "imsid": 661630,
+    "monitored": true,
+    "name": "FR-TWAREN-221",
+    "scid": "b31af1ef-77a7-4cca-a6e8-e0d50787917f",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00886",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [],
+    "imsid": 709760,
+    "monitored": true,
+    "name": "PIONIER EUMETCAST AP1",
+    "scid": "b33f45fa-ff32-4d08-b7fd-186b0100af9a",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01114",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663241,
+    "monitored": false,
+    "name": "PS-FRA-DE-PSMP1-2",
+    "scid": "b34b0e9c-08b8-4050-8dd3-11a48e801d62",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00300",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662370,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-10GBE-013(GEANT)",
+    "scid": "b36e81dc-df48-459f-8d7f-816e9afe7430",
+    "service_type": "ETHERNET",
+    "sid": "GA-02135",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PSMP-GN-DRAC-LON2-UK.GEANT.ORG",
+        "port": "0-3"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/3/1"
+      },
+      {
+        "addresses": [
+          "62.40.106.248/31",
+          "2001:798:bb:2::d5/126"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/3/1.0"
+      }
+    ],
+    "imsid": 708923,
+    "monitored": false,
+    "name": "UAT-PS-LON2-UK-BWCTL",
+    "scid": "b3778d94-7f4e-434d-994e-0319f44bb6a1",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00377",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae30"
+      }
+    ],
+    "imsid": 658684,
+    "monitored": true,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-057(GEANT)",
+    "scid": "b37e10c4-9552-4d63-8f06-79ff83c0a439",
+    "service_type": "ETHERNET",
+    "sid": "GA-01938",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae31.0"
+      },
+      {
+        "addresses": [
+          "62.40.99.17/28",
+          "2001:798:ee:14::1/64"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae16.2001"
+      }
+    ],
+    "imsid": 661564,
+    "monitored": false,
+    "name": "ESXI-MANAGEMENT-LON2",
+    "scid": "b3a1ede6-d417-4aad-9294-211de943fdd6",
+    "service_type": "POP LAN LINK",
+    "sid": "GS-00074",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.109/30",
+          "2001:798:1::85/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-24.333"
+      }
+    ],
+    "imsid": 747956,
+    "monitored": true,
+    "name": "MREN-AP1-IAS",
+    "scid": "b3c9b555-7f1d-47d7-9031-079edac22f85",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00538",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.16/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.15"
+      }
+    ],
+    "imsid": 732675,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-NOAA2",
+    "scid": "b3edecf3-f344-40c7-87cf-be30385dbaf8",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01087",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 678987,
+    "monitored": true,
+    "name": "DUB-DUB2-LAG",
+    "scid": "b3f2db88-7ee5-497c-b736-4c430182cb1f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01927",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.37/31",
+          "2001:798:cc:1::d6/126"
+        ],
+        "hostname": "rt0.vie.at.geant.net",
+        "interface": "lag-4.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.36/31",
+          "2001:798:cc:1::d5/126"
+        ],
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-4.0"
+      }
+    ],
+    "imsid": 740950,
+    "monitored": true,
+    "name": "MIL2-VIE-IPTRUNK",
+    "scid": "b44df27c-8312-4673-81a8-bd68413992ba",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00057",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae12"
+      }
+    ],
+    "imsid": 727609,
+    "monitored": true,
+    "name": "FR-IC1-LAG",
+    "scid": "b44eaa26-0f7a-4874-af94-b81b003264e4",
+    "service_type": "ETHERNET",
+    "sid": "GA-02233",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ULAKBIM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.161/30",
+          "2001:798:1::c5/126"
+        ],
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-21.333"
+      }
+    ],
+    "imsid": 745293,
+    "monitored": true,
+    "name": "ULAKBIM-AP1-IAS",
+    "scid": "b4738f69-42a7-46e7-8356-663cf725bff5",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00591",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.120.89/29",
+          "2001:798:bb:2c::1/64"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/2.11"
+      }
+    ],
+    "imsid": 661935,
+    "monitored": false,
+    "name": "FLOWMON-LON2-UK-MANAGEMENT",
+    "scid": "b478a077-1a79-4471-b3e5-7e888197fa2e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00166",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae14"
+      }
+    ],
+    "imsid": 662488,
+    "monitored": true,
+    "name": "RENATER-AP2-LAG",
+    "scid": "b4a0784c-deb6-4edb-9975-70274b9e33cd",
+    "service_type": "ETHERNET",
+    "sid": "GA-01877",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.26"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-123035"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4062"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:3501"
+      }
+    ],
+    "imsid": 745336,
+    "monitored": true,
+    "name": "MSEJUST-02318",
+    "scid": "b4a38235-7e8e-4579-9cc7-88f6a5fe4d8f",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02318",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661688,
+    "monitored": false,
+    "name": "LHCONE-PAR-FR-VLAN550",
+    "scid": "b4af3b04-7360-4dc9-b135-048915e27be2",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00225",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT-IT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "xe-1/0/17"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/6"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-5/0/1.0"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/6.0"
+      }
+    ],
+    "imsid": 729480,
+    "monitored": true,
+    "name": "FRA-PAR-SUPERPOP-QFX-2-GEANT",
+    "scid": "b4b0a9cb-9224-4923-abb3-7415fe8a6dbd",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00079",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663140,
+    "monitored": false,
+    "name": "KVMOIP-FRA-DE",
+    "scid": "b4e41b4e-48fd-4927-ad07-3ab5f23ac75b",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00220",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 721149,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-006(GEANT)",
+    "scid": "b50369b2-fe86-461a-9710-36401e7b2f9e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01384",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "DFN-AP2-CLS|ASN680",
+    "scid": "b50e70a2-c325-4a9b-a1b0-092673723fe5",
+    "service_type": null,
+    "sid": "DS-33537",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae10.930"
+      },
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.930"
+      }
+    ],
+    "imsid": 719523,
+    "monitored": true,
+    "name": "LON-MAD-GOTO-REDIRIS-JISC-16018",
+    "scid": "b5139f6c-0614-46b5-abba-d489a12c5020",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00734",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "2001:798:111:1::1/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae14.116"
+      }
+    ],
+    "imsid": 733483,
+    "monitored": true,
+    "name": "RENATER-AP2-IPV6-LHCONE",
+    "scid": "b51879d5-99bd-476f-b051-1c194b76cfb2",
+    "service_type": "L3-VPN",
+    "sid": "GS-00856",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661381,
+    "monitored": false,
+    "name": "PSMP-ATH-GR-DRAC",
+    "scid": "b52f676a-9bd9-4ae9-916b-2f31c5bec571",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00362",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/2/4"
+      }
+    ],
+    "imsid": 720003,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-10GBE-009(GEANT)",
+    "scid": "b55e4183-a474-4485-9823-3be4651c46e2",
+    "service_type": "ETHERNET",
+    "sid": "GA-02190",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 724614,
+    "monitored": true,
+    "name": "GEN-LON-800G-IPTRUNK",
+    "scid": "b572d1e2-e75f-4886-ba80-e1e7258e8e41",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02228",
+    "speed": 858993459200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 740946,
+    "monitored": true,
+    "name": "MIL2-VIE-LAG",
+    "scid": "b576a90f-5beb-4ec8-83a5-c0bebd0b6533",
+    "service_type": "ETHERNET",
+    "sid": "GA-01769",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 718262,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-1GBE-003(GEANT)",
+    "scid": "b582c35d-0d6d-42ba-b980-bc9e1d9c7b43",
+    "service_type": "ETHERNET",
+    "sid": "GA-01500",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CANARIE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "205.189.32.77/31",
+          "2001:410:101:fa5::2/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.2200"
+      }
+    ],
+    "imsid": 661404,
+    "monitored": true,
+    "name": "CANARIE-PAR-LHCONE",
+    "scid": "b5963593-0b98-4b89-adf4-1023cc4c72a4",
+    "service_type": "L3-VPN",
+    "sid": "GS-00809",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NETHERLIGHT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.1"
+      }
+    ],
+    "imsid": 668908,
+    "monitored": true,
+    "name": "NETHERLIGHT-GEO-UK-1-LL",
+    "scid": "b5aa5e1a-55c3-4693-a519-d4031a2e52fe",
+    "service_type": "CBL1",
+    "sid": "GA-01481",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.fra.de - Telia Multicast Traffic",
+    "scid": "b5e526fa-ffa0-4324-a951-3bf25c2c7a5e",
+    "service_type": null,
+    "sid": "DS-40463",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "URAN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.154/31",
+          "2001:798:99:1::f5/126"
+        ],
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "ae10.100"
+      }
+    ],
+    "imsid": 714000,
+    "monitored": true,
+    "name": "URAN-AP2",
+    "scid": "b6b872c2-a7e2-4665-ad89-795f61bc48ea",
+    "service_type": "GEANT IP",
+    "sid": "GS-00521",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "MX2.RIG.LV",
+        "port": "XE-1/1/1"
+      }
+    ],
+    "imsid": 679333,
+    "monitored": true,
+    "name": "RIGA-RIGA-10GBE-001(LAT)",
+    "scid": "b6cf4e2b-58b3-4f06-8a7c-f5e014ee85aa",
+    "service_type": "ETHERNET",
+    "sid": "GA-01531",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/46"
+      }
+    ],
+    "imsid": 658711,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-050(ETH)",
+    "scid": "b6dc006e-5cfd-4c21-b576-6a954177c050",
+    "service_type": "ETHERNET",
+    "sid": "GA-01220",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661693,
+    "monitored": false,
+    "name": "PRA-GROOVE-1",
+    "scid": "b6e17064-f328-46a3-9b50-14abe3efd9fc",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00279",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732262,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-1GBE-003(GEANT)",
+    "scid": "b728c593-1929-4bf8-a9e5-405722aa49d7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01548",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708172,
+    "monitored": false,
+    "name": "PS-FRA-DE-PSMP3-OWAMP",
+    "scid": "b740f04d-06fa-4d73-b1f2-821de0f7847a",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00306",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662934,
+    "monitored": false,
+    "name": "AMS-GROOVE-1-MANAGEMENT",
+    "scid": "b782f417-d8ef-4dd7-abbe-cc41da655bc6",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00092",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.208/31",
+          "2001:798:1::19a/127"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae48.740"
+      }
+    ],
+    "imsid": 741337,
+    "monitored": false,
+    "name": "A10-DDOS-SCRUBBING-FRA-CLEAN-TRAFFIC",
+    "scid": "b7b741da-5847-4bcb-8dc3-179e3a3dd54b",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00087",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.245/31",
+          "2001:798:cc:1::102/126"
+        ],
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.244/31",
+          "2001:798:cc:1::101/126"
+        ],
+        "hostname": "rt0.kau.lt.geant.net",
+        "interface": "lag-4.0"
+      }
+    ],
+    "imsid": 746526,
+    "monitored": true,
+    "name": "KAU-RIG-IPTRUNK",
+    "scid": "b7b8f440-5e5f-4b31-b1d9-d5a598ab5415",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00044",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.38/31",
+          "2001:798:99:1::19/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.1103"
+      }
+    ],
+    "imsid": 734591,
+    "monitored": true,
+    "name": "SURF-AP1",
+    "scid": "b7e1373e-17b5-4561-80c9-b5a0fbab0d33",
+    "service_type": "GEANT IP",
+    "sid": "GS-00512",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lju.si.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 746143,
+    "monitored": true,
+    "name": "LJU-MIL2-LAG",
+    "scid": "b7f8dc8d-7fd7-415f-8daa-44d16e05403e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01741",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "198.124.80.10/30",
+          "2001:400:f003:c::3/127"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.2004"
+      }
+    ],
+    "imsid": 661188,
+    "monitored": true,
+    "name": "ESNET-PAR-LHCONE",
+    "scid": "b80a4c95-1b57-450c-a86d-25de68a303b9",
+    "service_type": "L3-VPN",
+    "sid": "GS-00823",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732261,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-001(GEANT)",
+    "scid": "b81fb1ee-f611-413e-b402-20129b27eba3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01611",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.32"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4086"
+      }
+    ],
+    "imsid": 739668,
+    "monitored": true,
+    "name": "BELNET-THOMASMORE-EXPRESSROUTE-VLAN4086",
+    "scid": "b85d9136-670a-4bdb-b877-ee0c376bac30",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02476",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.21/30",
+          "2001:798:1::19/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-101.334"
+      }
+    ],
+    "imsid": 744964,
+    "monitored": true,
+    "name": "BREN-AP2-IAS",
+    "scid": "b86df08f-c9d5-48f8-9256-24d04e3b845f",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00558",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [],
+    "imsid": 708704,
+    "monitored": true,
+    "name": "ARNES EUMETCAST AP2",
+    "scid": "b8996f7b-d661-4bab-b225-0eadf9d06eae",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01095",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/5"
+      }
+    ],
+    "imsid": 717187,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-006(GEANT)",
+    "scid": "b8a9b384-a396-4877-8981-eb1681863166",
+    "service_type": "ETHERNET",
+    "sid": "GA-01231",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/7"
+      }
+    ],
+    "imsid": 658815,
+    "monitored": true,
+    "name": "LONDON-LONDON-10GBE-007(ETH)",
+    "scid": "b8ae15ec-5ab1-4136-8742-d7c580c7fa17",
+    "service_type": "ETHERNET",
+    "sid": "GA-01460",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae11"
+      }
+    ],
+    "imsid": 658519,
+    "monitored": false,
+    "name": "LON2-PRD-ESX01-VM-TRAFFIC",
+    "scid": "b8d7dbcf-4326-454e-99c6-0a4fd5af81bf",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01699",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.66/31",
+          "2001:798:99:1::95/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-25.100"
+      }
+    ],
+    "imsid": 747899,
+    "monitored": true,
+    "name": "KREN-AP1",
+    "scid": "b90fce2b-7f04-4901-b025-8b46a66f6ccf",
+    "service_type": "GEANT IP",
+    "sid": "GS-02153",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.30"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240586"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4093"
+      }
+    ],
+    "imsid": 744269,
+    "monitored": true,
+    "name": "MSEMOBILIT-02169",
+    "scid": "b929d646-5fcb-4818-a9a8-18e86b792c8a",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02169",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 712119,
+    "monitored": true,
+    "name": "SW4.LON.UK-LAG",
+    "scid": "b9306bed-fc72-4752-8beb-8b97ee903a76",
+    "service_type": "ETHERNET",
+    "sid": "GA-02066",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW2.MAD.ES",
+        "port": "AE3"
+      }
+    ],
+    "imsid": 702121,
+    "monitored": true,
+    "name": "LAG-MX1.MAD.ES_AE3",
+    "scid": "b9387dc3-1b43-4b80-be6f-8e47c9c9b5a8",
+    "service_type": "ETHERNET",
+    "sid": "GA-02085",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663071,
+    "monitored": false,
+    "name": "FRA-GROOVE-2",
+    "scid": "b93d5aa2-e98e-4a4d-8711-88c27d953fed",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00174",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.3902"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.5"
+      }
+    ],
+    "imsid": 707076,
+    "monitored": true,
+    "name": "NORDUNET-JYV-EXPRESSROUTE-VLAN3902",
+    "scid": "b966f5f6-46bf-4a8a-ac6a-a73d67cc7416",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01157",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [],
+    "imsid": 742905,
+    "monitored": false,
+    "name": "GRNET-AP1-COPERNICUS",
+    "scid": "b98db90e-403d-4c27-a380-fd2b987fad8f",
+    "service_type": "L3-VPN",
+    "sid": "GS-00828",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "CyNet AP1 IAS",
+    "scid": "b9c6ba65-676c-4b97-86e2-6297c48cff88",
+    "service_type": null,
+    "sid": "DS-31661",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.956"
+      },
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:2105"
+      }
+    ],
+    "imsid": 747545,
+    "monitored": true,
+    "name": "BIL-HAM-02517",
+    "scid": "b9cd992f-be68-44b5-b466-c18e63d6b539",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02517",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW2.PAR.FR",
+        "port": "AE1"
+      }
+    ],
+    "imsid": 733969,
+    "monitored": true,
+    "name": "LAG-SW2.PAR.FR_AE1",
+    "scid": "b9e5fff8-6075-4a74-90ce-32fc97f90a57",
+    "service_type": "ETHERNET",
+    "sid": "GA-02063",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "149.29.9.10/30",
+          "2001:978:2:7::13b:2/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae32.0"
+      }
+    ],
+    "imsid": 731788,
+    "monitored": true,
+    "name": "COGENT-GWS-FRA",
+    "scid": "b9f79c25-3bc2-4c59-8103-c1f496d07308",
+    "service_type": "GWS - UPSTREAM",
+    "sid": "GS-00066",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.109/31",
+          "2001:798:cc::a2/126"
+        ],
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae2.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.108/31",
+          "2001:798:cc::a1/126"
+        ],
+        "hostname": "rt0.bra.sk.geant.net",
+        "interface": "lag-2.0"
+      }
+    ],
+    "imsid": 743065,
+    "monitored": false,
+    "name": "BRA-BRA-MGMT-IPTRUNK",
+    "scid": "b9f8f440-038d-4a4e-bb99-6afdd111d953",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02602",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 658900,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-012(ETH)",
+    "scid": "ba283a19-dc87-41ad-bd9f-a1e3e37a35c6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01517",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [],
+    "imsid": 709746,
+    "monitored": true,
+    "name": "FCCN EUMETCAST AP2",
+    "scid": "ba4afbce-2cb2-4bf8-9969-5a94e7b2d9ad",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01104",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "212.133.7.166/30",
+          "2001:1900:5:2:2:0:8:5a56/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae28.0"
+      }
+    ],
+    "imsid": 720369,
+    "monitored": true,
+    "name": "COLT-GWS-VIE",
+    "scid": "ba5f76b0-1612-4e9f-bfc5-e9f5d8bbaf75",
+    "service_type": "GWS - UPSTREAM",
+    "sid": "GS-00070",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [],
+    "imsid": 661663,
+    "monitored": false,
+    "name": "PAR-PAR-MISC-SWITCH-INTERNET2-19116",
+    "scid": "ba7ddc4c-96a0-4613-8515-cb07a77bdb03",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00748",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "COGENT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae19"
+      }
+    ],
+    "imsid": 662449,
+    "monitored": true,
+    "name": "LAG-MX1.BUD.HU_AE19",
+    "scid": "ba9322c1-93f2-409f-9ca8-163031e89fc5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01898",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.245/30",
+          "2001:798:23:10aa::9/126"
+        ],
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.100"
+      }
+    ],
+    "imsid": 661706,
+    "monitored": true,
+    "name": "PIONIER-AP1",
+    "scid": "badce9f7-75f9-4033-839b-4abf274ba34a",
+    "service_type": "GEANT IP",
+    "sid": "GS-00495",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "URAN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.156/31",
+          "2001:798:99:1::f9/126"
+        ],
+        "hostname": "rt1.kie.ua.geant.net",
+        "interface": "ae10.100"
+      }
+    ],
+    "imsid": 714001,
+    "monitored": true,
+    "name": "URAN-AP1",
+    "scid": "baf94437-b3b0-49b6-84cf-09c027e9d4f8",
+    "service_type": "GEANT IP",
+    "sid": "GS-00520",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 702121,
+    "monitored": true,
+    "name": "LAG-MX1.MAD.ES_AE3",
+    "scid": "bb030b01-0fac-4993-b17e-a777e468b904",
+    "service_type": "ETHERNET",
+    "sid": "GA-01782",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae10.112"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae19.112"
+      }
+    ],
+    "imsid": 705439,
+    "monitored": true,
+    "name": "FRA-GEN-ORACLE-CERN-20150",
+    "scid": "bb3aeb56-5f86-4023-acc7-557780a35424",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00699",
+    "speed": 450971566080,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 661738,
+    "monitored": false,
+    "name": "BELNET-AP1",
+    "scid": "bb4e06c5-0c1a-4b97-ab81-7d4bb4981096",
+    "service_type": "GEANT IP",
+    "sid": "GS-00435",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.191"
+      },
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:191"
+      }
+    ],
+    "imsid": 747542,
+    "monitored": true,
+    "name": "HAM-MAD-02343",
+    "scid": "bb5ab83d-82f7-4984-8737-a10faff5e16f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02343",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.21"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4082"
+      }
+    ],
+    "imsid": 739676,
+    "monitored": true,
+    "name": "BELNET-ZWEV-EXPRESSROUTE-VLAN4082",
+    "scid": "bb783906-5d3c-461a-adca-a6151b843aac",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01129",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ULAKBIM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.52/31",
+          "2001:798:111:1::e9/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-23.111"
+      }
+    ],
+    "imsid": 744997,
+    "monitored": true,
+    "name": "ULAKBIM-AP2-LHCONE",
+    "scid": "bbe48914-6d1c-46c9-8086-8c328d3bafdc",
+    "service_type": "L3-VPN",
+    "sid": "GS-00869",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINGAREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "103.5.242.43/31",
+          "2401:c7c0:21a:fff7:0:20:965:1/127"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae12.840"
+      }
+    ],
+    "imsid": 727611,
+    "monitored": true,
+    "name": "FR-IC1-SINGAREN",
+    "scid": "bbe76de0-e9b4-45e5-add5-5415245a28f7",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02320",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.166/31",
+          "2001:798:0:1::d/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.612"
+      }
+    ],
+    "imsid": 736650,
+    "monitored": true,
+    "name": "REDCLARA-PAR-COPERNICUS",
+    "scid": "bc06fe95-4236-4a26-b343-b1976d7f8e39",
+    "service_type": "L3-VPN",
+    "sid": "GS-00849",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.21.6.1/24"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae3.998"
+      }
+    ],
+    "imsid": 702125,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-MAD-ES",
+    "scid": "bc1a44f4-7ae8-4a89-ad19-241866f73378",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00154",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae23"
+      }
+    ],
+    "imsid": 731668,
+    "monitored": true,
+    "name": "CESNET-AP2-VIE-LAG",
+    "scid": "bc54f878-78a5-4b91-8241-3041224c3cce",
+    "service_type": "ETHERNET",
+    "sid": "GA-01899",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.160/31",
+          "2001:798:0:1::1/126"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae15.668"
+      }
+    ],
+    "imsid": 713845,
+    "monitored": true,
+    "name": "REDCLARA-MAD-COPERNICUS",
+    "scid": "bc6ced75-3059-458a-a60f-203fa1fe4066",
+    "service_type": "L3-VPN",
+    "sid": "GS-00850",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.3151"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3151"
+      }
+    ],
+    "imsid": 705892,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-NORDUNET-SINGAREN-CAE1-19074-VL3151",
+    "scid": "bc6d5311-3173-490e-8ea0-09d12d6518d5",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00976",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-124049"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:3502"
+      }
+    ],
+    "imsid": 745306,
+    "monitored": true,
+    "name": "GEANT_EPIPE_124049",
+    "scid": "bc857d8e-0ceb-47fa-83e9-810b75c5aa82",
+    "service_type": "ETHERNET",
+    "sid": "GS-02511",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RESTENA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.113/30",
+          "2001:0798:0014:10aa::21/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae18.2602"
+      }
+    ],
+    "imsid": 732142,
+    "monitored": true,
+    "name": "RESTENA-AP1",
+    "scid": "bc96eb08-e225-484c-b1ff-c17a181a84b9",
+    "service_type": "GEANT IP",
+    "sid": "GS-00507",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW2.MIL2.IT",
+        "port": "AE1"
+      }
+    ],
+    "imsid": 726135,
+    "monitored": true,
+    "name": "RT1.MIL2-SW2.MIL2-LAG-001(GEANT)",
+    "scid": "bc972494-6123-447c-a0df-b8c7c813acca",
+    "service_type": "ETHERNET",
+    "sid": "GA-02062",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/1/7.370"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/7.370"
+      },
+      {
+        "addresses": [
+          "10.0.2.254/24"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "irb.370"
+      }
+    ],
+    "imsid": 732533,
+    "monitored": false,
+    "name": "SCION-SCION-FRA-INTERNAL-VPN-VL370",
+    "scid": "bc9dece8-ebf6-47bb-bf46-f9971f920528",
+    "service_type": "L3-VPN",
+    "sid": "GS-02216",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 742922,
+    "monitored": true,
+    "name": "BUD-BUD-LAG",
+    "scid": "bcd19a90-051d-4aa5-9a20-436e23c038c0",
+    "service_type": "ETHERNET",
+    "sid": "GA-02594",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [],
+    "imsid": 712192,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-HEANET-IE-(RR1-PW-HEA-NET)",
+    "scid": "bcd2e9ff-7cd7-4053-9749-7c232f738ba5",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01045",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.lis.pt - Traffic - xe-1/1/0 - FCCN AP2 LL 3\t",
+    "scid": "bcf6fbab-4bac-42f0-8c4f-dac9d8b82684",
+    "service_type": null,
+    "sid": "DS-46639",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30.3003"
+      },
+      {
+        "addresses": [
+          "62.40.123.59/29",
+          "2001:798:bb:4::3/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "irb.3003"
+      }
+    ],
+    "imsid": 712151,
+    "monitored": false,
+    "name": "PS-THROUGHPUT-NETWORK-PAR-FR",
+    "scid": "bd04925e-e0bf-4bc0-aeed-6cbcd277660a",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00354",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 733131,
+    "monitored": false,
+    "name": "BUC-FRA-IPTRUNK",
+    "scid": "bd09d218-e5fc-44c5-ab90-2d035408b225",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00023",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-111505"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21:1008"
+      }
+    ],
+    "imsid": 745323,
+    "monitored": true,
+    "name": "GEANT_EPIPE_111505",
+    "scid": "bd0b0011-52eb-452b-bd92-ee343984ce57",
+    "service_type": "ETHERNET",
+    "sid": "GS-00680",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "VIE-OOB-MC",
+        "port": "GE-/1"
+      }
+    ],
+    "imsid": 677796,
+    "monitored": false,
+    "name": "VIE OOB LINK",
+    "scid": "bd221e52-81e6-4818-8ef6-59d2fa497906",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00419",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae14.518"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.518"
+      }
+    ],
+    "imsid": 709299,
+    "monitored": true,
+    "name": "LON-GEN-CNES-NISN-RENATER-09201",
+    "scid": "bd390604-e36a-45fe-b40a-b8bd85b6856c",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00723",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [],
+    "imsid": 709886,
+    "monitored": false,
+    "name": "AMS-GEN-EEX-ESNET-2104",
+    "scid": "bd6355ad-644c-413a-87c5-cc2008e6ee44",
+    "service_type": "GEANT LAMBDA",
+    "sid": "GS-00779",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae10.2805"
+      },
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.953"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-124046"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-124046"
+      }
+    ],
+    "imsid": 739311,
+    "monitored": true,
+    "name": "UPV/EHU-REDIRIS-KIFU-SLICES-SZTAKI",
+    "scid": "bdaeefa1-99e5-41e9-b8de-13e10264e3da",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02518",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.169/31",
+          "2001:798:cc:1::fe/126"
+        ],
+        "hostname": "rt0.poz.pl.geant.net",
+        "interface": "lag-6.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.168/31",
+          "2001:798:cc:1::fd/126"
+        ],
+        "hostname": "rt0.kau.lt.geant.net",
+        "interface": "lag-3.0"
+      }
+    ],
+    "imsid": 746527,
+    "monitored": true,
+    "name": "KAU-POZ-IPTRUNK",
+    "scid": "bdf51392-7991-4564-bc29-c409c4bd840b",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00043",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708154,
+    "monitored": false,
+    "name": "NE-ESXI-FRA-DE-IDRAC",
+    "scid": "bdf993b0-17ee-45b4-aa3d-a2805f6bbdd8",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00253",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW2.MAR.FR",
+        "port": "AE1"
+      }
+    ],
+    "imsid": 719608,
+    "monitored": true,
+    "name": "MAR01-MAR01-LAG-004(GEANT)",
+    "scid": "bdf9a65c-4eec-4d99-9110-490c7b0b978c",
+    "service_type": "ETHERNET",
+    "sid": "GA-02061",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.64/31",
+          "2001:798:cc:1::29/126"
+        ],
+        "hostname": "rt0.lon.uk.geant.net",
+        "interface": "lag-2.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.65/31",
+          "2001:798:cc:1::2a/126"
+        ],
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-2.0"
+      }
+    ],
+    "imsid": 738842,
+    "monitored": true,
+    "name": "LON-LON2-IPTRUNK",
+    "scid": "be1ba63d-b53c-43ab-8d16-17b8c4517e18",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00052",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-7"
+      }
+    ],
+    "imsid": 740948,
+    "monitored": true,
+    "name": "MIL2-MIL2-LAG",
+    "scid": "be2dcbf1-13e0-4c2b-822a-371c73f7ef28",
+    "service_type": "ETHERNET",
+    "sid": "GA-02547",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708745,
+    "monitored": false,
+    "name": "FRA-POZ-IPTRUNK",
+    "scid": "be523bf4-760c-4174-9f6a-2657d4260748",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00036",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-1/0/4"
+      }
+    ],
+    "imsid": 658560,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-021(ETH)",
+    "scid": "be748e4c-3f3b-4180-92b9-b366d9572201",
+    "service_type": "ETHERNET",
+    "sid": "GA-01274",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ULAKBIM"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-21"
+      }
+    ],
+    "imsid": 745286,
+    "monitored": true,
+    "name": "ULAKBIM-AP1-LAG",
+    "scid": "be7a90ca-1e4b-41b4-8710-042be5a070fa",
+    "service_type": "ETHERNET",
+    "sid": "GA-01904",
+    "speed": 0,
+    "status": "planned"
+  },
+  {
+    "customers": [
+      "LAT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.3003"
+      },
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "pwe-150561"
+      },
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-20:3003"
+      }
+    ],
+    "imsid": 745967,
+    "monitored": true,
+    "name": "EVLBI-JIVE-00662",
+    "scid": "beb2d2ce-a399-406c-b323-ecd1eae09269",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00662",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 658773,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-006(ETH)",
+    "scid": "bedf31ca-dbb2-4852-a2c9-8cf3a6cb9647",
+    "service_type": "ETHERNET",
+    "sid": "GA-01516",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.PRA.CZ.GEANT2.NET",
+        "port": "ETH-45"
+      },
+      {
+        "hostname": "mx1.pra.cz.geant.net",
+        "interface": "xe-2/0/2.1022"
+      },
+      {
+        "hostname": "mx1.pra.cz.geant.net",
+        "interface": "ge-0/3/9.1022"
+      }
+    ],
+    "imsid": 661916,
+    "monitored": false,
+    "name": "BOD-SDN-PILOT-HOST-ETH1-PRAGUE",
+    "scid": "befccdd4-26e3-4f06-9495-0c1a48a5c4f5",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00102",
+    "speed": 11811160064,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-2/0/7"
+      }
+    ],
+    "imsid": 658593,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-026(ETH)",
+    "scid": "bf5d1f2d-aa3e-4613-88ef-54d35838a615",
+    "service_type": "ETHERNET",
+    "sid": "GA-01262",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 716952,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-BUD-HU",
+    "scid": "bf809248-bb2c-4fa6-be53-0a7355efef6f",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00106",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 738788,
+    "monitored": true,
+    "name": "V-LAN_246_RT1.BRU.BE_AE14_",
+    "scid": "bf814326-d51d-4481-98c2-343d98847678",
+    "service_type": "ETHERNET",
+    "sid": "GS-02333",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.43"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4070"
+      }
+    ],
+    "imsid": 741111,
+    "monitored": true,
+    "name": "BELNET-HOGENT-EXPRESSROUTE-VLAN4070",
+    "scid": "bfc4f0d7-3852-46bb-ad3a-930bdcd1cf20",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02574",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.144/31",
+          "2001:798:99:1::30/127"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.161"
+      }
+    ],
+    "imsid": 661439,
+    "monitored": true,
+    "name": "RENATER-AP-RTBH",
+    "scid": "bfff3423-7cbf-46a3-9f5a-5cfbb34cd382",
+    "service_type": "GEANT IP",
+    "sid": "GS-00503",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PSMP.LON.UK.GEANT2.NET",
+        "port": "1-10GE-1"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/6"
+      },
+      {
+        "addresses": [
+          "62.40.106.130/31",
+          "2001:798:fc00:28::5/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/6.0"
+      }
+    ],
+    "imsid": 708187,
+    "monitored": false,
+    "name": "PS-LON-UK-PSMP-BWCTL",
+    "scid": "c0127f31-17b6-4850-9aa7-c7a9461c3aec",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00319",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.123.217/29",
+          "2001:798:bb:38::1/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "et-11/3/0.100"
+      }
+    ],
+    "imsid": 708301,
+    "monitored": false,
+    "name": "DTN-PAR-100G-DATA",
+    "scid": "c0130d43-abac-4dc2-9b91-4e0d39e608bd",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00277",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 658975,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-015(ETH)",
+    "scid": "c027abff-f550-4599-a2d4-a0dc81588a91",
+    "service_type": "ETHERNET",
+    "sid": "GA-01507",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "RIG-TAL-TRUNK",
+    "scid": "c037d8c1-d24f-4204-8f81-4ab8aafda4cb",
+    "service_type": null,
+    "sid": "GS-00549",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658660,
+    "monitored": false,
+    "name": "LON2-PRD-ESX01-VSAN-LAG",
+    "scid": "c05ba211-eb05-4753-939c-9eb3b33db778",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01706",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707227,
+    "monitored": false,
+    "name": "AMS-GROOVE",
+    "scid": "c06b683a-6ae1-468b-b84f-42bd6a3a9a3d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00090",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743602,
+    "monitored": true,
+    "name": "SOF-SOF-IPTRUNK",
+    "scid": "c0b5ce20-2a38-43c8-83c7-0b13b8884c28",
+    "service_type": "IP TRUNK",
+    "sid": "GS-50009",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [],
+    "imsid": 708276,
+    "monitored": false,
+    "name": "NL-EEX-ESNET-OOB",
+    "scid": "c0bef8db-0fd6-45c1-a011-1b91fe243147",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00891",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/0/5"
+      }
+    ],
+    "imsid": 658906,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-061(ETH)",
+    "scid": "c0f795da-5b2f-4652-b465-c220d662e892",
+    "service_type": "ETHERNET",
+    "sid": "GA-01326",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "LAT"
+    ],
+    "endpoints": [],
+    "imsid": 669690,
+    "monitored": true,
+    "name": "LAT-AP2-LL-1",
+    "scid": "c130dd1f-c064-463d-be1a-6943ca0ef502",
+    "service_type": "ETHERNET",
+    "sid": "GA-02140",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708216,
+    "monitored": false,
+    "name": "PS-PAR-FR-BWCTL-XE4/0/0",
+    "scid": "c13dc034-c2c5-4828-91a2-c92cbe19b6ae",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00338",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.129/30",
+          "2001:798:99:1::21/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.2023"
+      }
+    ],
+    "imsid": 661366,
+    "monitored": true,
+    "name": "NORDUNET-AP1",
+    "scid": "c1671512-4f49-46ba-9264-aeb5287eaf17",
+    "service_type": "GEANT IP",
+    "sid": "GS-00492",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661594,
+    "monitored": false,
+    "name": "LON-GROOVE-2-MANAGEMENT",
+    "scid": "c191f481-890c-4c50-8829-fb375b34b2d0",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00231",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ams.nl.geant.net",
+        "interface": "lag-8"
+      }
+    ],
+    "imsid": 739043,
+    "monitored": true,
+    "name": "AMS-FRA-1.6T-LAG",
+    "scid": "c1a05ef7-133c-4ba9-a46a-fad8d55c17e9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01915",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.39"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4067"
+      }
+    ],
+    "imsid": 739670,
+    "monitored": true,
+    "name": "BELNET-RVA-ONEM-EXPRESSROUTE-VLAN4067",
+    "scid": "c1b43827-bd76-4f4a-872a-0e2ba1816e6b",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02432",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ams-lon_eVLBI_JANET-NetherLight_12010",
+    "scid": "c1c4094e-9e76-4ac6-8406-4fe1d0681836",
+    "service_type": null,
+    "sid": "GS-00641",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMS01-GRV2",
+        "port": "1/3/8"
+      },
+      {
+        "equipment": "GEN01-GRV4",
+        "port": "1/3/8"
+      },
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "NL172777-1"
+      },
+      {
+        "equipment": "DIGITAL REALTY Z-END",
+        "port": "NL172777-1"
+      }
+    ],
+    "imsid": 730061,
+    "monitored": true,
+    "name": "AMS-GEN1-EEX-ESNET-2373-3-400G",
+    "scid": "c1cc5200-6748-4bf6-ab95-d17eca1d8a90",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02336",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "irb.991"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae30.991"
+      }
+    ],
+    "imsid": 733023,
+    "monitored": false,
+    "name": "CORIANT-LIBRENMS-ACCESS-FRA-DE",
+    "scid": "c1da5da7-f513-42f5-b9fe-4606eb0f98fb",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00108",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 658663,
+    "monitored": false,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-054(GEANT)",
+    "scid": "c1f65e8f-588f-4863-93e7-2b88cd228a47",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01678",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-0/0/46"
+      }
+    ],
+    "imsid": 658499,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-017(ETH)",
+    "scid": "c20b9371-1a71-4ce7-ae81-c790b9e83d4a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01254",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 738899,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-001(GEANT)",
+    "scid": "c223df65-1067-46e9-9981-27164ad66cfb",
+    "service_type": "ETHERNET",
+    "sid": "GA-01382",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/0/0.1100"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae12.1100"
+      }
+    ],
+    "imsid": 707040,
+    "monitored": true,
+    "name": "GEN-GEN-GARR-CERNLIGHT-CERN-GARR-16011",
+    "scid": "c23442f2-3e0e-4fb0-b0be-fc1f3e2ea273",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00708",
+    "speed": 332859965440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.416"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae40.416"
+      }
+    ],
+    "imsid": 726355,
+    "monitored": true,
+    "name": "FRA-POZ-ORACLE-PIONIER-23002-VL416",
+    "scid": "c23e44cf-a432-4564-bac6-3eccf4b49868",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02243",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "URAN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.192/31",
+          "2001:798:1::215/126"
+        ],
+        "hostname": "rt1.kie.ua.geant.net",
+        "interface": "ae10.333"
+      }
+    ],
+    "imsid": 713995,
+    "monitored": true,
+    "name": "URAN-AP1-IAS",
+    "scid": "c2535121-6f0a-44f4-bab8-ebde3099606d",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00593",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.19/31",
+          "2001:798:cc::16/126"
+        ],
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-6.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.18/31",
+          "2001:798:cc::15/126"
+        ],
+        "hostname": "rt0.cor.ie.geant.net",
+        "interface": "lag-3.0"
+      }
+    ],
+    "imsid": 738860,
+    "monitored": true,
+    "name": "COR-LON2-IPTRUNK",
+    "scid": "c26b818b-0512-4be8-9740-62f2ba60da81",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02386",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658696,
+    "monitored": false,
+    "name": "LON2-PRD-ESX12-VSAN-LAG",
+    "scid": "c27038e1-5257-41cf-ba83-712b5562c3c2",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01713",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT-IT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae14"
+      }
+    ],
+    "imsid": 679045,
+    "monitored": true,
+    "name": "FRA-SUPERPOP-LAG",
+    "scid": "c29d438f-0d92-44e0-a730-1b74577463b5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01686",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CSTNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.64/31",
+          "2001:798:111:1::f5/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.112"
+      }
+    ],
+    "imsid": 730081,
+    "monitored": true,
+    "name": "CSTNET-LON-LHCONE-SECONDARY",
+    "scid": "c2a86c96-75ac-4bd4-a540-52acdb190e82",
+    "service_type": "L3-VPN",
+    "sid": "GS-02380",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "REDIRIS-AP2-CLS|ASN766",
+    "scid": "c2aaefe4-6774-48d2-99d8-7db4f5d711b5",
+    "service_type": null,
+    "sid": "GS-00614",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-4/1/4.2710"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.2710"
+      }
+    ],
+    "imsid": 739897,
+    "monitored": true,
+    "name": "LON-POZ-PIONIER-ESNET-QUANTUM-DEMO-VL2710",
+    "scid": "c2af009b-d919-4ead-b5d4-f4d1e05318e0",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02557",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.kie.ua.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 713324,
+    "monitored": true,
+    "name": "KIE-KIE-LAG",
+    "scid": "c2b1e809-0e87-438e-a0f4-ee1e3b09f831",
+    "service_type": "ETHERNET",
+    "sid": "GA-02023",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-5"
+      }
+    ],
+    "imsid": 744990,
+    "monitored": true,
+    "name": "BUC-SOF-LAG",
+    "scid": "c2d5f624-3636-4670-9954-62760ed1c293",
+    "service_type": "ETHERNET",
+    "sid": "GA-01733",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BREN"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW2.SOF.BG",
+        "port": "AE3"
+      }
+    ],
+    "imsid": 745039,
+    "monitored": true,
+    "name": "BREN-AP2-LAG",
+    "scid": "c3080f02-99aa-4134-8ee5-56afca846349",
+    "service_type": "ETHERNET",
+    "sid": "GA-01997",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "AMRES"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.5/30",
+          "2001:798:1::9/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-21.333"
+      }
+    ],
+    "imsid": 744957,
+    "monitored": true,
+    "name": "AMRES-AP2-IAS",
+    "scid": "c310cf90-0422-4e84-8cf0-47ba377cff1c",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-02241",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.8/31",
+          "2001:798:cc:1::119/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.9/31",
+          "2001:798:cc:1::11a/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-1.0"
+      }
+    ],
+    "imsid": 747867,
+    "monitored": true,
+    "name": "SOF-ZAG-IPTRUNK",
+    "scid": "c335e87a-a00f-48c9-9e5a-71693e8ea6c0",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02367",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.202/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.20"
+      }
+    ],
+    "imsid": 732662,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-KMA2",
+    "scid": "c35754f2-9b40-432e-88db-84138eb6e783",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-00790",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 712568,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-PRA-CZ",
+    "scid": "c3656cc7-ec51-46c4-9ab0-d361a0b28f13",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00159",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "et-2/1/1"
+      },
+      {
+        "addresses": [
+          "173.194.125.195/31",
+          "2001:4860:1:1::3a69/127"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae49.0"
+      }
+    ],
+    "imsid": 746056,
+    "monitored": true,
+    "name": "GOOGLE-FRA-IP1",
+    "scid": "c39b0dd0-dfb4-4d59-90b0-0a85f2485d68",
+    "service_type": "ETHERNET",
+    "sid": "GS-00934",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [],
+    "imsid": 662247,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-058(ETH)",
+    "scid": "c39b9496-57f1-4be8-8568-8c58c4678351",
+    "service_type": "ETHERNET",
+    "sid": "GA-01591",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NETHERLIGHT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.4020"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.4020"
+      }
+    ],
+    "imsid": 736741,
+    "monitored": true,
+    "name": "LON-PAR-GEANTOPEN-INTERNET2-NETHERLIGHT-15034",
+    "scid": "c3e109c3-4e36-4cf4-a5c9-d91e2f8648a5",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00968",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662860,
+    "monitored": true,
+    "name": "DE-CSTNET LAG",
+    "scid": "c406b696-6083-4686-a585-3ab6778287d0",
+    "service_type": "ETHERNET",
+    "sid": "GA-01964",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae7"
+      }
+    ],
+    "imsid": 744435,
+    "monitored": true,
+    "name": "LON2-AMT-LAG",
+    "scid": "c417031b-98e1-4dc9-a737-f7d75f8604ad",
+    "service_type": "ETHERNET",
+    "sid": "GA-02301",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.104.193/30"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae2.53"
+      }
+    ],
+    "imsid": 745870,
+    "monitored": false,
+    "name": "FLOWMON-LON-IDRAC",
+    "scid": "c41c5af1-6375-4f4b-aec0-a89444b6b527",
+    "service_type": "SERVER LINK",
+    "sid": "GS-01193",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663011,
+    "monitored": false,
+    "name": "DNA-FRA-DE-ILO",
+    "scid": "c42cd91c-9c49-45a3-84b4-961dab243923",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00136",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/0/6"
+      }
+    ],
+    "imsid": 721140,
+    "monitored": true,
+    "name": "PARIS-PSMP-MGMT (GEANT)",
+    "scid": "c4385623-973b-425f-978e-f1e67fbacc85",
+    "service_type": "ETHERNET",
+    "sid": "GA-01397",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae13"
+      }
+    ],
+    "imsid": 659313,
+    "monitored": true,
+    "name": "SWITCH-AP2-LAG",
+    "scid": "c4419bc4-2cbf-4bc8-9260-0cda17a00970",
+    "service_type": "ETHERNET",
+    "sid": "GA-01817",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae7"
+      }
+    ],
+    "imsid": 744346,
+    "monitored": true,
+    "name": "AMS-AMT-LAG",
+    "scid": "c48751f8-34ad-439c-ac75-a1a04b5ed972",
+    "service_type": "ETHERNET",
+    "sid": "GA-02302",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae30.3000"
+      }
+    ],
+    "imsid": 733005,
+    "monitored": false,
+    "name": "VM-DATANETWORK-FRA",
+    "scid": "c48bb3d0-ac8e-402c-ba78-550ad6bdb970",
+    "service_type": "POP LAN LINK",
+    "sid": "GS-00084",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 709619,
+    "monitored": false,
+    "name": "HA-3140E01B69",
+    "scid": "c491707b-ffd3-4e92-af24-7c4ba0468993",
+    "service_type": "GTS",
+    "sid": "GS-01173",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "RedIRIS-GN-PRACE-VPN-Proxy-Marseille-L3VPN",
+    "scid": "c4c0ed0e-f010-4c8b-a224-78a85ca22205",
+    "service_type": null,
+    "sid": "GS-01068",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 744057,
+    "monitored": false,
+    "name": "BRU-BRU-IPTRUNK",
+    "scid": "c4e87f30-543c-417f-bd89-ba4a3e1e33a5",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02571",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.123"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-4/1/4.123"
+      }
+    ],
+    "imsid": 738642,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-ESNET-NORDUNET-15039-1",
+    "scid": "c4f0c295-1abe-4464-8089-9d7606c4c37f",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00963",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707240,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-MIL2-IT-NEW",
+    "scid": "c502fc22-8cac-469a-a111-b67599801724",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00247",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.104.34/31"
+        ],
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae1.28"
+      }
+    ],
+    "imsid": 732103,
+    "monitored": false,
+    "name": "POZ-EUMETSAT-SERVER-DATA-TRAFFIC",
+    "scid": "c5169868-38fa-4809-84d3-81bfd8bd97a8",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02360",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 745467,
+    "monitored": true,
+    "name": "GRNET-AP1-LAG",
+    "scid": "c517debb-5428-4cdf-82da-cdd396544e25",
+    "service_type": "ETHERNET",
+    "sid": "GA-01794",
+    "speed": 64424509440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660551,
+    "monitored": false,
+    "name": "LON-SINET-INTERNET-ACCESS",
+    "scid": "c56c589a-710f-4191-a304-f58acd786b0a",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00236",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708315,
+    "monitored": false,
+    "name": "FLOWMON-DDOS-FRA-DE-IDRAC",
+    "scid": "c5787831-0a20-42e1-b213-944d7d910d49",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00163",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708006,
+    "monitored": true,
+    "name": "RIG-TAL-LAG",
+    "scid": "c591626c-a7d6-49ba-9c67-dc8edd689c90",
+    "service_type": "ETHERNET",
+    "sid": "GA-02050",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30.3004"
+      },
+      {
+        "addresses": [
+          "10.254.254.3/29"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "irb.3004"
+      }
+    ],
+    "imsid": 712152,
+    "monitored": false,
+    "name": "TAAS-CONTROL-RANCID-LOGICAL-INTERFACE-PAR-FR",
+    "scid": "c5bf4d76-6da0-44a1-afeb-6127ada78f16",
+    "service_type": "L3-VPN",
+    "sid": "GS-00865",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.3910"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.12"
+      }
+    ],
+    "imsid": 706560,
+    "monitored": true,
+    "name": "NORDUNET-HHU-EXPRESSROUTE-VLAN3910",
+    "scid": "c5bfe097-4a36-46db-b2c3-adff4f18db66",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01156",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.50/31",
+          "2001:798::61/126"
+        ],
+        "hostname": "mx1.ath2.gr.geant.net",
+        "interface": "ae11.667"
+      }
+    ],
+    "imsid": 663015,
+    "monitored": false,
+    "name": "GRNET-AP2-CLS",
+    "scid": "c5c574ad-32aa-4903-ae1d-50328c5f523b",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00609",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/1/4.1726"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.1726"
+      }
+    ],
+    "imsid": 732831,
+    "monitored": true,
+    "name": "AMS-GEN-KAUST-SCION",
+    "scid": "c63fc8f0-7c84-43e5-9430-e2fca1bedfcb",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02418",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.117.88/31"
+        ],
+        "hostname": "rt1.kie.ua.geant.net",
+        "interface": "ae2.998"
+      }
+    ],
+    "imsid": 713313,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-KIE-UA",
+    "scid": "c648e129-b7b9-4c78-bbf3-5bc66018c2f1",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00152",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIAE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.121/30",
+          "2001:798:99:1::8d/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae16.100"
+      }
+    ],
+    "imsid": 734246,
+    "monitored": true,
+    "name": "NL-KIAE",
+    "scid": "c65bd8e2-6e6a-421f-82df-edea4123a75f",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00896",
+    "speed": 32212254720,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.120.65/29"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae2.310"
+      }
+    ],
+    "imsid": 740700,
+    "monitored": false,
+    "name": "DTN-PROJECT-VLAN310",
+    "scid": "c662da28-422a-421a-b184-c6c246d67b6e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00142",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661383,
+    "monitored": false,
+    "name": "XANTARO-SERVICE-ENGINE-REMOTEKVM-LON2-VLAN940",
+    "scid": "c66721fa-422b-4cb8-aa96-76bd47249a5d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00388",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ENSTINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.301"
+      }
+    ],
+    "imsid": 734573,
+    "monitored": false,
+    "name": "NL-ENSTINET-IAS",
+    "scid": "c67758f9-c224-47a7-a94a-c6d9d7401d5e",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00579",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "xe-0/0/40"
+      }
+    ],
+    "imsid": 721387,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-010(GEANT)",
+    "scid": "c67a3ca0-0cba-410a-8345-3dfa4a0fb559",
+    "service_type": "ETHERNET",
+    "sid": "GA-01668",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/26"
+      }
+    ],
+    "imsid": 658649,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-044(ETH)",
+    "scid": "c68d5615-2d47-4fde-b8be-bca37088df5e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01228",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.vie.at.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 740750,
+    "monitored": true,
+    "name": "VIE-VIE-LAG",
+    "scid": "c69101bb-1942-4400-b11f-6ea34ee7e363",
+    "service_type": "ETHERNET",
+    "sid": "GA-02562",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 677786,
+    "monitored": false,
+    "name": "SOF OOB LINK",
+    "scid": "c6a4a1cf-5682-4937-a6b0-73bb86ab4a35",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00417",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 677790,
+    "monitored": false,
+    "name": "TAL OOB LINK",
+    "scid": "c6af1acd-ca4e-4b71-9716-9c2a5a48f654",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00418",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ORANGE"
+    ],
+    "endpoints": [],
+    "imsid": 733923,
+    "monitored": true,
+    "name": "NL-ORANGE-LAG-1",
+    "scid": "c6c02e10-8e53-41e7-8266-cfde5355c3a1",
+    "service_type": "ETHERNET",
+    "sid": "GA-02141",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 719588,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-001(GEANT)",
+    "scid": "c7090b30-837a-4078-859b-d9c6cf88659a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01586",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ASNET-AM"
+    ],
+    "endpoints": [],
+    "imsid": 746552,
+    "monitored": false,
+    "name": "ASNET-AM-AP2-TEST",
+    "scid": "c726ebd2-1454-4a1c-a900-0edb44ba6289",
+    "service_type": "GEANT IP",
+    "sid": "TS-00430",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae11"
+      }
+    ],
+    "imsid": 743291,
+    "monitored": true,
+    "name": "DFN-AP1-LAG-400G",
+    "scid": "c73589e3-fd22-4fe7-bc54-4c0ae4de7efc",
+    "service_type": "ETHERNET",
+    "sid": "GA-01957",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BREN"
+    ],
+    "endpoints": [],
+    "imsid": 712354,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-BREN-BG",
+    "scid": "c761998e-3f08-4dec-8031-76d94f536c28",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01013",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "Belnet CONFINE BRU L3VPN",
+    "scid": "c79892fd-1b39-4355-b090-05aa1bd4b5df",
+    "service_type": null,
+    "sid": "DS-28049",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [],
+    "imsid": 708305,
+    "monitored": true,
+    "name": "GEN513-EEX-ESNET-1G",
+    "scid": "c79c24dd-0402-4ac9-a011-abc778fbefc0",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00187",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae10.4088"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.22"
+      }
+    ],
+    "imsid": 707295,
+    "monitored": true,
+    "name": "GARR-ROMA_EXPRESSROUTE_VLAN4088",
+    "scid": "c7af49ba-94ec-413a-b819-14b37888133e",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01147",
+    "speed": 332859965440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 739238,
+    "monitored": true,
+    "name": "PRA-PRA-LAG",
+    "scid": "c7c2ba71-7c2a-433f-b643-99d5e5b9b26d",
+    "service_type": "ETHERNET",
+    "sid": "GA-02543",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [],
+    "imsid": 714986,
+    "monitored": false,
+    "name": "DTN-JISC-NETHERLIGHT-21093",
+    "scid": "c7c44b27-02eb-4ed0-b1d0-be676f0e8cf0",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00688",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RARE"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.1916"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.1916"
+      }
+    ],
+    "imsid": 736072,
+    "monitored": false,
+    "name": "AMS-PAR-RARE-INTERNET2-RNP-20061",
+    "scid": "c7f1bf65-eb72-4f3d-af16-6b93695dadc1",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00655",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.420"
+      },
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-20:420"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae34.420"
+      }
+    ],
+    "imsid": 745831,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-ETHS-409(GEANT)",
+    "scid": "c7f5e6de-99d1-4a67-9bf0-ae9aee46dba1",
+    "service_type": "ETHERNET",
+    "sid": "GS-02211",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "SANET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae13"
+      }
+    ],
+    "imsid": 718826,
+    "monitored": true,
+    "name": "SANET-AP1-LAG",
+    "scid": "c7fe2cc8-d104-461c-82c8-81a3deca515c",
+    "service_type": "ETHERNET",
+    "sid": "GA-02157",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.112.2/29",
+          "2001:799:cb2::2/64"
+        ],
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/3.501"
+      }
+    ],
+    "imsid": 663189,
+    "monitored": false,
+    "name": "SRX1-CITY-HOUSE-WAN-GATEWAY",
+    "scid": "c80fdf8c-c8b4-4dc2-a27a-ff02df72d61b",
+    "service_type": "CORPORATE",
+    "sid": "GS-01744",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658993,
+    "monitored": true,
+    "name": "BRUSSELS-BRUSSELS-1GBE-006(ETH)",
+    "scid": "c816804c-afdd-4a68-ab4c-fdc68d1f21c5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01360",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SINGAREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "203.30.38.93/31",
+          "2001:df0:21a:fff2:0:20:965:1/64"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.3160"
+      }
+    ],
+    "imsid": 661924,
+    "monitored": true,
+    "name": "UK-CAE1-SINGAREN",
+    "scid": "c83ba1d9-bff1-4947-8585-dc997f3be6a5",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00912",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663125,
+    "monitored": false,
+    "name": "PSMP3-MANAGEMENT-LHCONE",
+    "scid": "c84075b9-ba96-4191-aff3-b2fc99af8eac",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00368",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.254.5/30"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "gr-4/0/0.1"
+      }
+    ],
+    "imsid": 736088,
+    "monitored": false,
+    "name": "TUNNEL-FORTIGATE-AMSTERDAM",
+    "scid": "c854bca5-a89b-44aa-b307-46c4b712d592",
+    "service_type": "L3-VPN",
+    "sid": "GS-01113",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663098,
+    "monitored": false,
+    "name": "PS-BUD-HU-MANAGEMENT",
+    "scid": "c85a204a-d7c4-47bf-9e80-d731ab2a763c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00294",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.13/30",
+          "2001:798:1::111/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae14.333"
+      }
+    ],
+    "imsid": 678048,
+    "monitored": true,
+    "name": "RENATER-AP2-IAS",
+    "scid": "c8b67507-835d-47b7-b137-4bc0d1a7104d",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00584",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CSTNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.26/31",
+          "2001:798:99:1::5/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.1007"
+      }
+    ],
+    "imsid": 732232,
+    "monitored": true,
+    "name": "UK-CAE-1-CSTNET-SECONDARY",
+    "scid": "c8bee5bf-01ee-4d42-89fb-894e85597692",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02391",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662932,
+    "monitored": false,
+    "name": "AMS-GROOVE-1",
+    "scid": "c8c28f15-a34b-4fa0-8af4-f00e3ad618d2",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00091",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 728004,
+    "monitored": true,
+    "name": "AMS-PSMP-PS BWCTL(GEANT)",
+    "scid": "c8e8c5e0-8e1c-4e58-8eb5-20d609d597c6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01638",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.24/31",
+          "2001:798:111:1::95/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae23.111"
+      }
+    ],
+    "imsid": 733852,
+    "monitored": true,
+    "name": "CESNET-AP2-LHCONE",
+    "scid": "c90af496-4a28-4cd1-a177-b27967b34f06",
+    "service_type": "L3-VPN",
+    "sid": "GS-02455",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "XE-2/2/0"
+      }
+    ],
+    "imsid": 658501,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-10GBE-003(ETH)",
+    "scid": "c9403b16-b52b-4764-871f-85b502acf386",
+    "service_type": "ETHERNET",
+    "sid": "GA-01279",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CYNET"
+    ],
+    "endpoints": [],
+    "imsid": 736657,
+    "monitored": false,
+    "name": "CYNET-AP3-IAS",
+    "scid": "c942c0da-21af-40fa-93da-4e7f159915f1",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00526",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.209/30",
+          "2001:0798:0028:10aa::11/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae11.1103"
+      }
+    ],
+    "imsid": 660540,
+    "monitored": true,
+    "name": "SURF-AP2",
+    "scid": "c94845ef-6002-45a8-98cb-a4f207e6b31b",
+    "service_type": "GEANT IP",
+    "sid": "GS-00513",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743134,
+    "monitored": true,
+    "name": "DUB-DUB-IPTRUNK",
+    "scid": "c99ec2e5-547d-4da7-b9ae-6ba9d8f98571",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02621",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "217.29.66.183/21",
+          "2001:7f8:b:100:1d1:a5d2:965:183/64"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae20.0"
+      }
+    ],
+    "imsid": 708323,
+    "monitored": false,
+    "name": "IX-PEERINGS-IN-MIX",
+    "scid": "c9a4f7b5-3126-4ec9-b5d0-178117a60880",
+    "service_type": "IP PEERING - NON R&E (PUBLIC)",
+    "sid": "GS-00952",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.149/30",
+          "2001:0798:001b:10aa::29/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae12.36"
+      }
+    ],
+    "imsid": 730104,
+    "monitored": true,
+    "name": "CARNET-AP2",
+    "scid": "c9aef082-e342-4e48-8c9a-57805a1d9d48",
+    "service_type": "GEANT IP",
+    "sid": "GS-00441",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/6"
+      }
+    ],
+    "imsid": 658621,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-039(ETH)",
+    "scid": "c9beda45-f721-47b9-8b22-1f6f991212e3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01234",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.29"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240588"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4080"
+      }
+    ],
+    "imsid": 744146,
+    "monitored": true,
+    "name": "MSEUCLOUVAIN-02152",
+    "scid": "c9c70e8d-8f14-44e4-ada6-d1ba6c3e1414",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02152",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.33"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4084"
+      }
+    ],
+    "imsid": 739669,
+    "monitored": true,
+    "name": "BELNET-KULEUVEN-EXPRESSROUTE-4084",
+    "scid": "c9d3556a-bb2d-4b13-89ae-eb626906a0f1",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01135",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "80.81.192.173/21",
+          "2001:7f8::51e5:0:1/64"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae20.100"
+      }
+    ],
+    "imsid": 730796,
+    "monitored": false,
+    "name": "IX-PEERINGS-IN-DE-CIX-FRA",
+    "scid": "c9de51c7-7e2d-4570-ac0a-a5a652237dbc",
+    "service_type": "IP PEERING - NON R&E (PUBLIC)",
+    "sid": "GS-00947",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707278,
+    "monitored": true,
+    "name": "POZ-VIE-LAG",
+    "scid": "c9eb9934-f8da-4b0c-9eba-ce042a41e154",
+    "service_type": "ETHERNET",
+    "sid": "GA-01813",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "195.169.24.26/29",
+          "2001:610:9d8:1::2/64"
+        ],
+        "hostname": "srx2.am.office.geant.net",
+        "interface": "ge-0/0/0.50"
+      }
+    ],
+    "imsid": 663042,
+    "monitored": false,
+    "name": "SRX2-AMS-TO-FW-WAN",
+    "scid": "c9f58189-ad91-44df-b352-69d9ea80a002",
+    "service_type": "CORPORATE",
+    "sid": "GS-01746",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.2021"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.2021"
+      }
+    ],
+    "imsid": 736882,
+    "monitored": true,
+    "name": "NORDU-TO-WIX-2021",
+    "scid": "c9fd12ba-3ffc-4336-9d0c-a2394dfe835d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00743",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679112,
+    "monitored": true,
+    "name": "TAL-TAL-LAG",
+    "scid": "ca13c091-d212-486b-a3cb-a7d4aa6b5c60",
+    "service_type": "ETHERNET",
+    "sid": "GA-02052",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 658833,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-054(ETH)",
+    "scid": "ca201ab3-f805-44fa-8edb-172febc2f348",
+    "service_type": "ETHERNET",
+    "sid": "GA-01320",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CIXP"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae18"
+      }
+    ],
+    "imsid": 662507,
+    "monitored": true,
+    "name": "CIXP-LAG",
+    "scid": "ca2cff36-bdaf-4158-95fc-bd1bcaf41df2",
+    "service_type": "ETHERNET",
+    "sid": "GA-01881",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.148/31",
+          "2001:798:cc:1::91/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae1.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.149/31",
+          "2001:798:cc:1::92/126"
+        ],
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-1.0"
+      }
+    ],
+    "imsid": 746147,
+    "monitored": true,
+    "name": "MAR-MIL2-IPTRUNK",
+    "scid": "ca39e8f6-2fbd-4d04-ba99-153276b2bc99",
+    "service_type": "IP TRUNK",
+    "sid": "GS-01185",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/0/2.0"
+      }
+    ],
+    "imsid": 740087,
+    "monitored": false,
+    "name": "PS-GEN-CH-BWCTL",
+    "scid": "ca532cfd-bea1-40c7-9574-35699196d319",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00307",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "CARNET"
+    ],
+    "endpoints": [],
+    "imsid": 709736,
+    "monitored": true,
+    "name": "CARNET EUMETCAST AP1",
+    "scid": "ca8d32ee-cbf9-4304-ba4d-20ef4ca1e3c6",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01097",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 726093,
+    "monitored": true,
+    "name": "GARR-AP1-LAG",
+    "scid": "caa54ef7-b04a-4f74-882c-889a0a57c95e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01773",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.77/30"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae13.104"
+      }
+    ],
+    "imsid": 730102,
+    "monitored": true,
+    "name": "CH-ESNET-IPV4",
+    "scid": "cac678e8-45d9-4472-a7b3-61d498b19b53",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00872",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659095,
+    "monitored": true,
+    "name": "PAR01-DTNX10-1-XCM2-1GBE-008(ETH)",
+    "scid": "cad079b3-506f-4270-80b2-d8df493219c7",
+    "service_type": "ETHERNET",
+    "sid": "GA-01406",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.13"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240591"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4087"
+      }
+    ],
+    "imsid": 744148,
+    "monitored": true,
+    "name": "MSEICT-01133",
+    "scid": "cb832ef3-f739-4bc3-b9ef-ffac677e5dd8",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01133",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "DE259558"
+      },
+      {
+        "equipment": "DIGITAL REALTY Z-END",
+        "port": "DE259558"
+      }
+    ],
+    "imsid": 739824,
+    "monitored": true,
+    "name": "FRA-POZ-PSNC-24052-2",
+    "scid": "cc0fc4ec-c521-4ae1-bfb7-8431a8f3e356",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02550",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ACONET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.216/31",
+          "2001:798:1::1ad/126"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae18.52"
+      }
+    ],
+    "imsid": 661759,
+    "monitored": true,
+    "name": "ACONET-AP2-IAS",
+    "scid": "cc5f3b04-63ee-4f93-89c2-ff9d7cec0f13",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00551",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 731211,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-LJU-SI",
+    "scid": "cc75f98b-d911-4fbe-a119-2f4d1d8f7aee",
+    "service_type": "SERVER LINK",
+    "sid": "GS-XXXXX",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 730153,
+    "monitored": false,
+    "name": "BRU-LON-IX-BELNET-BELNET-20009",
+    "scid": "cc862dc4-45d2-43b9-ba9c-deea02151e52",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00789",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae5"
+      }
+    ],
+    "imsid": 735410,
+    "monitored": true,
+    "name": "AMS-AMS-800G-LAG",
+    "scid": "cccb78db-0584-4c94-ae86-8528f036ad77",
+    "service_type": "ETHERNET",
+    "sid": "GA-02456",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 721142,
+    "monitored": true,
+    "name": "AMS-PAR-LOFAR-RENATER-NETHERLIGHT-10001-LL1",
+    "scid": "ccd32cbc-dae0-4bde-b589-14c2f1ba5926",
+    "service_type": "ETHERNET",
+    "sid": "GA-01388",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661457,
+    "monitored": false,
+    "name": "LON-SINET-EDGE-DEVICE-IDRAC",
+    "scid": "ccff1277-f356-4359-9abc-f1e31e28d598",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00234",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.42/31",
+          "2001:798:99:1::69/126"
+        ],
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-20.100"
+      }
+    ],
+    "imsid": 745279,
+    "monitored": true,
+    "name": "GRNET-AP2",
+    "scid": "cd200521-330b-4fa8-b689-70c18e69bb67",
+    "service_type": "GEANT IP",
+    "sid": "GS-00472",
+    "speed": 64424509440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658896,
+    "monitored": true,
+    "name": "VIENNA-VERIZON-LL-2-2",
+    "scid": "cd28abe0-b9e7-427c-8b7f-334725c2c996",
+    "service_type": "ETHERNET",
+    "sid": "GA-01490",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "Now ASREN LAG",
+    "scid": "cd2aabc3-648a-4f39-b553-7127c7285bda",
+    "service_type": null,
+    "sid": "GS-01758",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658883,
+    "monitored": true,
+    "name": "BRATISLAVA-BRATISLAVA-1GBE-008(ETH)",
+    "scid": "cd5bbe1f-3f2a-46d8-b187-c5407f9aa9c8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01303",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663064,
+    "monitored": false,
+    "name": "OLD",
+    "scid": "cd5e7f8e-2282-4655-bb0d-1da355601739",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00293",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663123,
+    "monitored": false,
+    "name": "NTP6.GEANT.NET",
+    "scid": "cd6579a0-e820-4bd5-9da4-4e6e5f46dfa8",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00262",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "LAT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.2009"
+      },
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "pwe-119052"
+      },
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-20:cp-2009"
+      }
+    ],
+    "imsid": 745942,
+    "monitored": true,
+    "name": "LOFAR-00663",
+    "scid": "cd6722d5-af7f-4d81-a27b-1f111e56c5b2",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00663",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.245/30",
+          "2001:798:99:1::59/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-20.100"
+      }
+    ],
+    "imsid": 744953,
+    "monitored": true,
+    "name": "BREN-AP1",
+    "scid": "cdb20727-90f0-4c2c-8e6d-6fac841703fd",
+    "service_type": "GEANT IP",
+    "sid": "GS-00438",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [],
+    "imsid": 705896,
+    "monitored": true,
+    "name": "AMS-DUB-KNMI-ME-1-SURF-HEANET-20045",
+    "scid": "ce04f84a-3086-4324-aa27-754ce07a466d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00631",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663169,
+    "monitored": false,
+    "name": "NTP4.GEANT.NET",
+    "scid": "ce0e8bb0-f6ae-49cd-9c83-ab4eb7e63b05",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00260",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660455,
+    "monitored": false,
+    "name": "LON2-GROOVE-1",
+    "scid": "ce1e6140-2e95-45ed-84c8-661ca46a6f57",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00238",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.40"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240571"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4070"
+      }
+    ],
+    "imsid": 744256,
+    "monitored": true,
+    "name": "MSEFEDPOL-02524",
+    "scid": "ce3c927c-fb1e-47ed-9755-4c2e5cfd0e26",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02524",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "UBUNTUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/5.1500"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.1500"
+      }
+    ],
+    "imsid": 734613,
+    "monitored": true,
+    "name": "AMS-LON-JIVE-NETHERLIGHT-UBUNTUNET-12008",
+    "scid": "ce8f3f15-dd6b-49f7-9815-d0f830e1704b",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00645",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/3.1032"
+      }
+    ],
+    "imsid": 661942,
+    "monitored": true,
+    "name": "SDN-BOD-BR53-OF-2-HOST-H-ETH1",
+    "scid": "ce90dc7d-4712-4e2c-a168-4451290886e8",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00756",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/1/7"
+      }
+    ],
+    "imsid": 733208,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-027(GEANT)",
+    "scid": "cecf64bf-c5b5-4ad0-8f42-e213434f1c8e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01327",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 673548,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10GBE-035(GEANT)",
+    "scid": "ced96333-c17d-4062-822d-3590d753756d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01752",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/2/3"
+      }
+    ],
+    "imsid": 720005,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-10GBE-012(GEANT)",
+    "scid": "cee65467-4691-475c-a62a-7271db8ff9a1",
+    "service_type": "ETHERNET",
+    "sid": "GA-02189",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "ae11.500"
+      },
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae1.500"
+      }
+    ],
+    "imsid": 728645,
+    "monitored": true,
+    "name": "PRA-VIE-CESNET-AP1-CESNET-AP2",
+    "scid": "ceecb999-0473-4a5a-bbbb-d31d27c87e5d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02344",
+    "speed": 225485783040,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.42"
+      },
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.691"
+      }
+    ],
+    "imsid": 740766,
+    "monitored": true,
+    "name": "REDIRIS-ICN2-EXPRESSROUTE-VLAN691",
+    "scid": "cf450d34-80f9-4d5e-96c2-423f0a3bde05",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02559",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.42/31",
+          "2001:798:cc:1::11d/126"
+        ],
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae1.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.43/31",
+          "2001:798:cc:1::11e/126"
+        ],
+        "hostname": "rt2.bra.sk.geant.net",
+        "interface": "ae1.0"
+      }
+    ],
+    "imsid": 731789,
+    "monitored": false,
+    "name": "BRA-BRA-IPTRUNK",
+    "scid": "cf62a005-e362-46b9-a3a6-325028dac384",
+    "service_type": "IP TRUNK",
+    "sid": "GS-01205",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.33.253/24"
+        ],
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae3.103"
+      }
+    ],
+    "imsid": 731614,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-BRA1-SK",
+    "scid": "cf86b03f-5196-4733-a09d-0224957ba9f7",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00114",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.112.3/29",
+          "2001:799:cb2::3/64"
+        ],
+        "hostname": "srx2.ch.office.geant.net",
+        "interface": "ge-0/0/3.501"
+      }
+    ],
+    "imsid": 663110,
+    "monitored": false,
+    "name": "CAM-CH-WAN-GATEWAY-2",
+    "scid": "cf95c776-7c22-45e0-ad5c-004758163354",
+    "service_type": "CORPORATE",
+    "sid": "GS-01195",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/8"
+      }
+    ],
+    "imsid": 725639,
+    "monitored": true,
+    "name": "PRAGUE 2-PRAGUE 2-10GBE-007(GEANT)",
+    "scid": "cfab41d6-3fa5-4373-97b0-d0309b75787c",
+    "service_type": "ETHERNET",
+    "sid": "GA-02285",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "DUB-LON-IPTRUNK",
+    "scid": "cfe49030-8d18-4bf4-af83-fadf71ad76f1",
+    "service_type": null,
+    "sid": "DS-25851",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.205/30",
+          "2001:798:22:10aa::9/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21.100"
+      }
+    ],
+    "imsid": 747589,
+    "monitored": true,
+    "name": "NORDUNET-AP2",
+    "scid": "cff07a10-55b1-487f-87a6-4d1078926e5d",
+    "service_type": "GEANT IP",
+    "sid": "GS-00493",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae31.0"
+      },
+      {
+        "addresses": [
+          "62.40.99.128/31",
+          "2001:798:4::1/64"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae16.100"
+      }
+    ],
+    "imsid": 661315,
+    "monitored": false,
+    "name": "GEANT-SLOUGH-ACCESS",
+    "scid": "cff4798f-d9e2-4fc4-9da3-70632c6311ab",
+    "service_type": "CORPORATE",
+    "sid": "GS-00469",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NISN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.519"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.519"
+      }
+    ],
+    "imsid": 709305,
+    "monitored": true,
+    "name": "LON-PAR-CNES-NISN-RENATER",
+    "scid": "d002e64a-83fc-4ec4-bc46-bda9f0797d80",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00736",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae14"
+      }
+    ],
+    "imsid": 734179,
+    "monitored": true,
+    "name": "NL-SWITCH-AMS-IX-LAG",
+    "scid": "d0036e59-f4c0-4d43-b044-4b7b42493af9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01912",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lon.uk.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 738597,
+    "monitored": true,
+    "name": "AMS-LON-1.6T-LAG",
+    "scid": "d025b23f-9550-4555-958a-47a5dcef3c39",
+    "service_type": "ETHERNET",
+    "sid": "GA-02268",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "addresses": [
+          "62.40.123.58/29",
+          "2001:798:bb:4::2/64"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "irb.3003"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae30.3003"
+      }
+    ],
+    "imsid": 733021,
+    "monitored": false,
+    "name": "PS-THROUGHPUT-NETWORK-FRA-DE",
+    "scid": "d0292373-2dd5-4039-be72-ff51169cb943",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00299",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.98/31",
+          "2001:798:cc:1::7d/126"
+        ],
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "ae3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.99/31",
+          "2001:798:cc:1::7e/126"
+        ],
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "ae3.0"
+      }
+    ],
+    "imsid": 713101,
+    "monitored": true,
+    "name": "CHI-KIE-IPTRUNK",
+    "scid": "d02a13a6-b710-46ef-9ee4-250e09f1a37f",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00029",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 747866,
+    "monitored": true,
+    "name": "SOF-ZAG-LAG",
+    "scid": "d04c73f8-db92-4732-ad93-c650e164f0f8",
+    "service_type": "ETHERNET",
+    "sid": "GA-02369",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRENA"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "xe-4/2/3.0"
+      },
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae20.210"
+      }
+    ],
+    "imsid": 719668,
+    "monitored": true,
+    "name": "VIE-VIE-EAP-GRENA-COGENT-22035",
+    "scid": "d04dbc76-f3cd-48a7-83ca-314b9aa5a1f7",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00695",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662390,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-10GBE-089(GEANT)",
+    "scid": "d059e580-6855-4757-9126-d823505a8535",
+    "service_type": "ETHERNET",
+    "sid": "GA-01604",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.16/31",
+          "2001:798::1d/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae12.667"
+      }
+    ],
+    "imsid": 663166,
+    "monitored": false,
+    "name": "GARR-AP2-CLS",
+    "scid": "d05d7e38-418c-49e8-88bf-02b85c08d888",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00607",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708105,
+    "monitored": false,
+    "name": "PS-PRA-CZ-BWCTL",
+    "scid": "d07ec0be-f2bc-466f-83cc-2dfa5eb2a8cd",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00347",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661541,
+    "monitored": false,
+    "name": "TAAS-CONTROL-LON-UK-VLAN260",
+    "scid": "d08130ed-c29b-4f91-97c0-4739feaae93d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00373",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "VERIZON"
+    ],
+    "endpoints": [],
+    "imsid": 731606,
+    "monitored": true,
+    "name": "FRANKFURT-VERIZON-1-LAG",
+    "scid": "d094ee7a-bab5-4d19-8724-cfd69c1f5e6b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01951",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/2/3"
+      }
+    ],
+    "imsid": 721148,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-005(GEANT)",
+    "scid": "d0ad0d4f-2f3b-4733-934d-476639ed5cea",
+    "service_type": "ETHERNET",
+    "sid": "GA-02191",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ACONET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.40/31",
+          "2001:798::49/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae15.667"
+      }
+    ],
+    "imsid": 661215,
+    "monitored": true,
+    "name": "ACONET-AP-CLS",
+    "scid": "d0effc91-ba8a-49a8-b00e-70b632a9ff10",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00595",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.BRA.SK.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 677546,
+    "monitored": false,
+    "name": "BRA OOB LINK",
+    "scid": "d0f3031c-b9ad-465c-8384-83ab06874698",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00392",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "AT-AWS-CLS|ASN16509",
+    "scid": "d0fa942e-d9f8-41a9-b869-aaa386887acf",
+    "service_type": null,
+    "sid": "GS-00597",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.BIL.ES",
+        "port": "AE1"
+      }
+    ],
+    "imsid": 709429,
+    "monitored": true,
+    "name": "LAG-SW1.BIL.ES_AE1",
+    "scid": "d103e966-f663-4387-ba51-5990632039b2",
+    "service_type": "ETHERNET",
+    "sid": "GA-02056",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 745923,
+    "monitored": true,
+    "name": "KAU-RIG-IP1",
+    "scid": "d12e1360-cd9f-4e7b-a43f-23c4ce689cf6",
+    "service_type": "ETHERNET",
+    "sid": "GA-D00011    ---TEMP",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "TIFR LHCONE GEN L3VPN",
+    "scid": "d135cc65-c9a5-419f-83ab-ea629dfcd609",
+    "service_type": null,
+    "sid": "DS-30073",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 734321,
+    "monitored": true,
+    "name": "THE-THE-LAG",
+    "scid": "d13c60d8-c415-4ea8-bddc-ab80a4abbc3a",
+    "service_type": "ETHERNET",
+    "sid": "GA-02428",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 715011,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-001(GEANT)",
+    "scid": "d1ee1aaa-333d-4410-84b0-4188cd7af48f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01312",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.69/30",
+          "2001:798:18:10aa::1/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.160"
+      }
+    ],
+    "imsid": 661272,
+    "monitored": true,
+    "name": "RENATER-AP1",
+    "scid": "d1ff1057-25d7-4793-bbe4-85df185237ce",
+    "service_type": "GEANT IP",
+    "sid": "GS-00505",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/2"
+      }
+    ],
+    "imsid": 678559,
+    "monitored": true,
+    "name": "LONDON-LONDON-10GBE-026(GEANT)",
+    "scid": "d2017c5e-19b5-4de9-85db-0eba31a02c3f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01658",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae11.2708"
+      },
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:2103"
+      }
+    ],
+    "imsid": 747540,
+    "monitored": false,
+    "name": "HAM-POZ-02494",
+    "scid": "d22515e7-bd25-43b0-8b03-dc2b6460b8b3",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02494",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.36/31",
+          "2001:798:99:1::a1/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae12.3242"
+      }
+    ],
+    "imsid": 742536,
+    "monitored": true,
+    "name": "FR-HARNET",
+    "scid": "d2546c58-d676-406d-9923-e3867bbe02d3",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02538",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 745566,
+    "monitored": true,
+    "name": "DFN-AP2-LAG",
+    "scid": "d263437d-e8a7-42e7-9a0b-e0f8edf38a5b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01894",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707587,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-MIL2-IT",
+    "scid": "d286bf62-74a3-4c1c-941d-4003bf2ac06d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00123",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "addresses": [
+          "62.40.108.65/27",
+          "2001:798:ee:19::1/64"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae30.2001"
+      }
+    ],
+    "imsid": 712148,
+    "monitored": false,
+    "name": "ESXI-MANAGEMENT-PAR",
+    "scid": "d2990a5e-2fb9-4cf0-9bdc-eb01c39f025b",
+    "service_type": "POP LAN LINK",
+    "sid": "GS-00075",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ASREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.169/30",
+          "2001:798:99:1::3d/126"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae17.500"
+      }
+    ],
+    "imsid": 661959,
+    "monitored": true,
+    "name": "UK-ASREN",
+    "scid": "d29fbc96-5569-4ae0-9629-6068d62944e3",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00911",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658872,
+    "monitored": true,
+    "name": "MADRID-MADRID-1GBE-005(ETH)",
+    "scid": "d2a5687f-3f32-4f77-9682-4cfa56c1b5cf",
+    "service_type": "ETHERNET",
+    "sid": "GA-01351",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT-IT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "xe-0/0/42"
+      },
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/42"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/0/4.0"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/1/7.0"
+      }
+    ],
+    "imsid": 729412,
+    "monitored": true,
+    "name": "PAR-LON2-SUPERPOP-QFX-GEANT",
+    "scid": "d2ef0373-296d-4b75-95ba-412c0846a30a",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00080",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.109.1/30"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "gr-3/0/0.11"
+      }
+    ],
+    "imsid": 732668,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-NMO",
+    "scid": "d2f10c06-1302-481f-9195-e005b76702d7",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01085",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.13/31",
+          "2001:798:cc:1::1e/126"
+        ],
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.12/31",
+          "2001:798:cc:1::1d/126"
+        ],
+        "hostname": "rt0.cor.ie.geant.net",
+        "interface": "lag-4.0"
+      }
+    ],
+    "imsid": 747279,
+    "monitored": true,
+    "name": "COR-DUB-IPTRUNK",
+    "scid": "d30fd7e7-9a03-4323-9fd0-14ea39d3b7e1",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02383",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMS01-GRV7",
+        "port": "1/1/8"
+      },
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "NL261658-2"
+      },
+      {
+        "equipment": "DIGITAL REALTY Z-END",
+        "port": "NL261658-2"
+      }
+    ],
+    "imsid": 739848,
+    "monitored": true,
+    "name": "AMS-GEN1-ESNET-24015-3-400G",
+    "scid": "d32ecb31-da44-4b00-b5ae-40eb62c9dae5",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02454",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ASREN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.189/30",
+          "2001:798:1::e1/126"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "ae17.333"
+      }
+    ],
+    "imsid": 661220,
+    "monitored": true,
+    "name": "UK-ASREN-IAS",
+    "scid": "d333c55c-2e16-49a5-85a0-9f4f0502a0e4",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00547",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679310,
+    "monitored": false,
+    "name": "FRA-TNMS",
+    "scid": "d336f7e1-8138-4d04-816d-c5ef8671e1aa",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00178",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708293,
+    "monitored": true,
+    "name": "BUDAPEST-BUDAPEST-ETHS-001(GEANT)",
+    "scid": "d34a5ae0-ed01-4d6a-a7b9-476e2c45ba0f",
+    "service_type": "ETHERNET",
+    "sid": "GS-00292",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659277,
+    "monitored": true,
+    "name": "BRATISLAVA-BRATISLAVA-1GBE-014(ETH)",
+    "scid": "d353b1b0-cfe7-4c57-ac43-55423ac766f8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01305",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 707029,
+    "monitored": true,
+    "name": "AMS-BRU-IMINDS-IMINDS-NETHERLIGHT-15012",
+    "scid": "d36f9d99-ac69-4f3a-9fe1-3b62818996ce",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00629",
+    "speed": 215822106624,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 739969,
+    "monitored": true,
+    "name": "HAM-HAM-LAG-300G",
+    "scid": "d3786ffb-02f3-4042-af36-4e64257ef23f",
+    "service_type": "ETHERNET",
+    "sid": "GA-02541",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661678,
+    "monitored": false,
+    "name": "OWAMP-PRA-CZ",
+    "scid": "d385dc29-f0a5-45e4-bd4f-b5f183d1422c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00269",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.5.1/24"
+        ],
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae2.103"
+      }
+    ],
+    "imsid": 679548,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-LIS-PT",
+    "scid": "d39aa021-dfe1-4137-9fe1-4eb7787e0571",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00118",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "2001:798:111:1::41/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae33.4005"
+      }
+    ],
+    "imsid": 740765,
+    "monitored": true,
+    "name": "NL-NORDUNET-LHCONE-IPV6",
+    "scid": "d3bf78da-77c6-4aeb-a54c-cd2a1650186c",
+    "service_type": "L3-VPN",
+    "sid": "GS-00839",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "WACREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.2033"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae22.2033"
+      }
+    ],
+    "imsid": 705942,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-NORDUNET-WACREN-20041",
+    "scid": "d3c58db5-4d61-421c-913c-8780c52ebc9f",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00979",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 658668,
+    "monitored": true,
+    "name": "LAG-QFX.PAR.FR_AE2",
+    "scid": "d3d20f59-38e0-4d42-8d88-ed87e9e6dabd",
+    "service_type": "ETHERNET",
+    "sid": "GA-01720",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 719291,
+    "monitored": false,
+    "name": "BELNET-SMALSDC-EXPRESSROUTE-VLAN4083",
+    "scid": "d3d2b37b-30ca-4de6-a587-bc7dc1a8bef0",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02150",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662402,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-10GBE-095(GEANT)",
+    "scid": "d3d32961-c817-418f-8070-02d2f3d28994",
+    "service_type": "ETHERNET",
+    "sid": "GA-01650",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CSTNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.186/31",
+          "2001:798:99:1::131/126"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae12.1006"
+      }
+    ],
+    "imsid": 729006,
+    "monitored": true,
+    "name": "FR-IC1-CSTNET-QUINARY",
+    "scid": "d3ee13ff-c8f8-4dc4-85ef-b40070067ba4",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02362",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae12"
+      }
+    ],
+    "imsid": 659344,
+    "monitored": true,
+    "name": "GOOGLE-15169-IT-LAG",
+    "scid": "d40499de-3611-4368-b3db-1a785aaf7bf9",
+    "service_type": "ETHERNET",
+    "sid": "GA-01771",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679555,
+    "monitored": true,
+    "name": "BUD-LJU-LAG",
+    "scid": "d43c67ce-031b-411e-a9ae-aa5d74ee0248",
+    "service_type": "ETHERNET",
+    "sid": "GA-01908",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.936"
+      },
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.936"
+      }
+    ],
+    "imsid": 736075,
+    "monitored": false,
+    "name": "AMS-BIL-REDIRIS-RARE",
+    "scid": "d45885b2-27b2-4366-afcf-5527c66be7ec",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02287",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663025,
+    "monitored": false,
+    "name": "KVMOIP-BUD-HU",
+    "scid": "d46b021f-8941-4302-b86a-dfd3d6a7ff54",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00219",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 728632,
+    "monitored": true,
+    "name": "KAU-POZ-IP1",
+    "scid": "d4c50dc7-d0c4-4aa9-9f33-d80785078bcd",
+    "service_type": "ETHERNET",
+    "sid": "GA-D0009",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 732509,
+    "monitored": false,
+    "name": "A10-DDOS-SCRUBBING-FRA",
+    "scid": "d4e1b55b-e683-4dc5-887c-fd9c34a7e2c9",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00086",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708255,
+    "monitored": false,
+    "name": "PS-LIS-PT-MANAGEMENT",
+    "scid": "d4f52794-9c67-4f4b-ab20-fdbdd470751c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00317",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.157/30",
+          "2001:798:99:1::39/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae17.200"
+      }
+    ],
+    "imsid": 662952,
+    "monitored": true,
+    "name": "CERN-AP1",
+    "scid": "d4fe7850-41a9-4f6a-a53b-7724bdcd82a2",
+    "service_type": "GEANT IP",
+    "sid": "GS-00442",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RARE"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.FRA.DE.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-11/0/0.103"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/2.103"
+      }
+    ],
+    "imsid": 716207,
+    "monitored": false,
+    "name": "FRA-PAR-RARE-RARE-21101",
+    "scid": "d50ec833-4324-4b69-a3c8-96e68c5e6541",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00705",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "et-11/3/0"
+      }
+    ],
+    "imsid": 658732,
+    "monitored": true,
+    "name": "PARIS-DTN-100G-1",
+    "scid": "d541a43c-6cbf-4e35-b9d2-fcb69ef1fb2e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01379",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CNGI-6IX"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.101/30",
+          "2001:0798:0028:10aa::25/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-1/0/0.200"
+      }
+    ],
+    "imsid": 661591,
+    "monitored": true,
+    "name": "UK-CNGI-6IX-CERNET",
+    "scid": "d5ad5c25-b1fb-4ccf-8ebd-c7960705334e",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00925",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [],
+    "imsid": 712387,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-GRNET-GR",
+    "scid": "d5b1f3d7-1921-44cc-8bf7-6cbaab0cd6da",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01023",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ams-ams_DREAMER_GARR-GTS_15033",
+    "scid": "d5b63263-3072-4fb8-81e5-8bb117806ef0",
+    "service_type": null,
+    "sid": "DS-29543",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CANARIE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae17.2128"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.2128"
+      }
+    ],
+    "imsid": 679228,
+    "monitored": true,
+    "name": "PAR-PAR-CANARIE-SURF-20058",
+    "scid": "d5c68aa6-3af9-4eb5-857f-40580d9ab83c",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00749",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/1/6"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/1/6.2702"
+      },
+      {
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "pwe-123051"
+      },
+      {
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "lag-20:2702"
+      }
+    ],
+    "imsid": 746442,
+    "monitored": false,
+    "name": "FRA-TAR-SCION-EENET",
+    "scid": "d5cc49df-3ef8-47fa-a409-3470a5a8171d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02357",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "pwe-117003"
+      },
+      {
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-20:2281"
+      }
+    ],
+    "imsid": 747267,
+    "monitored": true,
+    "name": "GEANT_EPIPE_117003",
+    "scid": "d6652088-b6e7-4635-9648-58dc87109db7",
+    "service_type": "ETHERNET",
+    "sid": "GS-00632",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae20.3020"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae2.3020"
+      }
+    ],
+    "imsid": 740717,
+    "monitored": false,
+    "name": "AMS-LON-SINET-SD-WAN-SINET-SINET-17084",
+    "scid": "d66ba55e-f3d1-4878-83cf-f06173877e5d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00648",
+    "speed": 236223201280,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662959,
+    "monitored": false,
+    "name": "RARE-P4-B1-FRA",
+    "scid": "d6728331-5037-4948-8808-f291ef030da8",
+    "service_type": "L2SERVICES",
+    "sid": "GS-00771",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 677344,
+    "monitored": true,
+    "name": "LISBON-LISBON-1GBE-005(ETH)",
+    "scid": "d69fd3fa-fca8-4345-b459-7dbf009c4ae0",
+    "service_type": "ETHERNET",
+    "sid": "GA-01655",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743328,
+    "monitored": true,
+    "name": "TAR-TAR-MGMT-LAG",
+    "scid": "d6a2a430-5fe2-4651-b6b6-06093e5b6694",
+    "service_type": "ETHERNET",
+    "sid": "GA-50004",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.15"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240593"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4088"
+      }
+    ],
+    "imsid": 744268,
+    "monitored": true,
+    "name": "MSENCCN-01136",
+    "scid": "d6bc6414-d7c0-4730-9bda-2ff5459b326d",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01136",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "REDIRIS_AP1_Confine",
+    "scid": "d6c28944-3098-4bdd-b772-005f1a63770f",
+    "service_type": null,
+    "sid": "DS-27555",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.178/31"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.87"
+      }
+    ],
+    "imsid": 715042,
+    "monitored": true,
+    "name": "EUMET-BUCC-MAD-17042",
+    "scid": "d6d4edc5-a3e1-4b98-a801-d11a739aeace",
+    "service_type": "GEANT IP",
+    "sid": "GS-00457",
+    "speed": 430570471424,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [],
+    "imsid": 709787,
+    "monitored": false,
+    "name": "AMS-LON1-EEX-ESNET-2106",
+    "scid": "d6d63a2c-fe3a-4018-8cfe-710e62d3d42e",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-00782",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "LON01-GRV3",
+        "port": "1/3/8"
+      },
+      {
+        "equipment": "AMS01-GRV4",
+        "port": "1/3/8"
+      },
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "NL172777-2"
+      },
+      {
+        "equipment": "DIGITAL REALTY Z-END",
+        "port": "NL172777-2"
+      }
+    ],
+    "imsid": 730066,
+    "monitored": true,
+    "name": "AMS-LON1-EEX-ESNET-2373-1-400G",
+    "scid": "d6ddce0a-e2fb-4f69-a7d4-c7d23f809bc0",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02334",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ge-0/3/3"
+      }
+    ],
+    "imsid": 718799,
+    "monitored": true,
+    "name": "LONDON-LONDON-1GBE-002(GEANT)",
+    "scid": "d6e94ba1-7a30-491e-aa2d-c9ee153f585a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01468",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [],
+    "imsid": 709773,
+    "monitored": false,
+    "name": "REDIRIS EUMETCAST AP2",
+    "scid": "d70ebbfd-350b-4bc7-b2ce-43c327ddc276",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01117",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.bra.sk.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 729433,
+    "monitored": true,
+    "name": "BRA-BRA-LAG",
+    "scid": "d7102178-55d0-465b-b36a-2a2af6f9edd6",
+    "service_type": "ETHERNET",
+    "sid": "GA-02146",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "193.188.137.37/24",
+          "2001:7f8:35::2:1320:1/64"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae18.10"
+      }
+    ],
+    "imsid": 663235,
+    "monitored": false,
+    "name": "IX-PEERINGS-IN-BIX-BUD",
+    "scid": "d7135296-211f-47f8-a2a7-6674b35abf6d",
+    "service_type": "IP PEERING - NON R&E (PUBLIC)",
+    "sid": "GS-00956",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 712565,
+    "monitored": true,
+    "name": "PRA-SW1-LAG",
+    "scid": "d713c4d2-9939-4712-bac2-d48e36907826",
+    "service_type": "ETHERNET",
+    "sid": "GA-02068",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/1"
+      },
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/1.0"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/1/1"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/1/1.0"
+      }
+    ],
+    "imsid": 720236,
+    "monitored": true,
+    "name": "AMS-PRA-IX-CESNET-AMS-18088",
+    "scid": "d71d0993-39c7-44af-b8fc-a8765cf66da3",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00787",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15"
+      }
+    ],
+    "imsid": 718161,
+    "monitored": true,
+    "name": "REDIRIS-AP2-LAG",
+    "scid": "d72de364-befd-4233-b51a-a7d8259e8aa3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01780",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "xe-3/0/2"
+      }
+    ],
+    "imsid": 662302,
+    "monitored": true,
+    "name": "BUDAPEST-BUDAPEST-10GBE-010(GEANT)",
+    "scid": "d745479b-8dd4-404d-9e83-6327bce78e26",
+    "service_type": "ETHERNET",
+    "sid": "GA-02128",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [],
+    "imsid": 661227,
+    "monitored": false,
+    "name": "ARNES-AP3",
+    "scid": "d74cc08f-781f-4bc5-9019-f17b780af9e5",
+    "service_type": "GEANT IP",
+    "sid": "GS-00428",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708241,
+    "monitored": false,
+    "name": "NETRONOME-MANAGEMENT-LON2-UK",
+    "scid": "d77b7b62-14b0-40a9-9a17-576aa4abcdeb",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00191",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 734464,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-004(GEANT)",
+    "scid": "d7acffe0-1c6a-4b06-b178-ba1a19cf14f2",
+    "service_type": "ETHERNET",
+    "sid": "GA-01587",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 727145,
+    "monitored": true,
+    "name": "BRU-BRU-LAG-100G",
+    "scid": "d7ebebba-14b8-41ee-986e-5c8c3658deb8",
+    "service_type": "ETHERNET",
+    "sid": "GA-02276",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-3"
+      }
+    ],
+    "imsid": 746515,
+    "monitored": true,
+    "name": "KAU-RIG-LAG",
+    "scid": "d801120f-af92-4510-b98b-206795094433",
+    "service_type": "ETHERNET",
+    "sid": "GA-02031",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx2.lis.pt - Traffic - ae0 - LAG INFRASTRUCTURE BACKBONE | LIS-MAD | 40G",
+    "scid": "d81b6e95-d334-46b5-8fa1-c77545a10c0a",
+    "service_type": null,
+    "sid": "GA-01790",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BASNET"
+    ],
+    "endpoints": [],
+    "imsid": 661373,
+    "monitored": false,
+    "name": "BASNET-AP1-IAS",
+    "scid": "d82faf31-3fcf-4256-950a-b55b7a98ddee",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00556",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx2.am.office.geant.net",
+        "interface": "ge-0/0/2"
+      }
+    ],
+    "imsid": 662522,
+    "monitored": true,
+    "name": "PHY INFRASTRUCTURE | SURFNET SECONDARY",
+    "scid": "d8710f34-b964-4d97-8abd-67457602f202",
+    "service_type": "ETHERNET",
+    "sid": "GA-01245",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 739969,
+    "monitored": true,
+    "name": "HAM-HAM-LAG-300G",
+    "scid": "d8896d70-042a-4996-a9f6-21ad2ce9bcec",
+    "service_type": "ETHERNET",
+    "sid": "GA-02540",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BREN"
+    ],
+    "endpoints": [],
+    "imsid": 731985,
+    "monitored": false,
+    "name": "BREN-BGP-LU-COC-AP2",
+    "scid": "d8d84d98-7f1e-46a8-b218-fca5a8daacb5",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-00999",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.68/31",
+          "2001:798:111:1::81/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae11.666"
+      }
+    ],
+    "imsid": 732253,
+    "monitored": true,
+    "name": "SURF-AP2-LHCONE",
+    "scid": "d8d90097-d8c8-4d6c-9934-a949bc8b0a0b",
+    "service_type": "L3-VPN",
+    "sid": "GS-02413",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707413,
+    "monitored": true,
+    "name": "RIG-RIG-LAG",
+    "scid": "d8dd77ee-f95c-4aec-b15b-a2ec8c1e2577",
+    "service_type": "ETHERNET",
+    "sid": "GA-02049",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.KIE.UA",
+        "port": "AE2"
+      }
+    ],
+    "imsid": 713306,
+    "monitored": true,
+    "name": "LAG-RT1.KIE.UA_AE2-SW1.KIE.UA_AE2",
+    "scid": "d8ede461-aece-4d7c-a7af-7a6d91197022",
+    "service_type": "ETHERNET",
+    "sid": "GA-02057",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ACONET"
+    ],
+    "endpoints": [],
+    "imsid": 709733,
+    "monitored": true,
+    "name": "ACONET-AP1-EUMETCAST",
+    "scid": "d8fa88ee-8718-465b-94ec-2becd5836a01",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01094",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "MX2.RIG.LV",
+        "port": "GE-0/2/1"
+      }
+    ],
+    "imsid": 679321,
+    "monitored": true,
+    "name": "RIGA-RIGA-1GBE-003(LAT)",
+    "scid": "d92851c4-ec00-4aa2-a2d8-7c3067ad4941",
+    "service_type": "ETHERNET",
+    "sid": "GA-01367",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.lis.pt - Traffic - ae0 - LAG INFRASTRUCTURE BACKBONE | LIS-LIS |",
+    "scid": "d94ec3ed-c521-41d9-ae76-3d1d6bcd05ff",
+    "service_type": null,
+    "sid": "GA-01766",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/0/6"
+      },
+      {
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/0/6.1"
+      }
+    ],
+    "imsid": 678451,
+    "monitored": true,
+    "name": "SDX-L2-HOSTC-TO-BR51",
+    "scid": "d96c5890-9114-4a8d-9d5c-85fd8c16706a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00762",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708316,
+    "monitored": false,
+    "name": "PS-PSMP-OWAMP-FRA-DE",
+    "scid": "d98306b9-3c51-495d-9cd5-9031cc4c1fa8",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00351",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 658976,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-1GBE-016(ETH)",
+    "scid": "d98e2541-ed43-4972-8803-5bd8de0a1fc1",
+    "service_type": "ETHERNET",
+    "sid": "GA-01514",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/1/6.1306"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.1306"
+      }
+    ],
+    "imsid": 727332,
+    "monitored": false,
+    "name": "FRA-LON-SCION-SWITCH-KREONET",
+    "scid": "d9958028-de14-44ba-a5b9-845cd311d2bc",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02294",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658692,
+    "monitored": false,
+    "name": "730XD-1-VM-TRAFFIC-LAG-PAR",
+    "scid": "d9969e33-f1b8-4f22-b4b7-487894c76903",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01723",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "Nordunet_ExpressRoute_Vlan4076",
+    "scid": "d9a2957e-9fcd-4457-aa6c-e7448f3552b6",
+    "service_type": null,
+    "sid": "DS-51562",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660448,
+    "monitored": false,
+    "name": "JRA1-SDX-L2-PILOT-VLAN1001",
+    "scid": "d9a58172-8807-49c0-962d-d127d27a9190",
+    "service_type": "L3-VPN",
+    "sid": "GS-00937",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "VERIZON"
+    ],
+    "endpoints": [],
+    "imsid": 731612,
+    "monitored": false,
+    "name": "FRANKFURT-VERIZON-1-15133-DE-1",
+    "scid": "d9bf235d-af58-4989-afae-1c5731b2882e",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00932",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.fra.de - Traffic - |query_ifDescr| - |query_ifAlias|",
+    "scid": "da088685-36a1-476c-a5c0-d7e53173a129",
+    "service_type": null,
+    "sid": "GA-01971",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.113/30",
+          "2001:798:1b:10aa::d/126"
+        ],
+        "hostname": "rt0.lju.si.geant.net",
+        "interface": "lag-20.100"
+      }
+    ],
+    "imsid": 745714,
+    "monitored": true,
+    "name": "ARNES-AP1",
+    "scid": "da21a8e8-0b33-41f4-8986-5d480d46fc57",
+    "service_type": "GEANT IP",
+    "sid": "GS-00426",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ROEDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.241/30",
+          "2001:798:1::1ed/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae21.333"
+      }
+    ],
+    "imsid": 679570,
+    "monitored": true,
+    "name": "ROEDUNET-AP2-IAS",
+    "scid": "da55cc4d-fa1b-4fe7-a72d-70b0c0127074",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00545",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EDUZONE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.120/31",
+          "2001:798:99:1::1d/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-101.31"
+      }
+    ],
+    "imsid": 747941,
+    "monitored": true,
+    "name": "HR-EDUZONE",
+    "scid": "da6670a5-2f66-43a6-9145-44c41ce96423",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00936",
+    "speed": 22548578304,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.108.161/28"
+        ],
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/2.14"
+      }
+    ],
+    "imsid": 661540,
+    "monitored": false,
+    "name": "DRACS-LON2-UK",
+    "scid": "da69aace-b82a-42c0-bc68-826a089a9497",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00141",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "132.145.7.81/31",
+          "2603:c000:380::9/127"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae24.0"
+      }
+    ],
+    "imsid": 719260,
+    "monitored": true,
+    "name": "UK-ORACLE-31898",
+    "scid": "da89213d-6bcc-4ebe-874f-c3a15ebb761c",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00624",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663010,
+    "monitored": false,
+    "name": "FRA-GROOVE-2-MANAGEMENT",
+    "scid": "dab2b6cf-c667-4f3f-ab93-e09f9a533ea5",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00175",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "17.1.72.125/31",
+          "2a01:b740:1:9718::91/127"
+        ],
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae45.0"
+      }
+    ],
+    "imsid": 730369,
+    "monitored": true,
+    "name": "FR-APPLE-IAS",
+    "scid": "dab9fa01-1bfd-4d5f-82e7-ed2111687afb",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-02397",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae4"
+      }
+    ],
+    "imsid": 739735,
+    "monitored": true,
+    "name": "GEN-MAR-LAG",
+    "scid": "dade9050-d57b-448f-8de0-3eca131d7581",
+    "service_type": "ETHERNET",
+    "sid": "GA-02207",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae7"
+      }
+    ],
+    "imsid": 730316,
+    "monitored": true,
+    "name": "BUC-BUD-LAG-(200G)",
+    "scid": "db0a61cb-1cca-43d3-93a8-2826192e701f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01906",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lju.si.geant.net",
+        "interface": "lag-21"
+      }
+    ],
+    "imsid": 747472,
+    "monitored": true,
+    "name": "ARNES-LHCONE-LAG",
+    "scid": "db0bdb55-6fde-4935-866f-e139472eeeba",
+    "service_type": "ETHERNET",
+    "sid": "GA-02632",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.240"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae28.240"
+      }
+    ],
+    "imsid": 718107,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-NORDUNET-TENET-18075",
+    "scid": "db2fb636-4805-497c-8345-9aee1533aa70",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00978",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "AMS-FRA OPENFLOW",
+    "scid": "db64fd14-4595-4fbc-a982-ed00f52511a6",
+    "service_type": null,
+    "sid": "DS-15987",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12"
+      }
+    ],
+    "imsid": 659378,
+    "monitored": true,
+    "name": "RENATER-AP1-LAG",
+    "scid": "db6bdecb-2a64-400b-9624-1bf6e0d7a25d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01816",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662227,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-015(ETH)",
+    "scid": "db73cb52-2ffa-4a4b-9a84-6c68302df3e4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01623",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 733924,
+    "monitored": false,
+    "name": "NL-ORANGE-2281",
+    "scid": "db871b2e-9407-4ae8-9adf-d889d9bcbf7e",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-01180",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-21"
+      }
+    ],
+    "imsid": 744016,
+    "monitored": true,
+    "name": "IMINDS-IC-GEANT-LAG",
+    "scid": "db889949-d2e1-4c36-a2d6-a7f3c99237ba",
+    "service_type": "ETHERNET",
+    "sid": "GA-02314",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16"
+      }
+    ],
+    "imsid": 719102,
+    "monitored": true,
+    "name": "REDIRIS-AP1-LAG",
+    "scid": "db95aa46-1fb6-4b71-8ef6-5eb7f4e8b84b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01800",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/4"
+      }
+    ],
+    "imsid": 658491,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-019(ETH)",
+    "scid": "dbb7d237-aa90-42c2-9ef5-274bafad1937",
+    "service_type": "ETHERNET",
+    "sid": "GA-01241",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 713272,
+    "monitored": true,
+    "name": "CHI-CHI-LAG",
+    "scid": "dbe21175-3203-4536-aec4-e5dc458ae83e",
+    "service_type": "ETHERNET",
+    "sid": "GA-02037",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "185.1.192.126/23",
+          "2001:7f8:a0::51e5:0:1/64"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae14.100"
+      }
+    ],
+    "imsid": 661295,
+    "monitored": false,
+    "name": "IX-PEERINGS-IN-DE-CIX-MAD",
+    "scid": "dc1670ff-80af-4519-9ba8-8cc53063af19",
+    "service_type": "IP PEERING - NON R&E (PUBLIC)",
+    "sid": "GS-00949",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-22"
+      }
+    ],
+    "imsid": 747581,
+    "monitored": true,
+    "name": "PIONIER-AP2-LAG",
+    "scid": "dc243c32-8a94-4b02-9713-5898ed9c9781",
+    "service_type": "ETHERNET",
+    "sid": "GA-01892",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658743,
+    "monitored": true,
+    "name": "MILAN 2 CALDERA-MILAN 2 CALDERA-1GBE-003(GEANT)",
+    "scid": "dc24b1d8-cdc8-4420-aef1-3ca5e896120a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01525",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ams.nl.geant.net",
+        "interface": "lag-9"
+      }
+    ],
+    "imsid": 739968,
+    "monitored": true,
+    "name": "AMS-HAM-LAG-300G",
+    "scid": "dc297262-1c02-464c-b38e-d0f5de232e08",
+    "service_type": "ETHERNET",
+    "sid": "GA-01923",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae4"
+      }
+    ],
+    "imsid": 712768,
+    "monitored": true,
+    "name": "LIS-MAD-LAG-200G",
+    "scid": "dc37c9e0-3026-4861-9628-201ee271413a",
+    "service_type": "ETHERNET",
+    "sid": "GA-02001",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 745267,
+    "monitored": true,
+    "name": "GRNET-AP2-LAG",
+    "scid": "dc3d5bf7-b93f-48e7-9a09-07bc5142c232",
+    "service_type": "ETHERNET",
+    "sid": "GA-01929",
+    "speed": 64424509440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RARE"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.FRA.DE.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/2.201"
+      },
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.201"
+      }
+    ],
+    "imsid": 732759,
+    "monitored": false,
+    "name": "FRA-MAD-RARE-REDIRIS-23017-VL201",
+    "scid": "dc68e1e6-fd38-4c69-afca-e169a057e1c7",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02274",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708203,
+    "monitored": false,
+    "name": "PS-MIL2-IT-BWCTL",
+    "scid": "dc6bbb90-debe-4a1b-9664-76ec2cc9eef7",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00334",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae10"
+      }
+    ],
+    "imsid": 714059,
+    "monitored": true,
+    "name": "RENAM-AP1-LAG",
+    "scid": "dc767ba4-1cfd-4a5a-b757-e72897aec5c3",
+    "service_type": "ETHERNET",
+    "sid": "GA-02016",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 747919,
+    "monitored": true,
+    "name": "CHISINAU-CHISINAU-LAG-001(GEANT)",
+    "scid": "dcae8940-de26-4555-a36b-c1914f74de52",
+    "service_type": "ETHERNET",
+    "sid": "GA-92018",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.31"
+      },
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae23.401"
+      }
+    ],
+    "imsid": 724682,
+    "monitored": true,
+    "name": "CESNET-NACIT-EXPRESSROUTE-VLAN401",
+    "scid": "dcb38399-ffaa-4391-a6ac-4256a81317db",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02175",
+    "speed": 225485783040,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.191/31",
+          "2001:798:cc:1::ee/126"
+        ],
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-2.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.190/31",
+          "2001:798:cc:1::ed/126"
+        ],
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-2.0"
+      }
+    ],
+    "imsid": 744055,
+    "monitored": true,
+    "name": "BRU-PAR-IPTRUNK",
+    "scid": "dcb7c9c2-2147-458d-9f45-6b6342d8295a",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02280",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658667,
+    "monitored": false,
+    "name": "730XD-1-ESXI-TRAFFIC-LAG-PAR",
+    "scid": "dce57f5f-a783-47fe-9533-a276131d7874",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01715",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.123.249/29",
+          "2001:798:bb:16::1/64"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-1/0/2.10"
+      }
+    ],
+    "imsid": 661522,
+    "monitored": false,
+    "name": "DTN-LON-10G-DATA",
+    "scid": "dcee4bb7-0bef-4055-9608-0a22f018fc29",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00146",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/14"
+      }
+    ],
+    "imsid": 658556,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-030(ETH)",
+    "scid": "dd0225f2-726c-4c49-b4ed-87d39596f571",
+    "service_type": "ETHERNET",
+    "sid": "GA-01243",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662245,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-1GBE-020(ETH)",
+    "scid": "dd02d519-5303-4260-b7d4-3671d780ec17",
+    "service_type": "ETHERNET",
+    "sid": "GA-01607",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 733944,
+    "monitored": true,
+    "name": "PARIS-PARIS 007B-10GBE-004(GEANT)",
+    "scid": "dd3edba8-ba00-41b0-8f73-ab4c1fc0d192",
+    "service_type": "ETHERNET",
+    "sid": "GA-01395",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GOOGLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae11"
+      }
+    ],
+    "imsid": 734925,
+    "monitored": true,
+    "name": "GOOGLE-AMS-PNI-2-LAG",
+    "scid": "dd5f21c3-82df-42df-9df9-4d09a6bf7186",
+    "service_type": "ETHERNET",
+    "sid": "GA-01921",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.202/31",
+          "2001:798:1::109/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae17.0"
+      }
+    ],
+    "imsid": 708275,
+    "monitored": true,
+    "name": "FACEBOOK-32934-LON-FA-1026202",
+    "scid": "dd614802-09a4-46f8-9ebd-e63ae3403bd0",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00928",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 713307,
+    "monitored": true,
+    "name": "LAG-RT2.KIE.UA_AE2-SW1.KIE.UA_AE3",
+    "scid": "dd9cdfaa-465e-4acf-ba91-c2d4b4d211a0",
+    "service_type": "ETHERNET",
+    "sid": "GA-02047",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679555,
+    "monitored": true,
+    "name": "LJUBLJANA 2-LJUBLJANA 2-LAG-001(GEANT)",
+    "scid": "ddb630a7-d791-4d2f-935c-e0c42d30ae3b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01743",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662388,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10GBE-029(GEANT)",
+    "scid": "ddd25c51-6b1c-4f9b-8f6e-34ffb667fe0d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01573",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "T-SYSTEMS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae25"
+      }
+    ],
+    "imsid": 732118,
+    "monitored": true,
+    "name": "T-SYSTEM FRA 10G LAG",
+    "scid": "dde4f7df-9477-438a-a506-58faf19b19f8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01947",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.21"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240584"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4091"
+      }
+    ],
+    "imsid": 744147,
+    "monitored": true,
+    "name": "MSEZWEV-01139",
+    "scid": "ddf11fab-28ec-470f-a367-323aa6229b37",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01139",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.GEN.CH.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 677587,
+    "monitored": false,
+    "name": "GENEVA OOB LINK",
+    "scid": "de13cd4d-8a18-4f54-9b38-3c8b5d58a5e9",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00400",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.pra.cz.geant.net",
+        "interface": "lag-5"
+      }
+    ],
+    "imsid": 740749,
+    "monitored": true,
+    "name": "PRA-VIE-LAG",
+    "scid": "de693f48-6715-4372-b3b1-b4dd9bbc87ab",
+    "service_type": "ETHERNET",
+    "sid": "GA-01830",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.115.92/31"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae2.998"
+      }
+    ],
+    "imsid": 736107,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-AMS-NL",
+    "scid": "de7ef2ec-4db9-4ac8-8c31-5164a2d7a686",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00147",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.2023"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.2023"
+      }
+    ],
+    "imsid": 705899,
+    "monitored": true,
+    "name": "AMS-PAR-GEANTOPEN-NORDUNET-INTERNET2-17008",
+    "scid": "dee5ebab-3027-4954-9f56-ab3bb6fe8e3c",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00959",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMT1.LON2.UK",
+        "port": "AE1"
+      }
+    ],
+    "imsid": 744435,
+    "monitored": true,
+    "name": "LON2-AMT-LAG",
+    "scid": "deff51a2-96de-427f-b5d7-8e3e3099bd4d",
+    "service_type": "ETHERNET",
+    "sid": "GA-02298",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 713232,
+    "monitored": true,
+    "name": "BUC-CHI-LAG",
+    "scid": "df010b75-5cad-425f-a476-8c8178e1cb90",
+    "service_type": "ETHERNET",
+    "sid": "TA-02018",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae23"
+      }
+    ],
+    "imsid": 734843,
+    "monitored": true,
+    "name": "NL-ORACLEFC-LAG-1",
+    "scid": "df06578f-e3c9-4e60-8cc7-65cfb6106f46",
+    "service_type": "ETHERNET",
+    "sid": "GA-02009",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/7"
+      }
+    ],
+    "imsid": 658814,
+    "monitored": true,
+    "name": "JISC GN+ 10GE LL 1",
+    "scid": "df171bca-dae0-4d4d-9266-89c75a64f326",
+    "service_type": "ETHERNET",
+    "sid": "GA-01457",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15"
+      }
+    ],
+    "imsid": 659341,
+    "monitored": true,
+    "name": "NYC-PAR LAG",
+    "scid": "df802000-65cc-4229-bcad-03e61d9bd3e8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01821",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662232,
+    "monitored": true,
+    "name": "SOFIA-SOFIA-1GBE-005(ETH)",
+    "scid": "dfbcbcd8-fe63-4df6-9121-19cd9c255291",
+    "service_type": "ETHERNET",
+    "sid": "GA-01250",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 712375,
+    "monitored": true,
+    "name": "MD-VPN-VRR-PARIS-NORDUNET-2-SE",
+    "scid": "dfc4fc68-6881-4263-a306-011504053f26",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01048",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "UOM"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae11"
+      }
+    ],
+    "imsid": 721888,
+    "monitored": true,
+    "name": "UOM-AP1-LAG",
+    "scid": "dfcabdfe-a047-4027-bddb-5c0000a0a341",
+    "service_type": "ETHERNET",
+    "sid": "GA-01344",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661979,
+    "monitored": false,
+    "name": "OWAMP-ATH-GR",
+    "scid": "dfe24866-b91d-4596-9ca0-78253ed44210",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00264",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708714,
+    "monitored": false,
+    "name": "FRA-HAM-IPTRUNK",
+    "scid": "dfeadd24-fe49-484f-b6d8-ee48370deacf",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00035",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EUMETSAT-SVALBARD"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.146/31"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.120"
+      }
+    ],
+    "imsid": 729170,
+    "monitored": true,
+    "name": "EUMET-SVALBARD-LON-MONITORINGVLAN",
+    "scid": "e0033954-ca83-4760-b909-67c4f71d4cea",
+    "service_type": "GEANT IP",
+    "sid": "GS-02156",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679042,
+    "monitored": true,
+    "name": "FRA-HAM-LAG",
+    "scid": "e004a0a0-2ed2-4a48-9e6b-bb6a74702982",
+    "service_type": "ETHERNET",
+    "sid": "GA-01897",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [],
+    "imsid": 719556,
+    "monitored": false,
+    "name": "FRA-MAR-REDIRIS-RARE-20092",
+    "scid": "e0077a11-932d-44e4-9e2c-1a307a157e85",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00693",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662203,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-1GBE-010(ETH)",
+    "scid": "e0150c66-e5c7-4d5a-9dd1-e3aa391a31f5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01645",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae7"
+      }
+    ],
+    "imsid": 744378,
+    "monitored": true,
+    "name": "FRA-AMT-LAG",
+    "scid": "e022f42d-3e1d-4a5c-89cb-3fbf0a719564",
+    "service_type": "ETHERNET",
+    "sid": "GA-02303",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/7"
+      }
+    ],
+    "imsid": 658424,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-006(ETH)",
+    "scid": "e02385ac-5381-4727-bbc3-1d395cb97268",
+    "service_type": "ETHERNET",
+    "sid": "GA-01214",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658680,
+    "monitored": false,
+    "name": "LON2-PRD-ESX03-VSAN-LAG",
+    "scid": "e065894a-c9f1-4592-88de-6a3d9acaae2f",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01708",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "equipment": "GEN01-GRV6",
+        "port": "1/2/5"
+      },
+      {
+        "equipment": "LON01-GRV4",
+        "port": "1/2/5"
+      }
+    ],
+    "imsid": 726382,
+    "monitored": true,
+    "name": "GEN1-LON1-LHC-CERN-JISC-22109",
+    "scid": "e0a85d56-33ae-4088-b4bb-305cae3074ef",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02238",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ORACLE"
+    ],
+    "endpoints": [],
+    "imsid": 719256,
+    "monitored": true,
+    "name": "DE-ORACLE-31898",
+    "scid": "e0b1255e-ed93-42aa-b44c-707ad21357c8",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00605",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 734735,
+    "monitored": true,
+    "name": "ATH2-MIL2-LAG",
+    "scid": "e0b1bce4-ec45-4d7c-9f2d-d8ce32a19ee3",
+    "service_type": "ETHERNET",
+    "sid": "DA-000198",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CANARIE"
+    ],
+    "endpoints": [],
+    "imsid": 661996,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-CANARIE-QNREN-15024",
+    "scid": "e0b7f5ac-9708-4315-9517-028eb1a4ebf5",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00961",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/0"
+      }
+    ],
+    "imsid": 658426,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-008(ETH)",
+    "scid": "e0eb1af3-5183-442b-a660-16d26d09ae6b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01235",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.21/30",
+          "2001:0798:0012:10aa::1/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae23.100"
+      }
+    ],
+    "imsid": 663078,
+    "monitored": true,
+    "name": "SWITCH-AP1",
+    "scid": "e0f36f7f-1d4e-43d6-a21d-cf9ab001f377",
+    "service_type": "GEANT IP",
+    "sid": "GS-00514",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "VERIZON"
+    ],
+    "endpoints": [],
+    "imsid": 731607,
+    "monitored": true,
+    "name": "FRANKFURT-VERIZON-2-LAG",
+    "scid": "e0fe73a4-0126-480f-ba0b-048a79d88ff6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01967",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.pra.cz.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 739238,
+    "monitored": true,
+    "name": "PRA-PRA-LAG",
+    "scid": "e12a14a3-2dd3-4b0e-8db3-01a914a33bc7",
+    "service_type": "ETHERNET",
+    "sid": "GA-02544",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NIKS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae25"
+      }
+    ],
+    "imsid": 734927,
+    "monitored": true,
+    "name": "NL-NIKS-LAG",
+    "scid": "e12c60cb-7a3b-4a8a-8637-a27124227ed0",
+    "service_type": "ETHERNET",
+    "sid": "GA-02143",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663222,
+    "monitored": false,
+    "name": "TAAS-CONTROL-AMSTERDAM",
+    "scid": "e12ed422-0e34-4adc-89a3-9b3658cd2a7b",
+    "service_type": "GTS",
+    "sid": "GS-01186",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/7"
+      }
+    ],
+    "imsid": 729227,
+    "monitored": true,
+    "name": "LON2-PAR-SUPERPOP-GBS-LL2",
+    "scid": "e141a58f-f0c0-4323-8e6a-e6e42ba22163",
+    "service_type": "ETHERNET",
+    "sid": "GA-01321",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/44"
+      }
+    ],
+    "imsid": 739584,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-041(GEANT)",
+    "scid": "e17a4c25-03fc-42e7-931a-9b6e22e5290a",
+    "service_type": "ETHERNET",
+    "sid": "GS-00076",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663002,
+    "monitored": false,
+    "name": "PS-LHCONE-BUD-HU-DATA",
+    "scid": "e17bf9f0-2e66-4b59-a73f-a83b58ecf94f",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00314",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/3.1640"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-223079"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-22:1640"
+      }
+    ],
+    "imsid": 745432,
+    "monitored": true,
+    "name": "PARIS-PARIS-ETHS-001(GRNET)",
+    "scid": "e18ee5c4-dc5b-4b94-b293-42a3de4700db",
+    "service_type": "ETHERNET",
+    "sid": "GS-02382",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 746052,
+    "monitored": true,
+    "name": "KAU-KAU-MGMT-LAG",
+    "scid": "e1b30dbd-e217-4a72-b634-71ada9f7a983",
+    "service_type": "ETHERNET",
+    "sid": "GA-50064",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.25/31",
+          "2001:798:cc:1::126/126"
+        ],
+        "hostname": "rt0.mil2.it.geant.net",
+        "interface": "lag-3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.24/31",
+          "2001:798:cc:1::125/126"
+        ],
+        "hostname": "rt0.lju.si.geant.net",
+        "interface": "lag-1.0"
+      }
+    ],
+    "imsid": 746146,
+    "monitored": true,
+    "name": "LJU-MIL2-IPTRUNK",
+    "scid": "e1b6fb34-222a-4198-ad8a-3e0b191c8252",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00051",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [],
+    "imsid": 738297,
+    "monitored": true,
+    "name": "PSNC-REDIRIS-SLICES-UPV/EHU",
+    "scid": "e1efa10c-7321-4d78-9991-aca4f23c6185",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-024913",
+    "speed": 429496729600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662206,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-1GBE-011(ETH)",
+    "scid": "e221794d-5bea-4d69-b92a-1b364cef9a4f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01647",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.7"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-240585"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4092"
+      }
+    ],
+    "imsid": 744142,
+    "monitored": true,
+    "name": "MSEIMEC-02092",
+    "scid": "e2239a60-dd3e-457c-8fb8-d0373c1575fb",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02092",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ASREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-1/2/5.46"
+      }
+    ],
+    "imsid": 707023,
+    "monitored": true,
+    "name": "LON-LON2-GEANTOPEN-ASREN-ASREN-190491",
+    "scid": "e23295a1-1ca7-40e6-a7c1-0a52c19b7495",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00984",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ROEDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.137/30",
+          "2001:798:2b:10aa::1/126"
+        ],
+        "hostname": "rt0.buc.ro.geant.net",
+        "interface": "lag-20.100"
+      }
+    ],
+    "imsid": 747908,
+    "monitored": true,
+    "name": "ROEDUNET-AP1",
+    "scid": "e234c7ba-60bf-4682-8ee1-92d138913f38",
+    "service_type": "GEANT IP",
+    "sid": "GS-00509",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "AMS-PAR-SCION-GTS-20053",
+    "scid": "e234d5ad-2d5e-4e8e-9997-8fc94ca8ee07",
+    "service_type": null,
+    "sid": "DS-51652",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW3.AMS.NL",
+        "port": "AE2"
+      }
+    ],
+    "imsid": 736042,
+    "monitored": true,
+    "name": "RT1.AMS-SW3.AMS-LAG",
+    "scid": "e23cc629-58f2-4bef-818f-1fdb1ca3bca2",
+    "service_type": "ETHERNET",
+    "sid": "GA-02081",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "COLT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "xe-4/3/0"
+      }
+    ],
+    "imsid": 720362,
+    "monitored": true,
+    "name": "GWS COLT LL1",
+    "scid": "e23e021c-6aa6-4266-8829-b210401838e4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01488",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "FRA01-GRV4",
+        "port": "1/1/6"
+      },
+      {
+        "equipment": "GEN01-GRV8",
+        "port": "1/2/6"
+      },
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "DE259800"
+      },
+      {
+        "equipment": "DIGITAL REALTY Z-END",
+        "port": "DE259800"
+      }
+    ],
+    "imsid": 739641,
+    "monitored": true,
+    "name": "FRA-GEN-NORDUNET-24055-2",
+    "scid": "e2525041-14bb-485c-9783-d9553167c895",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02532",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.136/31",
+          "2001:798:cc::d1/126"
+        ],
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae6.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.137/31",
+          "2001:798:cc::d2/126"
+        ],
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-6.0"
+      }
+    ],
+    "imsid": 745054,
+    "monitored": true,
+    "name": "LIS-PAR-IPTRUNK",
+    "scid": "e266a1a4-5beb-4a9b-b3c0-4be736eeecab",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02633",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679315,
+    "monitored": false,
+    "name": "PAR-TNMS",
+    "scid": "e2806c84-dbb2-4c63-a052-3149aedd8b19",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00276",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661261,
+    "monitored": false,
+    "name": "PS-PRA-CZ-MANAGEMENT",
+    "scid": "e2940a92-299c-464d-9e8a-18e2d52b7cca",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00349",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.157/30",
+          "2001:798:99:1::dd/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae22.201"
+      }
+    ],
+    "imsid": 701593,
+    "monitored": true,
+    "name": "CERN-AP1-EXT2",
+    "scid": "e2d7cc89-a2f4-459f-9bc8-e2333ecca4b4",
+    "service_type": "GEANT IP",
+    "sid": "GS-00443",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "addresses": [
+          "10.0.1.130/26"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "irb.3001"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae30.3001"
+      }
+    ],
+    "imsid": 733003,
+    "monitored": false,
+    "name": "TAAS-CONTROL-FRANKFURT-VRF-VLAN3001",
+    "scid": "e2d8e1be-e04c-4379-8ee7-be733bb2e9f8",
+    "service_type": "L3-VPN",
+    "sid": "GS-00861",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "LAT"
+    ],
+    "endpoints": [],
+    "imsid": 709261,
+    "monitored": true,
+    "name": "LAT-AP1-IPV4",
+    "scid": "e2e169d5-2acb-4352-a7d3-b1bbebf6a5ac",
+    "service_type": "GEANT IP",
+    "sid": "GS-00483",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708325,
+    "monitored": false,
+    "name": "PS-LIS-PT-OWAMP",
+    "scid": "e2f95001-b5c0-4bab-a454-abedbfa38727",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00318",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EENET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-21"
+      }
+    ],
+    "imsid": 745927,
+    "monitored": true,
+    "name": "EENET-AP2-LAG",
+    "scid": "e3017c47-c0ad-47ab-857c-516e4d7c4f3c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01737",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.206/31",
+          "2001:798:1::198/127"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae48.720"
+      }
+    ],
+    "imsid": 741338,
+    "monitored": false,
+    "name": "A10-DDOS-SCRUBBING-FRA-DIRTY-TRAFFIC",
+    "scid": "e3183991-3bde-465f-ab0e-035c0b6f60fa",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00088",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.166/31",
+          "2001:798:99:1::99/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.611"
+      }
+    ],
+    "imsid": 709307,
+    "monitored": true,
+    "name": "UK-CLARA-NEA3R",
+    "scid": "e3203527-2489-4618-90ce-e8f0634beb4f",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00914",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae6"
+      }
+    ],
+    "imsid": 658665,
+    "monitored": false,
+    "name": "LON2-PRD-ESX10-ESXI-TRAFFIC",
+    "scid": "e32d2136-3aad-432a-bab3-891e2dba54e4",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01693",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661517,
+    "monitored": false,
+    "name": "JUNOSSPACE-R720-NEBACKUP-PAR-FR",
+    "scid": "e3314fbd-8090-42a8-83c9-87a2cbc724d9",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00215",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.3152"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae11.353"
+      }
+    ],
+    "imsid": 706059,
+    "monitored": true,
+    "name": "FRA-PAR-JAXA-DFN-SINET-14005",
+    "scid": "e3641428-7c89-4e2d-b05c-0c816e5fd21e",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00703",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662205,
+    "monitored": true,
+    "name": "BUDAPEST-BUDAPEST-1GBE-006(ETH)",
+    "scid": "e36d28bf-a4a1-45e0-83db-41fd73616562",
+    "service_type": "ETHERNET",
+    "sid": "GA-01566",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "UBUNTUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.21/30",
+          "2001:798:22:10aa::15/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae17.100"
+      }
+    ],
+    "imsid": 735726,
+    "monitored": true,
+    "name": "NL-UBUNTUNET",
+    "scid": "e3afa18d-5021-4b9c-bb64-e5a892e7c749",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00902",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659175,
+    "monitored": true,
+    "name": "MILAN 2 CALDERA-MILAN 2 CALDERA-1GBE-010(ETH)",
+    "scid": "e3b1b406-0e59-4d28-bf2a-ab33615af235",
+    "service_type": "ETHERNET",
+    "sid": "GA-01518",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/3"
+      }
+    ],
+    "imsid": 662521,
+    "monitored": true,
+    "name": "PHY TO SWITCH CLUSTER (GE-0/0/4)",
+    "scid": "e3c78429-10e8-4683-a22f-f01039d75e9a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01282",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "AARNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-1/3/0"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-1/3/0.1"
+      }
+    ],
+    "imsid": 678243,
+    "monitored": true,
+    "name": "AARNET_GEO_UK_1",
+    "scid": "e3c97737-950f-4637-8800-f0a224eff712",
+    "service_type": "ETHERNET",
+    "sid": "GA-01480",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "equipment": "AMS01-GRV4",
+        "port": "1/3/9"
+      },
+      {
+        "equipment": "LON01-GRV3",
+        "port": "1/3/9"
+      },
+      {
+        "equipment": "DIGITAL REALTY A-END",
+        "port": "NL261658-1"
+      },
+      {
+        "equipment": "DIGITAL REALTY Z-END",
+        "port": "NL261658-1"
+      }
+    ],
+    "imsid": 739847,
+    "monitored": true,
+    "name": "AMS-LON1-ESNET-24015-1-400G",
+    "scid": "e3d305c6-49e3-4135-b4b9-8776b236fff1",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-02452",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658741,
+    "monitored": true,
+    "name": "MILAN 2 CALDERA-MILAN 2 CALDERA-10GBE-001(ETH)",
+    "scid": "e45e8728-4354-4471-9bdc-114edced1fa0",
+    "service_type": "ETHERNET",
+    "sid": "GA-01341",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-4/1/4.1488"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.488"
+      }
+    ],
+    "imsid": 738739,
+    "monitored": true,
+    "name": "LON-PAR-NCSA-LAAS-ESNET-RENATER-15057",
+    "scid": "e47134f7-e166-4aeb-9a49-023c40c46969",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00738",
+    "speed": 751619276800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.112.18/28",
+          "2001:799:cb2:2::2/64"
+        ],
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/3.500"
+      }
+    ],
+    "imsid": 662973,
+    "monitored": false,
+    "name": "SRX1-CITY-HOUSE-NETWORK-INFRASTRUCTURE",
+    "scid": "e4774582-95b2-4806-af6b-21d7616ac13f",
+    "service_type": "CORPORATE",
+    "sid": "GS-01663",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-2/0/6"
+      }
+    ],
+    "imsid": 658625,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-030(ETH)",
+    "scid": "e4800358-20b7-4ba8-80ef-0519fe4bfd7b",
+    "service_type": "ETHERNET",
+    "sid": "GA-01265",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.239/31",
+          "2001:798:cc:1::be/126"
+        ],
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-7.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.238/31",
+          "2001:798:cc:1::bd/126"
+        ],
+        "hostname": "rt0.gen.ch.geant.net",
+        "interface": "lag-7.0"
+      }
+    ],
+    "imsid": 739696,
+    "monitored": true,
+    "name": "GEN-PAR-IPTRUNK",
+    "scid": "e4926619-f72f-45da-9c67-4d43f15e9b1f",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00040",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663037,
+    "monitored": false,
+    "name": "OWAMP-GENEVA-VLAN22",
+    "scid": "e4bbd6eb-4cee-4e1c-b71d-a42bb93d2d3d",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00265",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.246/31",
+          "2001:798:111:1::91/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-22.111"
+      }
+    ],
+    "imsid": 747600,
+    "monitored": true,
+    "name": "PIONIER-AP2-LHCONE",
+    "scid": "e4c66a81-ed98-49fa-b9b8-8f9de868171b",
+    "service_type": "L3-VPN",
+    "sid": "GS-00843",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 719293,
+    "monitored": false,
+    "name": "BELNET-SMALSDC-EXPRESSROUTE-VLAN4086",
+    "scid": "e4cf18a8-7386-4838-8737-d8cf5521ddbb",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02159",
+    "speed": 118111600640,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.209/30",
+          "2001:798:1::f1/126"
+        ],
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae10.333"
+      }
+    ],
+    "imsid": 661641,
+    "monitored": true,
+    "name": "FCCN-AP1-IAS",
+    "scid": "e4edd0c1-7b0b-4868-9517-13cde2e351e1",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00527",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12"
+      }
+    ],
+    "imsid": 659342,
+    "monitored": true,
+    "name": "CAE1-LAG",
+    "scid": "e5026e53-b04b-4668-b66b-0f07e6914968",
+    "service_type": "ETHERNET",
+    "sid": "GA-01843",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "TELIA"
+    ],
+    "endpoints": [],
+    "imsid": 659304,
+    "monitored": true,
+    "name": "LAG-MX1.VIE.AT_AE24",
+    "scid": "e5183c45-c0c3-43e3-8b58-bb3a678b9646",
+    "service_type": "ETHERNET",
+    "sid": "GA-01857",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.197/30",
+          "2001:798:111:1::39/126"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae16.111"
+      }
+    ],
+    "imsid": 719492,
+    "monitored": true,
+    "name": "REDIRIS-AP1-LHCONE",
+    "scid": "e52d0a4b-ba6d-45d9-a4ea-d33fd940563b",
+    "service_type": "L3-VPN",
+    "sid": "GS-00852",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662365,
+    "monitored": true,
+    "name": "NETHERLIGHT AUTOMATED GOLE",
+    "scid": "e5543071-40e3-40b2-89ea-2421845bbb3c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01631",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.mar.fr.geant.net",
+        "interface": "lag-5"
+      }
+    ],
+    "imsid": 742605,
+    "monitored": true,
+    "name": "MAR-MAR-MGMT-LAG",
+    "scid": "e55b7515-c8b3-4530-88e4-4aac5f6f4f4e",
+    "service_type": "ETHERNET",
+    "sid": "GA-02589",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "AMRES"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.62/31",
+          "2001:798:99:1::11d/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-21.1"
+      }
+    ],
+    "imsid": 747837,
+    "monitored": true,
+    "name": "AMRES-AP1",
+    "scid": "e55d42c0-d940-4f25-875d-c7f4b48d768e",
+    "service_type": "GEANT IP",
+    "sid": "GS-00425",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "CERN_CERN_ExpressRoute_VLAN497",
+    "scid": "e56745fc-10d7-4d60-b031-a9be71578c3c",
+    "service_type": null,
+    "sid": "DS-53205",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660437,
+    "monitored": false,
+    "name": "MIL2-GROOVE-1-MANAGEMENT",
+    "scid": "e58af948-f32f-41c7-8fd9-b8a2e3a0abe8",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00249",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658435,
+    "monitored": false,
+    "name": "730XD-5-VMNIC7-PAR",
+    "scid": "e5a4382c-e5c1-467d-9844-c095372da8a9",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01287",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ARN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae18"
+      }
+    ],
+    "imsid": 724748,
+    "monitored": true,
+    "name": "ES-ARN-AP1-LAG",
+    "scid": "e5de065e-9e3d-40a8-b12e-4deb0b214419",
+    "service_type": "ETHERNET",
+    "sid": "GA-02206",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 729089,
+    "monitored": true,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-005(GEANT)",
+    "scid": "e5e1b2dc-18a6-4e39-bca3-2c9837bed95d",
+    "service_type": "ETHERNET",
+    "sid": "GA-02067",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [],
+    "imsid": 712385,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-GARR-2-IT",
+    "scid": "e5fcc660-8be6-4dc2-af15-634b76e8c80f",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01022",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AMRES"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-21"
+      }
+    ],
+    "imsid": 747784,
+    "monitored": true,
+    "name": "AMRES-AP1-LAG",
+    "scid": "e61e7c7a-f832-44de-a175-db1516f16953",
+    "service_type": "ETHERNET",
+    "sid": "GA-01902",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658945,
+    "monitored": true,
+    "name": "MADRID-MADRID-1GBE-008(ETH)",
+    "scid": "e638fb8c-3105-43dd-a9a4-25e4f053d74a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01353",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 715108,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-10GBE-023(GEANT)",
+    "scid": "e654f5c9-847e-473e-a1d1-efe56066b129",
+    "service_type": "ETHERNET",
+    "sid": "GA-01634",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RARE"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.POZ.PL.GEANT.NET",
+        "port": "XE-1"
+      },
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-1"
+      },
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-3/0/1.0"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/2.0"
+      }
+    ],
+    "imsid": 736091,
+    "monitored": false,
+    "name": "AMS-POZ-RARE-P4-9951379",
+    "scid": "e68ad047-af95-4472-b32c-75f491ddb09d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00661",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KREONET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.45/30",
+          "2001:798:99:1::79/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.673"
+      }
+    ],
+    "imsid": 734548,
+    "monitored": true,
+    "name": "NL-KREONET",
+    "scid": "e6a69eba-1173-4eb8-9d81-bfbae639cf25",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00897",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 708924,
+    "monitored": true,
+    "name": "BIL-POR-LAG",
+    "scid": "e6ad9809-93c7-4030-8aad-34607c14d3bc",
+    "service_type": "ETHERNET",
+    "sid": "GA-02028",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT-SVALBARD"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.148/31"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21.110"
+      }
+    ],
+    "imsid": 747590,
+    "monitored": true,
+    "name": "EUMET-SVALBARD-HAM-MONITORINGVLAN",
+    "scid": "e6aec653-17f1-4ce2-ad23-4149f73e1a88",
+    "service_type": "GEANT IP",
+    "sid": "GS-02155",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 727288,
+    "monitored": false,
+    "name": "BELNET-BGP-LU-COC-AP1",
+    "scid": "e6baf936-f5e3-4a55-9435-fbc9816335e1",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-00998",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.1/30",
+          "2001:798:1::75/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae10.333"
+      }
+    ],
+    "imsid": 661497,
+    "monitored": true,
+    "name": "JISC-AP1-IAS",
+    "scid": "e6e7d903-96b7-48e1-ba72-4905d99db1d8",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00574",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.3222"
+      }
+    ],
+    "imsid": 734552,
+    "monitored": true,
+    "name": "NL-INTERNET2-MONTREAL",
+    "scid": "e70f64a3-c3a5-4ffb-8381-540934d4214a",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00893",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.4/31",
+          "2001:798:cc::31/126"
+        ],
+        "hostname": "rt1.kie.ua.geant.net",
+        "interface": "ae1.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.5/31",
+          "2001:798:cc::32/126"
+        ],
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "ae1.0"
+      }
+    ],
+    "imsid": 713325,
+    "monitored": true,
+    "name": "KIE-KIE-IPTRUNK",
+    "scid": "e716f601-8562-46e4-a043-4b4bbb2bbd10",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00045",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 727425,
+    "monitored": true,
+    "name": "V-LAN_1002_RT2.BRU.BE_XE-0/1/0_",
+    "scid": "e733196d-aed9-49ea-8f1a-4834fc98d0d0",
+    "service_type": "ETHERNET",
+    "sid": "GS-00675",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/6.1626"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.1626"
+      }
+    ],
+    "imsid": 736666,
+    "monitored": false,
+    "name": "FRA-PAR-SCION-SCION-INTERNET2-2",
+    "scid": "e739296c-d5fa-4b32-9867-03beab096b5f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02310",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 717107,
+    "monitored": false,
+    "name": "BUD-PRA-RARE-BMS9",
+    "scid": "e7640680-555a-4812-b2b2-7157db2572b7",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00687",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "UBUNTUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/5.2369"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.3400"
+      }
+    ],
+    "imsid": 706028,
+    "monitored": true,
+    "name": "LON-PAR-ESNET-UBUNTUNET-14020",
+    "scid": "e794124d-d77d-4bcb-b408-53c1c841b89a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00737",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CANARIE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.221/30",
+          "2001:0798:0029:10aa::1/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.204"
+      }
+    ],
+    "imsid": 660638,
+    "monitored": true,
+    "name": "FR-CANARIE-VLAN204",
+    "scid": "e7b236f7-8057-4b13-aac8-f3df7a94c5f9",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00881",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ASNET-AM"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-11/1/1.0"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae17.220"
+      }
+    ],
+    "imsid": 732138,
+    "monitored": true,
+    "name": "FRA-FRA-EAP-ASNET-AM-CL-190891",
+    "scid": "e7b8ad81-4627-43bf-9d8d-2d54d03d86bf",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00696",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.CHI.MD",
+        "port": "AE2"
+      }
+    ],
+    "imsid": 713246,
+    "monitored": true,
+    "name": "LAG-RT1.CHI.MD_AE2-SW1.CHI.MD_AE2",
+    "scid": "e7c4a8fb-21e0-4adc-81a5-53a2b406e53b",
+    "service_type": "ETHERNET",
+    "sid": "GA-02079",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.72/31",
+          "2001:798:cc::71/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae2.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.73/31",
+          "2001:798:cc::72/126"
+        ],
+        "hostname": "rt0.fra.de.geant.net",
+        "interface": "lag-1.0"
+      }
+    ],
+    "imsid": 739046,
+    "monitored": true,
+    "name": "FRA-FRA-IPTRUNK",
+    "scid": "e7de6e36-4cae-449a-aa3a-965132b699b2",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02461",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.116/31",
+          "2001:798:1::21d/126"
+        ],
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "ae10.333"
+      }
+    ],
+    "imsid": 714067,
+    "monitored": true,
+    "name": "RENAM-AP2-IAS",
+    "scid": "e7fe8c5f-58ca-4678-9e55-ab142560642f",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00542",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 739712,
+    "monitored": true,
+    "name": "GEN-GEN-800G-LAG",
+    "scid": "e80d7eaf-e342-4dd1-bda4-6dd08c5a2721",
+    "service_type": "ETHERNET",
+    "sid": "GA-02462",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FACEBOOK"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae46"
+      }
+    ],
+    "imsid": 737789,
+    "monitored": true,
+    "name": "FACEBOOK-FRA-LAG-1",
+    "scid": "e82da13d-472b-4c27-af77-1ad6ce36106c",
+    "service_type": "ETHERNET",
+    "sid": "GA-02481",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.180/31",
+          "2001:798:1e:10aa::9/126"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae10.1000"
+      }
+    ],
+    "imsid": 661320,
+    "monitored": true,
+    "name": "GARR-AP1",
+    "scid": "e84ab848-4ff2-422b-9941-3f3fe817c837",
+    "service_type": "GEANT IP",
+    "sid": "GS-00462",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.kie.ua.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 713306,
+    "monitored": true,
+    "name": "LAG-RT1.KIE.UA_AE2-SW1.KIE.UA_AE2",
+    "scid": "e84ef210-3dc2-4599-87c7-8a4662dcb768",
+    "service_type": "ETHERNET",
+    "sid": "GA-02025",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.PRA.CZ.GEANT2.NET",
+        "port": "ETH-45"
+      },
+      {
+        "hostname": "mx1.pra.cz.geant.net",
+        "interface": "xe-2/0/2.1025"
+      },
+      {
+        "hostname": "mx1.pra.cz.geant.net",
+        "interface": "ge-0/3/9.1025"
+      }
+    ],
+    "imsid": 660722,
+    "monitored": false,
+    "name": "BOD-SDN-PILOT-HOST-ETH4-PRAGUE",
+    "scid": "e869a973-1573-43e5-b456-b47b1a382708",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00105",
+    "speed": 11811160064,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "xe-2/1/4.200"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae23.200"
+      }
+    ],
+    "imsid": 720418,
+    "monitored": false,
+    "name": "GEN-GEN-SCION-SWITCH",
+    "scid": "e8db8b11-433b-4855-b52b-b214e711d57d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02199",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663165,
+    "monitored": false,
+    "name": "PS-FRA-DE-IDRAC",
+    "scid": "e8e4c67a-07ac-4dab-9b8d-47f094ce2384",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00298",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT-IT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/41"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/2/6.0"
+      },
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "xe-1/0/43"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-7/0/1.0"
+      }
+    ],
+    "imsid": 729418,
+    "monitored": true,
+    "name": "FRA-LON2-SUPERPOP-QFX-2-GEANT",
+    "scid": "e90afa3a-cab8-48fb-9991-5dd1ce9b0c5d",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00077|GS00077",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ge-0/3/2.302"
+      }
+    ],
+    "imsid": 661557,
+    "monitored": false,
+    "name": "VIE-GROOVE-1-MANAGEMENT",
+    "scid": "e9179e1a-884b-41ed-8193-d6fb1c3f07fd",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00381",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.127.133/31",
+          "2001:798:99:1::ce/126"
+        ],
+        "hostname": "srx1.ch.office.geant.net",
+        "interface": "ge-0/0/4.17"
+      }
+    ],
+    "imsid": 663138,
+    "monitored": false,
+    "name": "VIRGIN_MEDIA_EX1_LON2_TO_CAM_SRX_VLAN17-CH",
+    "scid": "e921bf8f-7400-41d3-ac31-9dbbd4008d5b",
+    "service_type": "CORPORATE",
+    "sid": "GS-01745",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.54/31",
+          "2001:798:111:1::ed/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21.111"
+      }
+    ],
+    "imsid": 747591,
+    "monitored": true,
+    "name": "NORDUNET-AP2-LHCONE",
+    "scid": "e9515340-d66c-41ea-817d-a4ceb85cc66a",
+    "service_type": "L3-VPN",
+    "sid": "GS-02118",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae17"
+      }
+    ],
+    "imsid": 659301,
+    "monitored": true,
+    "name": "FACEBOOK-LON-LAG",
+    "scid": "e9da92b5-91f2-4f8f-81aa-d561e149ac0f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01841",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 724242,
+    "monitored": false,
+    "name": "UAT-TEST-INTERCONNECT",
+    "scid": "e9fcc627-cadb-4198-90ee-8afc3356b58b",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-11115",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ARN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.134/31",
+          "2001:798:1::191/126"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae18.333"
+      }
+    ],
+    "imsid": 724754,
+    "monitored": true,
+    "name": "ES-ARN-AP1-IAS",
+    "scid": "ea0e586f-a78e-4f07-a87f-bf3676e5c6a8",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00529",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ge-0/3/2"
+      },
+      {
+        "addresses": [
+          "62.40.121.136/31"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae1.31"
+      }
+    ],
+    "imsid": 662202,
+    "monitored": true,
+    "name": "GENEVA-GENEVA-1GBE-006(ETH)",
+    "scid": "ea1950b4-8772-42e0-8a28-7dc7a2b33dc4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01543",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.fra.de - Traffic - ae29 - LAG PRIVATE AWS SRF9940987 |",
+    "scid": "ea2da137-4fc7-4ce1-9a3c-25244706f53d",
+    "service_type": null,
+    "sid": "GA-01937",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "UBUNTUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae17"
+      }
+    ],
+    "imsid": 735535,
+    "monitored": true,
+    "name": "NL-UBUNTUNET-LAG",
+    "scid": "ea454b4f-8a70-48f4-a281-4bdac5539225",
+    "service_type": "ETHERNET",
+    "sid": "GA-01917",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [],
+    "imsid": 712406,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-REDIRIS-1-ES",
+    "scid": "ea55246e-3330-4423-bea6-3c595ebb3275",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01029",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.106.201/30",
+          "2001:798:bb:1::11/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-23.0"
+      }
+    ],
+    "imsid": 747638,
+    "monitored": false,
+    "name": "HAM-DTN-10G-DATA",
+    "scid": "ea71e8ac-3ad3-4ef4-bcd2-bce97b8ffe27",
+    "service_type": "SERVER LINK",
+    "sid": "GS-02433",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 677538,
+    "monitored": false,
+    "name": "ATH OOB LINK",
+    "scid": "ea785ce8-c0ff-45b9-8553-735cf0f1e8f9",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00390",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "pwe-210341"
+      },
+      {
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-20:2112"
+      },
+      {
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "pwe-210341"
+      },
+      {
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "lag-20:2112"
+      }
+    ],
+    "imsid": 745926,
+    "monitored": true,
+    "name": "GEANT_EPIPE_210341",
+    "scid": "eaa71543-1004-479e-85fd-d2c076e5da61",
+    "service_type": "ETHERNET",
+    "sid": "GS-00752",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "LITNET"
+    ],
+    "endpoints": [],
+    "imsid": 745359,
+    "monitored": false,
+    "name": "RARE-02642",
+    "scid": "eab93543-e6ba-4fc3-a456-455787c79ebb",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02642",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.334"
+      }
+    ],
+    "imsid": 734557,
+    "monitored": true,
+    "name": "NL-NORDUNET-IX-2603",
+    "scid": "eada3559-0c96-47f8-955d-84844952fe32",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00939",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae19"
+      }
+    ],
+    "imsid": 738698,
+    "monitored": true,
+    "name": "ES-MICROSOFT-EXPRESSROUTE-LAG#1",
+    "scid": "eb15061d-27ef-4419-b393-fcdd9ca9c739",
+    "service_type": "ETHERNET",
+    "sid": "GA-02522",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ARNES"
+    ],
+    "endpoints": [],
+    "imsid": 669604,
+    "monitored": false,
+    "name": "VIE-LJU-GWS-ARNES-TELIA-17055",
+    "scid": "eb24a0cc-4b6d-4b89-8b31-7fb035a357f9",
+    "service_type": "GEANT LAMBDA",
+    "sid": "GS-00802",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 737214,
+    "monitored": true,
+    "name": "GEN-GEN-10G-LINK1",
+    "scid": "eb54bfd8-60b6-4078-a101-c3326d9c8c00",
+    "service_type": "ETHERNET",
+    "sid": "GA-01540",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.3914"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.25"
+      }
+    ],
+    "imsid": 713462,
+    "monitored": true,
+    "name": "NORDUNET-SUNET-EXPRESSROUTE-VLAN3914",
+    "scid": "eb5500be-7638-4e64-b18d-42de1b0ba1b3",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01160",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 679116,
+    "monitored": true,
+    "name": "ATH2-VIE-LAG",
+    "scid": "eb5a4e93-916f-4e98-8f02-bed347ab44d5",
+    "service_type": "ETHERNET",
+    "sid": "GA-01871",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "rt1.tal.ee - Traffic - ae3 - LAG INFRASTRUCTURE BACKBONE SRF0000001 | tal-tal ( rt1 to mx2.tal)",
+    "scid": "eb736df6-0e59-4bf6-9eb1-44661dc85b5f",
+    "service_type": null,
+    "sid": "GA-01736",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/3.141"
+      },
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae11.141"
+      }
+    ],
+    "imsid": 732906,
+    "monitored": false,
+    "name": "LIS-PAR-SCION-REDCLARA",
+    "scid": "eb975263-1b2c-4d72-b757-632c347b3a6f",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02435",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707238,
+    "monitored": false,
+    "name": "LON-GROOVE",
+    "scid": "ebb17817-ce5d-4f7c-9849-27097f4ec5da",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00227",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 660561,
+    "monitored": false,
+    "name": "IPCAMERA-PRA-CZ",
+    "scid": "ebb180e5-4be8-4e93-a9d1-c5edc92b53ad",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00211",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 712411,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-NORDUNET-2-SE",
+    "scid": "ebcbffc0-914c-4ed0-b4cd-04a0c8626938",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01027",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae20"
+      }
+    ],
+    "imsid": 659305,
+    "monitored": true,
+    "name": "MIL-MIX-LAG",
+    "scid": "ebda9ed0-18f9-4c95-be0e-c27dcaf9a8c3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01772",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661991,
+    "monitored": false,
+    "name": "PS-PAR-FR-IDRAC",
+    "scid": "ec01f788-909f-4f63-9820-1771daf28547",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00340",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.111/31",
+          "2001:798:cc::a6/126"
+        ],
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae2.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.110/31",
+          "2001:798:cc::a5/126"
+        ],
+        "hostname": "rt0.bud.hu.geant.net",
+        "interface": "lag-2.0"
+      }
+    ],
+    "imsid": 742924,
+    "monitored": true,
+    "name": "BUD-BUD-IPTRUNK",
+    "scid": "ec0f4cf4-541e-4dbc-abcc-42bb71b2c9d6",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02596",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [],
+    "imsid": 678999,
+    "monitored": false,
+    "name": "GEANT-OPERATIONS-LABCONNECTIVITY",
+    "scid": "ec260f18-5fb9-471c-80e8-703444d03ed2",
+    "service_type": "CORPORATE",
+    "sid": "GS-00468",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-1/0/3"
+      }
+    ],
+    "imsid": 658792,
+    "monitored": true,
+    "name": "POZNAN-POZNAN-10GBE-003(ETH)",
+    "scid": "ec4a8e1e-32ff-443c-8b28-7f9ad3c8f093",
+    "service_type": "ETHERNET",
+    "sid": "GA-01373",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661912,
+    "monitored": false,
+    "name": "PS-ATH-GR-MANAGEMENT",
+    "scid": "ec4b0c1e-336c-460a-959f-918eb1694ba4",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00291",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658711,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-050(ETH)",
+    "scid": "ecb128d0-af2b-442a-bcd1-b6e4934f5103",
+    "service_type": "ETHERNET",
+    "sid": "GA-02136",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.1214"
+      },
+      {
+        "hostname": "rt0.cor.ie.geant.net",
+        "interface": "pwe-121061"
+      },
+      {
+        "hostname": "rt0.cor.ie.geant.net",
+        "interface": "lag-20:1214"
+      }
+    ],
+    "imsid": 747413,
+    "monitored": false,
+    "name": "AMS-COR-00633",
+    "scid": "ecb83bc5-1689-4323-8318-b2860279feb6",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00633",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 709556,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-10GBE-016(GEANT)",
+    "scid": "ecb84052-2b15-49ed-ae10-1aae86b50621",
+    "service_type": "ETHERNET",
+    "sid": "GA-01664",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "EENET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.53/30",
+          "2001:798:16:10aa::5/126"
+        ],
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-21.100"
+      }
+    ],
+    "imsid": 745984,
+    "monitored": true,
+    "name": "EENET-AP2",
+    "scid": "ecbab82b-4027-4a3d-84ed-7863d04d1ac4",
+    "service_type": "GEANT IP",
+    "sid": "GS-00455",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "PIONIER"
+    ],
+    "endpoints": [],
+    "imsid": 669198,
+    "monitored": true,
+    "name": "PIONIER-GEO-UK-1-LL",
+    "scid": "ece1e83d-22d8-4076-89c4-ec5b8b6ba512",
+    "service_type": "CBL1",
+    "sid": "GA-01453",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658698,
+    "monitored": false,
+    "name": "730XD-5-ESXI-TRAFFIC-LAG-PAR",
+    "scid": "ecf777cc-e707-415c-bb84-376cfd9f0ea8",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01728",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 726688,
+    "monitored": true,
+    "name": "LON2-LON2-AMT-10GBE-1",
+    "scid": "ed084a6f-cb9e-42f9-977a-a3fc35166f7f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01331",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.vie.at - Telia  Multicast Traffic",
+    "scid": "ed25c91e-9f15-44d8-80e8-e889a134012d",
+    "service_type": null,
+    "sid": "DS-39951",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 727145,
+    "monitored": true,
+    "name": "BRU-BRU-LAG-100G",
+    "scid": "ed8bc845-9f12-441f-a744-3a776bfe0a4b",
+    "service_type": "ETHERNET",
+    "sid": "GA-02275",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.por.pt.geant.net",
+        "interface": "ae10.1944"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.2"
+      }
+    ],
+    "imsid": 706526,
+    "monitored": true,
+    "name": "FCCN-NOVESBE-EXPRESSROUTE-VLAN1944",
+    "scid": "ed902a30-88c5-426a-9633-fb9df364642c",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-01144",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.66/31",
+          "2001:798:1::17d/126"
+        ],
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-20.333"
+      }
+    ],
+    "imsid": 745494,
+    "monitored": true,
+    "name": "GRNET-AP1-IAS",
+    "scid": "ed92b8d4-144b-41f7-ba07-518978f5aae1",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00530",
+    "speed": 64424509440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/1"
+      }
+    ],
+    "imsid": 658423,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-005(ETH)",
+    "scid": "eda3f04a-627b-4c12-addf-e6f79a4874e8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01236",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SCION"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/3.1620"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.1620"
+      }
+    ],
+    "imsid": 736658,
+    "monitored": false,
+    "name": "PAR-PAR-SCION-INTERNET2-SCION-1",
+    "scid": "edde8f29-8902-4910-bccf-52d81a89baa7",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02295",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae28.220"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.220"
+      }
+    ],
+    "imsid": 736663,
+    "monitored": true,
+    "name": "LON-PAR-GEANTOPEN-INTERNET2-TENET-19004",
+    "scid": "ee2e0498-e64a-4289-9ca6-6e707f54b488",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00970",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-24"
+      }
+    ],
+    "imsid": 747895,
+    "monitored": true,
+    "name": "MREN-AP1-LAG",
+    "scid": "ee59a434-203c-43af-ab5b-88a4d1c4bb50",
+    "service_type": "ETHERNET",
+    "sid": "GA-01903",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.221/30",
+          "2001:798:1::51/126"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae10.333"
+      }
+    ],
+    "imsid": 660627,
+    "monitored": true,
+    "name": "GARR-AP1-IAS",
+    "scid": "ee6136a1-4415-41bd-ae41-74c310d61fdb",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00570",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "10.0.0.29/30"
+        ],
+        "hostname": "mx1.mil2.it.geant.net",
+        "interface": "xe-1/1/1.1003"
+      }
+    ],
+    "imsid": 661507,
+    "monitored": true,
+    "name": "JRA1-SDN-BOD-PILOT-BR53-VLAN1003",
+    "scid": "ee6786c2-3c76-45b2-8ca2-a3f6efd99b48",
+    "service_type": "L3-VPN",
+    "sid": "GS-00981",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lon2.uk.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 738840,
+    "monitored": true,
+    "name": "LON-LON2-1.6T-LAG",
+    "scid": "ee8e9d0e-867a-46a1-8d49-901875729caa",
+    "service_type": "ETHERNET",
+    "sid": "GA-01761",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [],
+    "imsid": 719305,
+    "monitored": false,
+    "name": "BELNET-GCLOUD-EXPRESSROUTE-VLAN4085",
+    "scid": "eeb38b33-2643-4eb4-a2a6-8b473ea3248b",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02151",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663065,
+    "monitored": false,
+    "name": "AMS-GROOVE-3-MANAGEMENT",
+    "scid": "eee69d9c-81e8-47ac-8792-524aa7bdfcef",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00096",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/2/4"
+      }
+    ],
+    "imsid": 721149,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-006(GEANT)",
+    "scid": "eefb6b1a-1428-4fe1-ab88-eb12ef559d40",
+    "service_type": "ETHERNET",
+    "sid": "GA-02193",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 728003,
+    "monitored": true,
+    "name": "AMS-PSMP-PS MGMT(GEANT)",
+    "scid": "ef097f6d-a480-4927-941a-bf49f401a659",
+    "service_type": "ETHERNET",
+    "sid": "GA-01636",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663059,
+    "monitored": false,
+    "name": "GEN-GROOVE-1-MANAGEMENT",
+    "scid": "ef17bd63-c7fc-4275-aef7-e642df962319",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00182",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "MAEEN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-4/1/4.102"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae27.102"
+      }
+    ],
+    "imsid": 738639,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-MAEEN-ESNET-22004",
+    "scid": "ef3258fd-4a9c-4db3-beab-48034d35a97f",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00464",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 712094,
+    "monitored": false,
+    "name": "HA-CB4088D78D",
+    "scid": "ef39e537-5d73-4817-80c5-ba1f9c73f204",
+    "service_type": "GTS",
+    "sid": "GS-01177",
+    "speed": 21474836480,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662225,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-1GBE-016(ETH)",
+    "scid": "ef5c8515-a906-4326-8da2-5eb23d437008",
+    "service_type": "ETHERNET",
+    "sid": "GA-01643",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "DE-AWS-CLS",
+    "scid": "ef620fee-3e6f-4062-b8ba-738acdbf7392",
+    "service_type": null,
+    "sid": "GS-00602",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/26"
+      }
+    ],
+    "imsid": 658456,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-011(ETH)",
+    "scid": "ef6d0b4e-63ab-4246-8bce-77c3e112a557",
+    "service_type": "ETHERNET",
+    "sid": "GA-01222",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708735,
+    "monitored": false,
+    "name": "ATH2-VIE-IPTRUNK",
+    "scid": "ef7365c0-3e14-46bb-8e0a-fed30dfb6426",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00015",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "SANET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.237/30",
+          "2001:798:1::ad/126"
+        ],
+        "hostname": "rt1.bra.sk.geant.net",
+        "interface": "ae13.421"
+      }
+    ],
+    "imsid": 718909,
+    "monitored": true,
+    "name": "SANET-AP1-IAS",
+    "scid": "ef9fffda-6c0e-4b59-9086-62bc5c023df8",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00546",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707589,
+    "monitored": false,
+    "name": "EUMETSAT-GRE-CMA2",
+    "scid": "efa22c49-0fa4-4394-8a54-7471c22149a8",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01074",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae10.0 - eumet"
+      }
+    ],
+    "imsid": 709757,
+    "monitored": true,
+    "name": "JISC EUMETCAST AP1",
+    "scid": "efb5cee1-d7e4-489d-9f8e-870d522d7954",
+    "service_type": "EUMETSAT TERRESTRIAL",
+    "sid": "GS-01109",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "IUCC"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.100.12/31",
+          "2001:798::15/126"
+        ],
+        "hostname": "mx1.fra.de.geant.net",
+        "interface": "ae21.667"
+      }
+    ],
+    "imsid": 662953,
+    "monitored": false,
+    "name": "IUCC-AP2-CLS",
+    "scid": "efbadb93-1bd2-44b1-901c-42276f988f1c",
+    "service_type": "GEANT CLOUD PEERING",
+    "sid": "GS-00611",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "VERIZON"
+    ],
+    "endpoints": [],
+    "imsid": 673552,
+    "monitored": true,
+    "name": "VIENNA-VERIZON-1-LAG",
+    "scid": "efcd918e-a187-4b16-aeaa-895deddf9904",
+    "service_type": "ETHERNET",
+    "sid": "GA-01851",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "138.44.226.17/31",
+          "2001:0388:cf7f:0004::1/127"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-2/0/5.2103"
+      }
+    ],
+    "imsid": 709697,
+    "monitored": false,
+    "name": "UK-AARNET-AER",
+    "scid": "efd624af-131e-4757-9c38-7690a2df7219",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00905",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ham-pra-WP6-GTS-21010",
+    "scid": "eff72a03-7f7c-4c46-a733-942098524fe0",
+    "service_type": null,
+    "sid": "DS-53421",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "URAN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.46/31",
+          "2001:798:1::211/126"
+        ],
+        "hostname": "rt2.kie.ua.geant.net",
+        "interface": "ae10.333"
+      }
+    ],
+    "imsid": 714004,
+    "monitored": true,
+    "name": "URAN-AP2-IAS",
+    "scid": "f0119914-5aac-454f-9958-22213fb635c5",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00594",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "150.99.188.202/30",
+          "2001:2f8:1:ff::12/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.207"
+      }
+    ],
+    "imsid": 661583,
+    "monitored": true,
+    "name": "FR-SINET",
+    "scid": "f02ffb81-3020-4fa1-a96f-390ea23feb5c",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00885",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 744013,
+    "monitored": true,
+    "name": "BRU-PAR-LAG",
+    "scid": "f038ad2a-c095-4cc7-b98d-c6e86822fc87",
+    "service_type": "ETHERNET",
+    "sid": "GA-02278",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662984,
+    "monitored": false,
+    "name": "PS-FRA-DE-PSMP2-OWAMP",
+    "scid": "f03d2944-b17f-4dec-abdc-b2f000252b73",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00303",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.19"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4060"
+      }
+    ],
+    "imsid": 739667,
+    "monitored": true,
+    "name": "BELNET-STAD-EXPRESSROUTE-VLAN4060",
+    "scid": "f0642514-1e8d-4243-927f-115a3f08482b",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02246",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708250,
+    "monitored": false,
+    "name": "NETMON-FRA-DE",
+    "scid": "f06ad980-cb53-4847-a657-3571a887d8f4",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00258",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.125/30",
+          "2001:798:28:20aa::1/126"
+        ],
+        "hostname": "rt0.dub.ie.geant.net",
+        "interface": "lag-20.12"
+      }
+    ],
+    "imsid": 747282,
+    "monitored": true,
+    "name": "HEANET-AP1",
+    "scid": "f07ec522-739d-4ddd-a06d-a8f1e205273f",
+    "service_type": "GEANT IP",
+    "sid": "GS-00473",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 673550,
+    "monitored": true,
+    "name": "FRANKFURT-FRANKFURT-10GBE-097(GEANT)",
+    "scid": "f08db4ba-17a0-490f-aa9d-949cbf4b5f46",
+    "service_type": "ETHERNET",
+    "sid": "GA-02131",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.254/31",
+          "2001:798:cc:1::111/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-1.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.255/31",
+          "2001:798:cc:1::112/126"
+        ],
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "lag-2.0"
+      }
+    ],
+    "imsid": 746460,
+    "monitored": true,
+    "name": "HAM-TAR-IPTRUNK",
+    "scid": "f0af1eae-65d1-4d6e-b8da-c758c0ee84e2",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02348",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.9/30",
+          "2001:798:1::10d/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae12.333"
+      }
+    ],
+    "imsid": 661239,
+    "monitored": true,
+    "name": "RENATER-AP1-IAS",
+    "scid": "f0b9d099-3730-4a91-a0be-26173d5300b1",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00583",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.48/31",
+          "2001:798:cc:1::15/126"
+        ],
+        "hostname": "rt0.lju.si.geant.net",
+        "interface": "lag-3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.49/31",
+          "2001:798:cc:1::16/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-4.0"
+      }
+    ],
+    "imsid": 747865,
+    "monitored": true,
+    "name": "LJU-ZAG-IPTRUNK",
+    "scid": "f0c12044-1853-4385-bfb4-d19c274bb1ff",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02372",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 659041,
+    "monitored": true,
+    "name": "PRAGUE-PRAGUE-1GBE-011(ETH)",
+    "scid": "f0c9b8fc-05d2-4224-b54f-359153521257",
+    "service_type": "ETHERNET",
+    "sid": "GA-01438",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT-IT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/3/0"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/2/0"
+      }
+    ],
+    "imsid": 739656,
+    "monitored": false,
+    "name": "AMSTERDAM-FRANKFURT 15-ETHS-003(GEANT-IT)",
+    "scid": "f0ea36c3-7971-4d61-a6fe-052f7604f4eb",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-02555",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [
+      "CERN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.249/30",
+          "2001:798:1::1f5/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae22.334"
+      }
+    ],
+    "imsid": 701592,
+    "monitored": true,
+    "name": "CERN-AP1-EXT2-IAS",
+    "scid": "f12ed2bd-deb6-4ecc-8f23-7ecb437daaff",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00561",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CANARIE"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.3928"
+      }
+    ],
+    "imsid": 746471,
+    "monitored": true,
+    "name": "NL-CANARIE-VLAN3928",
+    "scid": "f130a216-d6ae-4681-bea4-accdd8a9c625",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02646",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EENET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.28/31",
+          "2001:798:111:1::bd/126"
+        ],
+        "hostname": "rt0.tar.ee.geant.net",
+        "interface": "lag-20.111"
+      }
+    ],
+    "imsid": 746449,
+    "monitored": true,
+    "name": "EENET-AP1-LHCONE",
+    "scid": "f15da16d-ef35-44a9-897d-0cad24d1001a",
+    "service_type": "L3-VPN",
+    "sid": "GS-00818",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae11"
+      }
+    ],
+    "imsid": 717033,
+    "monitored": true,
+    "name": "NL-ORACLEFC-LAG-2",
+    "scid": "f16a928a-98d9-48e4-81e3-9187fd4f77ff",
+    "service_type": "ETHERNET",
+    "sid": "GA-02035",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PSMP-GN-DRAC-PAR-FR.GEANT.ORG",
+        "port": "10GE-2"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/2/7.903"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.903"
+      }
+    ],
+    "imsid": 705916,
+    "monitored": true,
+    "name": "PAR-PAR-MISC-GEANT-INTERNET2-9940539",
+    "scid": "f1aefbbb-364d-432f-99c8-3f4283f02a2d",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00747",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4074"
+      },
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.46"
+      },
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.45"
+      }
+    ],
+    "imsid": 747921,
+    "monitored": false,
+    "name": "MSECREDENDO-02655",
+    "scid": "f1afd29a-e811-40a2-a7aa-fcf5b9b42d22",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02655",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.168/31",
+          "2001:798:111:1::35/126"
+        ],
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-20.111"
+      }
+    ],
+    "imsid": 745581,
+    "monitored": true,
+    "name": "DFN-AP2-LHCONE",
+    "scid": "f1c4b902-9034-4227-80a7-e84efefb5ed4",
+    "service_type": "L3-VPN",
+    "sid": "GS-00817",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.1002"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae12.1002"
+      }
+    ],
+    "imsid": 705906,
+    "monitored": false,
+    "name": "LON-LON-GEANTOPEN-NORDUNET-TEIN-17026",
+    "scid": "f209045e-927f-41f9-a227-dca0c6a70dfc",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00977",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662983,
+    "monitored": false,
+    "name": "HADES-FRA-DE-DRAC",
+    "scid": "f20950ca-3c46-4a55-93fd-c73cc99457fa",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00193",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.24/31",
+          "2001:798:99:1::45/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae28.2061"
+      }
+    ],
+    "imsid": 720021,
+    "monitored": true,
+    "name": "UK-REDCLARA",
+    "scid": "f2251c9b-6c06-4730-a366-580194782d92",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02166",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.chi.md.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 713246,
+    "monitored": true,
+    "name": "LAG-RT1.CHI.MD_AE2-SW1.CHI.MD_AE2",
+    "scid": "f228fab6-5e86-498b-bb6f-423a99012c00",
+    "service_type": "ETHERNET",
+    "sid": "GA-02017",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bra.sk.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 742923,
+    "monitored": true,
+    "name": "BRA-BRA-MGMT-LAG",
+    "scid": "f22c031d-b72d-4a1b-8efc-b8a8c5447d32",
+    "service_type": "ETHERNET",
+    "sid": "GA-02601",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-0/0/47"
+      }
+    ],
+    "imsid": 658779,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-052(ETH)",
+    "scid": "f2351756-f873-418b-87dc-b00617db56c4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01242",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae1"
+      }
+    ],
+    "imsid": 658656,
+    "monitored": false,
+    "name": "LON2-PRD-ESX01-ESXI-TRAFFIC",
+    "scid": "f24ed56e-40d7-4e52-950c-e87997f38af7",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01690",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CANARIE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.124.241/30",
+          "2001:798:99:1::55/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae19.4050"
+      }
+    ],
+    "imsid": 736733,
+    "monitored": true,
+    "name": "FR-CANARIE-2",
+    "scid": "f262053e-6b35-4a7d-a601-4f74b453f8f7",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00913",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-0/0/6"
+      }
+    ],
+    "imsid": 658389,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-006(ETH)",
+    "scid": "f2a8d7c7-de1d-4eca-876d-4869313b85d4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01255",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.LIS.PT",
+        "port": "AE2"
+      }
+    ],
+    "imsid": 711783,
+    "monitored": true,
+    "name": "LAG-SW1.LIS.PT_AE2",
+    "scid": "f2ad9c81-56b1-4c7e-b3f6-fbd9554e2b83",
+    "service_type": "ETHERNET",
+    "sid": "GA-02059",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RASH"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.142/31",
+          "2001:798:99:1::129/126"
+        ],
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae16.100"
+      }
+    ],
+    "imsid": 727800,
+    "monitored": true,
+    "name": "RASH-AP1-100G",
+    "scid": "f2c69e20-8d1a-4f06-a8a7-fb5c532f91d2",
+    "service_type": "GEANT IP",
+    "sid": "GS-02325",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.182/31",
+          "2001:798:99:1::b9/126"
+        ],
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae20.100"
+      }
+    ],
+    "imsid": 734867,
+    "monitored": true,
+    "name": "NL-SINET",
+    "scid": "f30044b6-7d96-45e1-a3c8-ed91badcf8a6",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00901",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662274,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-10GBE-005(GEANT)",
+    "scid": "f3044a88-f150-4a1f-817e-e03a3652c462",
+    "service_type": "ETHERNET",
+    "sid": "GA-01552",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae31"
+      }
+    ],
+    "imsid": 659382,
+    "monitored": true,
+    "name": "LAG-MX1.LON2.UK_AE16",
+    "scid": "f34249c0-f1d0-44dc-9a1c-39ff73a9de14",
+    "service_type": "ETHERNET",
+    "sid": "GA-01710",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.91/31",
+          "2001:798:cc::96/126"
+        ],
+        "hostname": "rt0.mad.es.geant.net",
+        "interface": "lag-1.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.90/31",
+          "2001:798:cc::95/126"
+        ],
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae1.0"
+      }
+    ],
+    "imsid": 742615,
+    "monitored": true,
+    "name": "MAD-MAD-IPTRUNK",
+    "scid": "f35011c1-e830-4a04-9146-734c49f1167b",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02593",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 745264,
+    "monitored": true,
+    "name": "SOF-THE-LAG",
+    "scid": "f3adaf16-f049-40aa-9bd0-26c54b3c7334",
+    "service_type": "ETHERNET",
+    "sid": "GA-02425",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "srx2.ch.office.geant.net",
+        "interface": "ge-0/0/3"
+      }
+    ],
+    "imsid": 662524,
+    "monitored": true,
+    "name": "SRX-2 TO SWITCH CLUSTER GE-2/0/0",
+    "scid": "f3cb4467-e5e6-4dc8-aa4d-04f6535900c6",
+    "service_type": "ETHERNET",
+    "sid": "GA-00707",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 659079,
+    "monitored": true,
+    "name": "TALLINN-TALLINN-10GBE-019(ETH)",
+    "scid": "f3e49f30-f834-4c48-aee3-769bb2ce488d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01497",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 745424,
+    "monitored": true,
+    "name": "ATHENS 2-ATHENS 2-LAG-005(GEANT)",
+    "scid": "f4187418-393d-4d31-9a1c-c0b40b67f679",
+    "service_type": "ETHERNET",
+    "sid": "GA-01931",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae45"
+      }
+    ],
+    "imsid": 730219,
+    "monitored": true,
+    "name": "FR-APPLE-LAG",
+    "scid": "f425bf68-5c6f-453c-9566-767b640d8b95",
+    "service_type": "ETHERNET",
+    "sid": "GA-02396",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "AMRES"
+    ],
+    "endpoints": [],
+    "imsid": 712405,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-AMRES-RS",
+    "scid": "f4373516-73ad-48a0-a0ca-c545d7d9d796",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01032",
+    "speed": 32212254720,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 744407,
+    "monitored": true,
+    "name": "ZAG-ZAG-MGMT-LAG",
+    "scid": "f464a3d1-e7d6-4fc5-bb73-182c7103d37c",
+    "service_type": "ETHERNET",
+    "sid": "GA-50046",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-8"
+      }
+    ],
+    "imsid": 739434,
+    "monitored": true,
+    "name": "LON2-PAR-1.6T-LAG",
+    "scid": "f46b8482-e0b5-4471-a75f-6e673d0358a8",
+    "service_type": "ETHERNET",
+    "sid": "GA-01824",
+    "speed": 1717986918400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "FCCN"
+    ],
+    "endpoints": [],
+    "imsid": 661908,
+    "monitored": true,
+    "name": "FCCN-BGP-LU-COC-AP1",
+    "scid": "f46ca543-c625-4ca2-826b-d087b44504d2",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01003",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "AMRES"
+    ],
+    "endpoints": [],
+    "imsid": 732622,
+    "monitored": true,
+    "name": "AMRES-AP2-BGP-LU-COC",
+    "scid": "f4e0ef73-b842-45c6-8b05-1e2f01ebe9e6",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-02242",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.77/30",
+          "2001:798:14:10aa::19/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.203"
+      }
+    ],
+    "imsid": 661433,
+    "monitored": true,
+    "name": "UK-ESNET-NEA3R-203",
+    "scid": "f4f539f7-2b9d-4c15-acb0-b7d24a39b815",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00918",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SWITCH"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.FRA.DE.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-0/0/2.559"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae23.559"
+      }
+    ],
+    "imsid": 709921,
+    "monitored": false,
+    "name": "FRA-GEN-SWITCH-RARE-21035",
+    "scid": "f51f1151-fc6e-40e9-8929-fd889b36dde7",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00700",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.89.221/30",
+          "2001:798:1::1c1/126"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.333"
+      }
+    ],
+    "imsid": 739626,
+    "monitored": true,
+    "name": "BELNET-AP2-IAS",
+    "scid": "f54aa0dc-def2-48a6-b0cc-8a9c4d9cebac",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00523",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "IUCC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae21"
+      }
+    ],
+    "imsid": 730575,
+    "monitored": true,
+    "name": "IUCC-AP1-LAG",
+    "scid": "f56b5af4-866d-478e-a73f-178314524ae6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01831",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "T-SYSTEMS"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "80.158.74.247/31"
+        ],
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae21.4001"
+      }
+    ],
+    "imsid": 727982,
+    "monitored": true,
+    "name": "DE-T-SYSTEMS-IAS",
+    "scid": "f573c67a-ee66-43cc-b7f5-60c3ae4a4658",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-02273",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.3901"
+      },
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae17.3901"
+      }
+    ],
+    "imsid": 706599,
+    "monitored": true,
+    "name": "PAR-PAR-GEANTOPEN-SINET-SINET-19033",
+    "scid": "f5ab9f38-4e28-4211-b171-8273576fd4e7",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00987",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661506,
+    "monitored": false,
+    "name": "PAR-GROOVE-1-MANAGEMENT",
+    "scid": "f5b6db7d-9e5b-4e31-99fd-de95766d5898",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00273",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.14/31",
+          "2001:798:cc::9/126"
+        ],
+        "hostname": "rt1.buc.ro.geant.net",
+        "interface": "ae3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.15/31",
+          "2001:798:cc::a/126"
+        ],
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-5.0"
+      }
+    ],
+    "imsid": 744991,
+    "monitored": true,
+    "name": "BUC-SOF-IPTRUNK",
+    "scid": "f5bba7dc-072b-46df-ace7-1b04840dd749",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00024",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURF"
+    ],
+    "endpoints": [],
+    "imsid": 715093,
+    "monitored": true,
+    "name": "SURF-AMS-LON1-SPECTRUM SERVICE 2",
+    "scid": "f5d5d74e-33a4-4dcd-bfa5-0b4172fec9b5",
+    "service_type": "GEANT SPECTRUM SERVICE",
+    "sid": "GS-00072",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 718618,
+    "monitored": true,
+    "name": "GEN1-MIL2-IPTRUNK-GN43N",
+    "scid": "f5e2d713-3ba0-4f04-bd6f-bc5b4d77f9b3",
+    "service_type": "IP TRUNK",
+    "sid": "GS-01184",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "xe-3/0/1"
+      }
+    ],
+    "imsid": 662343,
+    "monitored": true,
+    "name": "RARE EDGECORE WEDGE100BF-32X XE-1",
+    "scid": "f5ef2dd1-3afb-47a4-bd3a-44d84298df21",
+    "service_type": "ETHERNET",
+    "sid": "GA-02127",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "LITNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.97/30",
+          "2001:798:1::79/126"
+        ],
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "ae10.333"
+      }
+    ],
+    "imsid": 745338,
+    "monitored": true,
+    "name": "LITNET-AP2-IAS",
+    "scid": "f5fdfd1e-565f-459a-a594-1984940278d0",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00535",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MICROSOFT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.ham.de.geant.net",
+        "interface": "lag-21:3907"
+      }
+    ],
+    "imsid": 747630,
+    "monitored": true,
+    "name": "AMS-HAM-MSE-01149",
+    "scid": "f6173209-5041-4a7a-9a7e-2b40155b5aa5",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-01149",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663111,
+    "monitored": false,
+    "name": "DNA-FRA-DE-ESXI",
+    "scid": "f6218c06-75b0-404f-bdec-4325f4b27bfa",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00135",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 743601,
+    "monitored": true,
+    "name": "SOF-SOF-MGMT-LAG",
+    "scid": "f6316502-c558-479a-acbc-6d9ca6e004bd",
+    "service_type": "ETHERNET",
+    "sid": "GA-50011",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae2"
+      }
+    ],
+    "imsid": 736042,
+    "monitored": true,
+    "name": "RT1.AMS-SW3.AMS-LAG",
+    "scid": "f658994d-83be-4666-90c2-3e3eb2b75bc5",
+    "service_type": "ETHERNET",
+    "sid": "GA-02076",
+    "speed": 42949672960,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "AMRES"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.sof.bg.geant.net",
+        "interface": "lag-21"
+      }
+    ],
+    "imsid": 744885,
+    "monitored": true,
+    "name": "AMRES-AP2-LAG",
+    "scid": "f66c70fe-969b-4c98-b9b7-6f065b169c05",
+    "service_type": "ETHERNET",
+    "sid": "GA-02239",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-3/0/4"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae30"
+      }
+    ],
+    "imsid": 733831,
+    "monitored": true,
+    "name": "NL-ESNET-400G-LL-1",
+    "scid": "f672dea8-743e-47c9-a43c-92be651d92d4",
+    "service_type": "ETHERNET",
+    "sid": "GA-01594",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NIKS"
+    ],
+    "endpoints": [],
+    "imsid": 662398,
+    "monitored": true,
+    "name": "NL-NIKS-LL1",
+    "scid": "f67a47c2-15bb-42f3-b960-9f0f513e0d34",
+    "service_type": "ETHERNET",
+    "sid": "GA-01595",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661966,
+    "monitored": false,
+    "name": "EXFO-MANAGEMENT-VLAN11",
+    "scid": "f67ded67-eeec-4523-b72d-5675b90a21a8",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00160",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 712390,
+    "monitored": false,
+    "name": "MD-VPN-VRR-PARIS-FUNET-1-FI",
+    "scid": "f6a29eac-c560-4152-9875-763df6dfd1ce",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01040",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/6"
+      }
+    ],
+    "imsid": 658758,
+    "monitored": true,
+    "name": "LONDON-LONDON-10GBE-001(ETH)",
+    "scid": "f6a996f9-d35a-460e-8903-a27a8378f015",
+    "service_type": "ETHERNET",
+    "sid": "GA-01456",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.48/31",
+          "2001:798:111:1::49/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae18.111"
+      }
+    ],
+    "imsid": 734866,
+    "monitored": true,
+    "name": "KIFU-AP2-LHCONE",
+    "scid": "f6bcb143-6e53-4a71-bd87-e3e73ad062cd",
+    "service_type": "L3-VPN",
+    "sid": "GS-02283",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bud.hu.geant.net",
+        "interface": "lag-2"
+      }
+    ],
+    "imsid": 742922,
+    "monitored": true,
+    "name": "BUD-BUD-LAG",
+    "scid": "f6cf441f-e381-4b14-a29e-fedc8bb4c241",
+    "service_type": "ETHERNET",
+    "sid": "GA-02595",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.par.fr.geant.net",
+        "interface": "ae13"
+      }
+    ],
+    "imsid": 729696,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-LAG-005(GEANT)",
+    "scid": "f6df960c-f512-48ca-a4e1-bf5834c3f821",
+    "service_type": "ETHERNET",
+    "sid": "GA-01727",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SURFNET"
+    ],
+    "endpoints": [],
+    "imsid": 709647,
+    "monitored": false,
+    "name": "SURFNET-GN-PRACE-VPN-PROXY-AMSTERDAM-L3VPN",
+    "scid": "f7113599-a010-4b4b-9580-17716f5def50",
+    "service_type": "MD-VPN (PROXY)",
+    "sid": "GS-01070",
+    "speed": 214748364800,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae0.0"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae30.3005"
+      }
+    ],
+    "imsid": 733914,
+    "monitored": false,
+    "name": "RARE-GATEWAY",
+    "scid": "f7157a4c-d22a-43a8-adda-2230523e86ed",
+    "service_type": "L2SERVICES",
+    "sid": "GS-00770",
+    "speed": 0,
+    "status": "planned"
+  },
+  {
+    "customers": [
+      "EENET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.30/31",
+          "2001:798:111:1::c5/126"
+        ],
+        "hostname": "rt0.rig.lv.geant.net",
+        "interface": "lag-21.111"
+      }
+    ],
+    "imsid": 745973,
+    "monitored": true,
+    "name": "EENET-AP2-LHCONE",
+    "scid": "f7548313-efaf-4a72-96f5-9c6db0e697be",
+    "service_type": "L3-VPN",
+    "sid": "GS-00819",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "INTERNET2"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.17/30",
+          "2001:798:14:10aa::11/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae26.202"
+      }
+    ],
+    "imsid": 709338,
+    "monitored": true,
+    "name": "UK-INTERNET2-NEA3R-202",
+    "scid": "f78c3575-5951-4190-bdf2-53d35c1542de",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00919",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ams-par_DREAMER_GTS-Internet2_15027",
+    "scid": "f793fb9a-800d-4c94-a3fb-69dd947595c9",
+    "service_type": null,
+    "sid": "DS-28754",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "ae7"
+      }
+    ],
+    "imsid": 658524,
+    "monitored": false,
+    "name": "LON2-PRD-ESX11-ESXI-TRAFFIC",
+    "scid": "f7adf2fc-4f30-4f4e-a4d2-9fcf609bdb4d",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01694",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.88.37/30",
+          "2001:798:1::29/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae23.333"
+      }
+    ],
+    "imsid": 731675,
+    "monitored": true,
+    "name": "CESNET-AP2-IAS",
+    "scid": "f8167375-b1b3-4abe-ac48-c53a833ad881",
+    "service_type": "GEANT PEERING",
+    "sid": "GS-00564",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NKN"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.214/31",
+          "2001:798:99:1::c1/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae20.100"
+      }
+    ],
+    "imsid": 678060,
+    "monitored": true,
+    "name": "CH-NKN",
+    "scid": "f8277d8d-67be-4ce4-bc17-66f4696beb57",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-00874",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707210,
+    "monitored": false,
+    "name": "FRA-GROOVE",
+    "scid": "f82f76ea-bd89-4414-9745-7314d6ad5426",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00171",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.40"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4071"
+      }
+    ],
+    "imsid": 739671,
+    "monitored": true,
+    "name": "BELNET-FEDPOL-EXPRESSROUTE-VLAN4071",
+    "scid": "f83d6d92-aad8-4eb9-85e2-f9aaddf96225",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02525",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/1"
+      }
+    ],
+    "imsid": 658589,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-036(ETH)",
+    "scid": "f846cb8e-2491-481e-9ed9-c556e0cc97c6",
+    "service_type": "ETHERNET",
+    "sid": "GA-01237",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 712410,
+    "monitored": true,
+    "name": "MD-VPN-VRR-LJUBLJANA-NORDUNET-1-DK",
+    "scid": "f8472840-1e5a-47f2-9b1f-b823798f3167",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01026",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "172.18.16.254/24"
+        ],
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "ae2.103"
+      }
+    ],
+    "imsid": 715035,
+    "monitored": false,
+    "name": "DCN-MANAGEMENT-CHI2-MD",
+    "scid": "f8930a4b-cca7-48f7-8274-0370f769561c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00128",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658845,
+    "monitored": true,
+    "name": "LISBON-LISBON-10GBE-010(ETH)",
+    "scid": "f8a0ed9c-4adf-40e0-8f5e-87a6e2b39c5f",
+    "service_type": "ETHERNET",
+    "sid": "GA-01357",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 721148,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-005(GEANT)",
+    "scid": "f8d853f3-e786-4ad7-adf5-573e83d3716c",
+    "service_type": "ETHERNET",
+    "sid": "GA-01387",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "Used for SINET LHCONE LON2 L3VPN (33123)",
+    "scid": "f8d8cd0d-edac-4bb0-9cde-7e94c8eb06a8",
+    "service_type": null,
+    "sid": "DS-33109",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ham-par_SCION_GTS-DFN_20021",
+    "scid": "f8d8d111-3315-4695-a32e-391cf459867b",
+    "service_type": null,
+    "sid": "DS-51513",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae40"
+      }
+    ],
+    "imsid": 731897,
+    "monitored": true,
+    "name": "ORACLE FASTCONNECT NREN-LAG",
+    "scid": "f8fc738e-c033-4a4a-b9c1-7c186e444416",
+    "service_type": "ETHERNET",
+    "sid": "GA-02011",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.56/31",
+          "2001:798:111:1::f1/126"
+        ],
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae28.2062"
+      }
+    ],
+    "imsid": 720027,
+    "monitored": true,
+    "name": "REDCLARA-TENET-LON-LHCONE",
+    "scid": "f955b83c-c563-406a-9688-f5f230fa05b4",
+    "service_type": "L3-VPN",
+    "sid": "GS-02167",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/5.25"
+      },
+      {
+        "hostname": "rt1.mil2.it.geant.net",
+        "interface": "ae10.25"
+      }
+    ],
+    "imsid": 705891,
+    "monitored": true,
+    "name": "LON-MIL2-ASI-BSC-TO-FUCINO-UBUNTUNET-GARR-20007",
+    "scid": "f956be7a-8206-49f9-ae4b-12e7a56f41db",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00735",
+    "speed": 332859965440,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MAEEN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae27"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "ae27.1"
+      }
+    ],
+    "imsid": 713955,
+    "monitored": true,
+    "name": "MAEEN-UK-LAG",
+    "scid": "f95b2228-2df8-42c4-927f-3d022cc5b428",
+    "service_type": "ETHERNET",
+    "sid": "GA-02005",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "CERN_CERN_ExpressRoute_VLAN497_Backup",
+    "scid": "f95b8df0-63bf-46a5-b66f-39bf4bda15af",
+    "service_type": null,
+    "sid": "DS-53203",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "DFN"
+    ],
+    "endpoints": [
+      {
+        "equipment": "FRA01-GRV4",
+        "port": "1/1/3"
+      },
+      {
+        "equipment": "GEN01-GRV4",
+        "port": "1/1/3"
+      }
+    ],
+    "imsid": 707337,
+    "monitored": true,
+    "name": "FRA-GEN-LHCOPN-CERN-DFN-20107",
+    "scid": "f95c4467-e504-4af8-ba82-ddb3fb3609b0",
+    "service_type": "GEANT MANAGED WAVELENGTH SERVICE",
+    "sid": "GS-00792",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "SINGAREN"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/1/4"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/1/4.1"
+      }
+    ],
+    "imsid": 659143,
+    "monitored": true,
+    "name": "SINGAREN-GEO-UK-1-LL",
+    "scid": "f961e496-923b-41cf-9f65-a42f2164aab6",
+    "service_type": "CBL1",
+    "sid": "GA-02230",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RARE"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.AMS.NL.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.3068"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-9/0/3.3068"
+      }
+    ],
+    "imsid": 736077,
+    "monitored": false,
+    "name": "AMS-AMS-RARE-CANARIE-21013",
+    "scid": "f975758c-15c1-4b81-800f-59e978831ea9",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00627",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 715104,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-005(ETH)",
+    "scid": "f983020b-e1eb-4638-a825-ddd7a10a4a62",
+    "service_type": "ETHERNET",
+    "sid": "GA-01588",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661998,
+    "monitored": false,
+    "name": "JUNOSSPACE-R720-VCENTRE-PAR-FR",
+    "scid": "f9a1b28a-c999-402d-ada1-bbed117e1035",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00216",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 745424,
+    "monitored": true,
+    "name": "ATHENS 2-ATHENS 2-LAG-005(GEANT)",
+    "scid": "f9cab4d4-1052-4f27-8b59-a79456744fd3",
+    "service_type": "ETHERNET",
+    "sid": "GA-01796",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.AM.OFFICE",
+        "port": "GE-0/0/5"
+      }
+    ],
+    "imsid": 658464,
+    "monitored": true,
+    "name": "AMSTERDAM GEANT OFFICE-AMSTERDAM GEANT OFFICE-1GBE-013(ETH)",
+    "scid": "f9f115e8-92b6-47b9-bdd6-db26f0cd6f99",
+    "service_type": "ETHERNET",
+    "sid": "GA-01256",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EXOSCALE"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "83.97.90.16/31",
+          "2001:798:1::235/126"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae23.668"
+      }
+    ],
+    "imsid": 717332,
+    "monitored": false,
+    "name": "CH-EXOSCALE-IAS",
+    "scid": "f9fd088a-f1ee-4336-a3bf-f5247eb05541",
+    "service_type": "IP PEERING - NON R&E (PRIVATE)",
+    "sid": "GS-00601",
+    "speed": 429496729600,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GARR"
+    ],
+    "endpoints": [],
+    "imsid": 661246,
+    "monitored": true,
+    "name": "GARR-BGP-LU-COC-AP1",
+    "scid": "fa00a50f-d5e5-408e-a03e-6b080a591d4f",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01005",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "ROEDUNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.36/31",
+          "2001:798:111:1::b5/126"
+        ],
+        "hostname": "mx1.vie.at.geant.net",
+        "interface": "ae21.111"
+      }
+    ],
+    "imsid": 679572,
+    "monitored": true,
+    "name": "ROEDUNET-AP2-LHCONE",
+    "scid": "fa298bd7-e2ae-42b2-82ad-866166619478",
+    "service_type": "L3-VPN",
+    "sid": "GS-00858",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662208,
+    "monitored": true,
+    "name": "AMSTERDAM-AMSTERDAM-1GBE-044(ETH)",
+    "scid": "fa704539-9ba7-4eb9-9ac4-89b3563daf35",
+    "service_type": "ETHERNET",
+    "sid": "GA-01629",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.50/31",
+          "2001:798:cc::1d/126"
+        ],
+        "hostname": "rt0.poz.pl.geant.net",
+        "interface": "lag-7.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.51/31",
+          "2001:798:cc::1e/126"
+        ],
+        "hostname": "rt0.pra.cz.geant.net",
+        "interface": "lag-7.0"
+      }
+    ],
+    "imsid": 740495,
+    "monitored": true,
+    "name": "POZ-PRA-IPTRUNK",
+    "scid": "fa73a1c1-2042-4185-8cc2-0388a1244603",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02407",
+    "speed": 322122547200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708262,
+    "monitored": false,
+    "name": "LONDON-LONDON-ETHS-001(GEANT)",
+    "scid": "fa89a1ee-83a4-48db-a21d-fb90ea6ef27c",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00244",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 658957,
+    "monitored": true,
+    "name": "LONDON-LONDON-10GBE-018(ETH)",
+    "scid": "fad7259f-b097-45f0-adb6-3402b846fb31",
+    "service_type": "ETHERNET",
+    "sid": "GA-01455",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.lon2.uk.geant.net",
+        "interface": "xe-1/0/44"
+      }
+    ],
+    "imsid": 739583,
+    "monitored": true,
+    "name": "LONDON 2-LONDON 2-10GBE-040(GEANT)",
+    "scid": "fae175fc-efdf-48cc-876f-c89628447334",
+    "service_type": "ETHERNET",
+    "sid": "GS-00077",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.41"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "pwe-124068"
+      },
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20:4067"
+      }
+    ],
+    "imsid": 744149,
+    "monitored": true,
+    "name": "MSEAZDELTA-02564",
+    "scid": "fb0adcdb-e6df-4798-a1f1-ab10afa6f4ee",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02564",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "ae12"
+      }
+    ],
+    "imsid": 658677,
+    "monitored": false,
+    "name": "FRANKFURT 15-FRANKFURT 15-LAG-061(GEANT)",
+    "scid": "fb1e4e6a-4d1e-4be3-b49c-91ab6dc05d9d",
+    "service_type": "POP LAN LINK",
+    "sid": "GA-01684",
+    "speed": 32212254720,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [],
+    "imsid": 663121,
+    "monitored": true,
+    "name": "RENATER-BGP-LU-COC-AP2",
+    "scid": "fb5e6f2f-9358-4936-bd55-e6ac62c2ab03",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01059",
+    "speed": 429496729600,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "xe-4/3/4"
+      }
+    ],
+    "imsid": 721147,
+    "monitored": true,
+    "name": "PARIS 007B-PARIS 007B-10GBE-004(GEANT)",
+    "scid": "fb84c1c2-2f52-4339-ae9e-6f59f303d44a",
+    "service_type": "ETHERNET",
+    "sid": "GA-02194",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/3/1"
+      }
+    ],
+    "imsid": 662848,
+    "monitored": true,
+    "name": "LONDON 2 (SLOUGH)-LONDON 2 (SLOUGH)-10GBE-078(GEANT)",
+    "scid": "fb90570a-c35c-40e7-bf39-d45377bd9a6d",
+    "service_type": "ETHERNET",
+    "sid": "GA-01653",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "MARNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.253/30",
+          "2001:798:2c:10aa::15/126"
+        ],
+        "hostname": "rt0.zag.hr.geant.net",
+        "interface": "lag-23.100"
+      }
+    ],
+    "imsid": 747954,
+    "monitored": true,
+    "name": "MARNET-AP2",
+    "scid": "fba33f59-fd72-4fad-8734-797026a568d0",
+    "service_type": "GEANT IP",
+    "sid": "GS-00490",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "RENATER"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae15.3151"
+      },
+      {
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae14.3151"
+      }
+    ],
+    "imsid": 705429,
+    "monitored": true,
+    "name": "AMS-GEN-GRID5000-RENATER-SINET-07201",
+    "scid": "fba9ffd7-382b-4ac3-9e3c-c44e59b18805",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00636",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "KIFU"
+    ],
+    "endpoints": [
+      {
+        "equipment": "PF1-RARE.BUD.HU.GEANT.NET",
+        "port": "XE-2"
+      },
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "xe-3/0/2.1955"
+      },
+      {
+        "hostname": "mx1.bud.hu.geant.net",
+        "interface": "ae10.1955"
+      }
+    ],
+    "imsid": 705914,
+    "monitored": false,
+    "name": "BUD-BUD-KIFU-RARE-200100",
+    "scid": "fbb8850e-c1b3-433a-b50f-85e92231a8cb",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00683",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.2031"
+      },
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-4/1/4.2031"
+      }
+    ],
+    "imsid": 738641,
+    "monitored": true,
+    "name": "LON-LON-GEANTOPEN-ESNET-NORDUNET-15039-3",
+    "scid": "fbe0e8a2-4c98-4fd3-b812-b16d82d5edc1",
+    "service_type": "GEANT OPEN CROSS CONNECT",
+    "sid": "GS-00965",
+    "speed": 536870912000,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [],
+    "imsid": 661351,
+    "monitored": true,
+    "name": "NORDUNET-BGP-LU-COC-AP1",
+    "scid": "fbe17888-ba10-47ce-919c-61d0b6db35af",
+    "service_type": "MD-VPN (NATIVE)",
+    "sid": "GS-01053",
+    "speed": 107374182400,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.98.74/31",
+          "2001:798:cc::75/126"
+        ],
+        "hostname": "mx1.par.fr.geant.net",
+        "interface": "ae3.0"
+      },
+      {
+        "addresses": [
+          "62.40.98.75/31",
+          "2001:798:cc::76/126"
+        ],
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-1.0"
+      }
+    ],
+    "imsid": 739437,
+    "monitored": true,
+    "name": "PAR-PAR-IPTRUNK",
+    "scid": "fbf3cb93-ffa0-4e71-8ac2-d5a16b1637a5",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02473",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.PAR.FR",
+        "port": "GI0/0"
+      }
+    ],
+    "imsid": 677775,
+    "monitored": false,
+    "name": "PAR OOB LINK",
+    "scid": "fc073c13-beda-4163-ae88-6ca6ce000679",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00411",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.mad.es.geant.net",
+        "interface": "ae20"
+      }
+    ],
+    "imsid": 738697,
+    "monitored": true,
+    "name": "ES-MICROSOFT-EXPRESSROUTE-LAG#2",
+    "scid": "fc0eb57c-f68e-4db2-9e65-1450e5ac6861",
+    "service_type": "ETHERNET",
+    "sid": "GA-02523",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GTS"
+    ],
+    "endpoints": [],
+    "imsid": 662270,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-10GBE-004(GEANT)",
+    "scid": "fc1122bf-8295-4d75-9947-ebc9a441e334",
+    "service_type": "ETHERNET",
+    "sid": "GA-01562",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "CSTNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "et-1/1/5.1008"
+      }
+    ],
+    "imsid": 734555,
+    "monitored": true,
+    "name": "NL-NETHERLIGHT-CSTNET-KAUST-1",
+    "scid": "fc51252b-8ae5-4926-83a4-adbf8886b079",
+    "service_type": "IP PEERING - R&E",
+    "sid": "GS-02392",
+    "speed": 214748364800,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mx1.fra.de - DE-DK Multicast Traffic",
+    "scid": "fc70cf3c-6f79-4178-87a3-f68672a7f3fd",
+    "service_type": null,
+    "sid": "DS-04996",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.34"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "ae28.4069"
+      }
+    ],
+    "imsid": 739661,
+    "monitored": true,
+    "name": "BELNET-RIZIV-INAMI-EXPRESSROUTE-VLAN4069",
+    "scid": "fc785c6a-395a-4474-800f-ee4436d29406",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02521",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 708746,
+    "monitored": false,
+    "name": "SOF-VIE-IPTRUNK",
+    "scid": "fc7acd40-7b25-4ad0-9eb7-ac33495f228f",
+    "service_type": "IP TRUNK",
+    "sid": "GS-00063",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT-IT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/0/1"
+      },
+      {
+        "hostname": "mx1.lon2.uk.geant.net",
+        "interface": "xe-2/0/1.0"
+      },
+      {
+        "hostname": "qfx.fra.de.geant.net",
+        "interface": "xe-0/0/43"
+      },
+      {
+        "hostname": "rt1.fra.de.geant.net",
+        "interface": "xe-7/0/0.0"
+      }
+    ],
+    "imsid": 729416,
+    "monitored": true,
+    "name": "FRA-LON2-SUPERPOP-QFX-GEANT",
+    "scid": "fcad7d0f-ff49-4edb-a851-e2073420df99",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00076|GS00076",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDCLARA"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx2.lis.pt.geant.net",
+        "interface": "ae11"
+      }
+    ],
+    "imsid": 713834,
+    "monitored": true,
+    "name": "PT-REDCLARA-LAG",
+    "scid": "fcb0f98c-efec-48e7-9239-a2197356b4a1",
+    "service_type": "ETHERNET",
+    "sid": "GA-02075",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/0/6"
+      }
+    ],
+    "imsid": 658958,
+    "monitored": true,
+    "name": "LONDON-LONDON-10GBE-019(ETH)",
+    "scid": "fccd843e-0eb5-4282-aebb-7db32f4392be",
+    "service_type": "ETHERNET",
+    "sid": "GA-01451",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "EUMETSAT"
+    ],
+    "endpoints": [],
+    "imsid": 732671,
+    "monitored": false,
+    "name": "GRE-MULTICAST-TUNNEL-IAMS",
+    "scid": "fcde32c1-4ba0-406f-b38c-8417c6ee2a4b",
+    "service_type": "EUMETSAT GRE",
+    "sid": "GS-01078",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "BELNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.bru.be.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 744127,
+    "monitored": true,
+    "name": "BELNET-AP1-LAG",
+    "scid": "fd008ee8-98b3-452e-867d-843e2bc7c987",
+    "service_type": "ETHERNET",
+    "sid": "GA-01913",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 707586,
+    "monitored": false,
+    "name": "EX3400-MANAGEMENT-MIL2-IT",
+    "scid": "fd100cc6-9201-4989-b856-d7c72802c473",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00156",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "192.65.185.119/24",
+          "2001:7f8:1c:24a::51e5:1/64"
+        ],
+        "hostname": "mx1.gen.ch.geant.net",
+        "interface": "ae18.2001"
+      }
+    ],
+    "imsid": 663212,
+    "monitored": true,
+    "name": "IX-PEERINGS-IN-CIXP",
+    "scid": "fd261bd8-bb9c-40b8-85e1-e8678821917e",
+    "service_type": "IP PEERING - NON R&E (PUBLIC)",
+    "sid": "GS-00946",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 662268,
+    "monitored": true,
+    "name": "HAMBURG-HAMBURG-10GBE-003(GEANT)",
+    "scid": "fd2ad335-8f33-4783-8ca1-416b79a6a76a",
+    "service_type": "ETHERNET",
+    "sid": "GA-01560",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "RENAM"
+    ],
+    "endpoints": [],
+    "imsid": 662955,
+    "monitored": false,
+    "name": "RENAM-AP3-IAS",
+    "scid": "fdd0c385-543b-4a26-b839-c9d9c8c82860",
+    "service_type": "GWS - INDIRECT",
+    "sid": "GS-00543",
+    "speed": 42949672960,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "TS1.ZAG.HR.GEANT.NET(OPENGEAR)",
+        "port": "NET1"
+      }
+    ],
+    "imsid": 677809,
+    "monitored": false,
+    "name": "ZAG OOB LINK",
+    "scid": "fdf5582f-ea82-4b48-9fb5-f819c0027a19",
+    "service_type": "OOB IP LINK",
+    "sid": "GS-00420",
+    "speed": 1073741824,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.mar.fr.geant.net",
+        "interface": "ae5"
+      }
+    ],
+    "imsid": 742605,
+    "monitored": true,
+    "name": "MAR-MAR-MGMT-LAG",
+    "scid": "fe064cbb-2076-46d2-a7fa-d0a333af6d99",
+    "service_type": "ETHERNET",
+    "sid": "GA-02588",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "HEANET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.cor.ie.geant.net",
+        "interface": "lag-20"
+      }
+    ],
+    "imsid": 747405,
+    "monitored": true,
+    "name": "HEANET-AP2-LAG",
+    "scid": "fe0abcb1-3bcf-4d4d-9ef5-ecff0d4a9c05",
+    "service_type": "ETHERNET",
+    "sid": "GA-01889",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.952"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "pwe-324046"
+      },
+      {
+        "hostname": "rt0.ath2.gr.geant.net",
+        "interface": "lag-20:714"
+      }
+    ],
+    "imsid": 745434,
+    "monitored": false,
+    "name": "SLCUTH-02499",
+    "scid": "fe65d966-d66e-4072-b3d0-ca80df00255a",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-02499",
+    "speed": 0,
+    "status": "installed"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "mar-par_I2CAT_RedIRIS-RedCLARA_12201",
+    "scid": "fe6bb3d8-2ee4-4ff6-a7c6-1eb8f16dc34f",
+    "service_type": null,
+    "sid": "DS-28728",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 739971,
+    "monitored": true,
+    "name": "HAM-HAM-IPTRUNK",
+    "scid": "fe78633e-4e41-4901-9bd4-5d01ad1605ee",
+    "service_type": "IP TRUNK",
+    "sid": "GS-02542",
+    "speed": 322122547200,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.par.fr.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 739435,
+    "monitored": true,
+    "name": "PAR-PAR-800G-LAG",
+    "scid": "fe9c7dfc-1ca4-4331-a87c-b56bf15ba48a",
+    "service_type": "ETHERNET",
+    "sid": "GA-02472",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "BASNET"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.81/30",
+          "2001:0798:23:10aa::d/126"
+        ],
+        "hostname": "mx1.poz.pl.geant.net",
+        "interface": "xe-1/0/0.100"
+      }
+    ],
+    "imsid": 661600,
+    "monitored": true,
+    "name": "BASNET-AP1",
+    "scid": "fec1613c-bb68-47b5-8e44-740ebeeadc45",
+    "service_type": "GEANT IP",
+    "sid": "GS-00434",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 663137,
+    "monitored": false,
+    "name": "PS-AMS-NL-MANAGEMENT-VLAN24",
+    "scid": "fed811dd-54fe-4084-9332-a032a604bf1e",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00288",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.chi.md.geant.net",
+        "interface": "ae3"
+      }
+    ],
+    "imsid": 713094,
+    "monitored": true,
+    "name": "CHI-KIE-LAG",
+    "scid": "fede0008-fb31-44e9-9121-180924c67589",
+    "service_type": "ETHERNET",
+    "sid": "GA-02040",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "ULAKBIM"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.126.50/31",
+          "2001:798:111:1::e5/126"
+        ],
+        "hostname": "rt0.the.gr.geant.net",
+        "interface": "lag-21.111"
+      }
+    ],
+    "imsid": 745294,
+    "monitored": true,
+    "name": "ULAKBIM-AP1-LHCONE",
+    "scid": "fefa7cc7-f886-4721-a2aa-18500bffb51a",
+    "service_type": "L3-VPN",
+    "sid": "GS-00868",
+    "speed": 0,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT_INTERNAL"
+    ],
+    "endpoints": [],
+    "imsid": 679232,
+    "monitored": true,
+    "name": "GEANT CORPORATE TO MX1.LON - VIA VODAFONE",
+    "scid": "fefb1ae2-554f-4147-84dc-c07d73082b5e",
+    "service_type": "ETHERNET",
+    "sid": "GA-01469",
+    "speed": 1073741824,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "JISC"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "xe-3/2/7.3004"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae15.3004"
+      }
+    ],
+    "imsid": 734615,
+    "monitored": true,
+    "name": "AMS-LON-EXPRES-NETHERLIGHT-JISC-18009",
+    "scid": "fefcc04b-862e-4552-9024-2aa6a13d4925",
+    "service_type": "GEANT PLUS",
+    "sid": "GS-00644",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.lon.uk.geant.net",
+        "interface": "lag-1"
+      }
+    ],
+    "imsid": 738584,
+    "monitored": true,
+    "name": "LON-LON-800G-LAG",
+    "scid": "ff161312-c6a3-462d-a201-b242cdca6b18",
+    "service_type": "ETHERNET",
+    "sid": "GA-02466",
+    "speed": 858993459200,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "equipment": "SW1.KIE.UA",
+        "port": "AE3"
+      }
+    ],
+    "imsid": 713307,
+    "monitored": true,
+    "name": "LAG-RT2.KIE.UA_AE2-SW1.KIE.UA_AE3",
+    "scid": "ff46c8cd-a2f9-48f7-9c70-226dd68e0768",
+    "service_type": "ETHERNET",
+    "sid": "GA-02058",
+    "speed": 10737418240,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "REDIRIS"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt2.ams.nl.geant.net",
+        "interface": "ae10.42"
+      },
+      {
+        "hostname": "rt1.bil.es.geant.net",
+        "interface": "ae15.692"
+      }
+    ],
+    "imsid": 740768,
+    "monitored": true,
+    "name": "REDIRIS-ICN2-EXPRESSROUTE-VLAN692",
+    "scid": "ff4d0787-984f-4e1a-ae63-9a2cac28adb3",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02560",
+    "speed": 440234147840,
+    "status": "operational"
+  },
+  {
+    "customers": [],
+    "endpoints": [],
+    "imsid": -1,
+    "monitored": false,
+    "name": "ams-gen_HPDMnet_NetherLight-RedIRIS",
+    "scid": "ff74d5d8-3068-48fd-8f19-cf8aa7a2eb99",
+    "service_type": null,
+    "sid": "DS-28660",
+    "speed": 0,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [],
+    "imsid": 661751,
+    "monitored": false,
+    "name": "XANTARO-SERVICE-ENGINE-ETH0-INTERNAL-LON2-VLAN944",
+    "scid": "ff83dc26-9bfd-4ac7-a780-b8d7c13a982a",
+    "service_type": "SERVER LINK",
+    "sid": "GS-00386",
+    "speed": 10737418240,
+    "status": "OutofService"
+  },
+  {
+    "customers": [
+      "NORDUNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "mx1.lon.uk.geant.net",
+        "interface": "et-5/0/5.3917"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "ae21.35"
+      }
+    ],
+    "imsid": 727782,
+    "monitored": true,
+    "name": "NORDUNET-FUNET-EXPRESSROUTE-VLAN3917",
+    "scid": "ff9cd230-7657-4885-bf23-174e0e8bb4d7",
+    "service_type": "EXPRESS ROUTE",
+    "sid": "GS-02327",
+    "speed": 118111600640,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GEANT"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt0.por.pt.geant.net",
+        "interface": "lag-4"
+      }
+    ],
+    "imsid": 742838,
+    "monitored": true,
+    "name": "POR-POR-MGMT-LAG",
+    "scid": "ffc82d25-4f04-4434-86b8-6bd9f73adafa",
+    "service_type": "ETHERNET",
+    "sid": "GA-02586",
+    "speed": 107374182400,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "CESNET"
+    ],
+    "endpoints": [
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/0"
+      },
+      {
+        "hostname": "rt1.pra.cz.geant.net",
+        "interface": "xe-3/0/0.0"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/1/0"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/1/0"
+      },
+      {
+        "hostname": "rt1.ams.nl.geant.net",
+        "interface": "xe-0/1/0.0"
+      }
+    ],
+    "imsid": 720237,
+    "monitored": true,
+    "name": "AMS-PRA-IX-CESNET-AMS-12016",
+    "scid": "ffeaacca-e6dc-448c-8fdb-056a4a49085e",
+    "service_type": "GEANT - GBS",
+    "sid": "GS-00786",
+    "speed": 21474836480,
+    "status": "operational"
+  },
+  {
+    "customers": [
+      "GRENA"
+    ],
+    "endpoints": [
+      {
+        "addresses": [
+          "62.40.125.73/30"
+        ],
+        "hostname": "mx1.fra.de.geant.net",
+        "interface": "ae23.200"
+      }
+    ],
+    "imsid": 663227,
+    "monitored": false,
+    "name": "GRENA-AP2",
+    "scid": "fff813ff-0c28-420e-abc6-74e8a44d13c8",
+    "service_type": "GEANT IP",
+    "sid": "GS-00470",
+    "speed": 10737418240,
+    "status": "OutofService"
+  }
+]
diff --git a/test/test_correlator.py b/test/test_correlator.py
new file mode 100644
index 0000000000000000000000000000000000000000..6020af147b0ed665afdcfcdbc9f80302581b0e90
--- /dev/null
+++ b/test/test_correlator.py
@@ -0,0 +1,16 @@
+import tempfile
+
+from mapping_provider.backends import cache, correlator
+
+
+def test_handle_correlator_state_broadcast():
+    """
+    tmp bogus test - just to have something
+    """
+    with tempfile.TemporaryDirectory() as tmp_dir:
+        cache.init(tmp_dir)
+        correlator.handle_correlator_state_broadcast(
+            message={'alarms': [], 'endpoints': []})
+        
+        cached_data = cache.get(correlator.CACHED_CORRELATOR_STATE_FILENAME)
+        assert cached_data == {'alarms': [], 'endpoints': []}
diff --git a/test/test_inventory.py b/test/test_inventory.py
new file mode 100644
index 0000000000000000000000000000000000000000..a68a72bce95127da9f8bfb071e7d14af19bd1ad1
--- /dev/null
+++ b/test/test_inventory.py
@@ -0,0 +1,51 @@
+import tempfile
+
+import responses
+
+from mapping_provider.backends import cache, inventory
+
+from .common import load_test_data
+
+
+@responses.activate
+def test_inventory_service_download():
+    """
+    tmp bogus test - just to have something
+    """
+
+    inventory_base_uri = 'https://dummy-hostname.dummy.domain'
+    reporting_base_uri = 'https://another-dummy-hostname.dummy.domain'
+
+    responses.add(
+        method=responses.GET,
+        url=f'{inventory_base_uri}/poller/interfaces',
+        json=load_test_data('poller-interfaces.json')
+    )
+    responses.add(
+        method=responses.GET,
+        url=f'{reporting_base_uri}/scid/current',
+        json=load_test_data('scid-current.json')
+    )
+    responses.add(
+        method=responses.GET,
+        url=f'{inventory_base_uri}/map/services',
+        json=load_test_data('inprov-services.json')
+    )
+    
+    with tempfile.TemporaryDirectory() as tmp_dir:
+
+        cache.init(tmp_dir)
+        inventory._load_all_inventory(
+            inventory_base_uri='https://dummy-hostname.dummy.domain',
+            reporting_base_uri='https://another-dummy-hostname.dummy.domain')
+
+        # assert os.path.exists(os.path.join(tmp_dir, services.POLLER_INTERFACES_CACHE_FILENAME))
+
+        cached_data = cache.get(inventory.INPROV_POLLER_INTERFACES_CACHE_FILENAME)
+        assert cached_data == load_test_data('poller-interfaces.json')
+
+        cached_data = cache.get(inventory.INPROV_MAP_SERVICES_CACHE_FILENAME)
+        assert cached_data == load_test_data('inprov-services.json')
+
+        cached_data = cache.get(inventory.REPORTING_SCID_CURRENT_CACHE_FILENAME)
+        assert cached_data == load_test_data('scid-current.json')
diff --git a/test/test_map_endpoints.py b/test/test_map_endpoints.py
index e1befeb97c6ff7a82b27d3a2bff296877c0d9384..9c88c68f14e17e6efd9851703cbe796f7b2d92d5 100644
--- a/test/test_map_endpoints.py
+++ b/test/test_map_endpoints.py
@@ -1,35 +1,20 @@
-import json
-import os
 import re
 
 import responses
 
-from mapping_provider.api.map import RouterList, ServiceList, SiteList
+from mapping_provider.api.map import RouterList, SiteList
+from mapping_provider.backends.services import ServiceList
 
-DATA_DIR = os.path.join(os.path.dirname(__file__), 'data')
+from .common import load_test_data
 
 
-def _load_test_data(filename: str) -> dict:
-    with open(os.path.join(DATA_DIR, filename)) as f:
-        return json.load(f)
-
-# @responses.activate
-# def test_inventory_uri_validation():
-#     responses.add(
-#         method=responses.GET, url=re.compile(r".*/version$"), json={"api": "0.9"}
-#     )
-#     assert (
-#         classifier.verify_inventory_provider_uri(None, None, "http://a.b.c:9999")
-#         == "http://a.b.c:9999/"
-#     )
-
 @responses.activate
 def test_get_sites(client):
 
     responses.add(
         method=responses.GET,
         url=re.compile(r'.*/map/sites$'),
-        json=_load_test_data('inprov-sites.json')
+        json=load_test_data('inprov-sites.json')
     )
 
     rv = client.get("/map/sites")
@@ -44,7 +29,7 @@ def test_get_routers(client):
     responses.add(
         method=responses.GET,
         url=re.compile(r'.*/map/routers$'),
-        json=_load_test_data('inprov-routers.json')
+        json=load_test_data('inprov-routers.json')
     )
 
     rv = client.get("/map/routers")
@@ -58,7 +43,7 @@ def test_get_trunks(client):
     responses.add(
         method=responses.GET,
         url=re.compile(r'.*/map/services.*'),
-        json=_load_test_data('inprov-services.json')
+        json=load_test_data('inprov-services.json')
     )
 
     rv = client.get("/map/trunks")
diff --git a/tox.ini b/tox.ini
index 936301481e2e1807b4a787019b0f54221957b3f1..30275125dba18abd5b818c5680384d98d422bd83 100644
--- a/tox.ini
+++ b/tox.ini
@@ -1,5 +1,5 @@
 [tox]
-envlist = lint, typecheck, docs
+envlist = coverage, lint, typecheck, docs
 
 [testenv:coverage]
 description = Run unit tests and save coverage
@@ -23,6 +23,7 @@ deps =
     mypy
     types-jsonschema
     types-requests
+    types-pika
 commands = mypy mapping_provider
 
 [testenv:sbom]