You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@nifi.apache.org by sc...@apache.org on 2022/02/01 14:21:51 UTC

[nifi-fds] branch gh-pages updated: remove old bundles

This is an automated email from the ASF dual-hosted git repository.

scottyaslan pushed a commit to branch gh-pages
in repository https://gitbox.apache.org/repos/asf/nifi-fds.git


The following commit(s) were added to refs/heads/gh-pages by this push:
     new d71480f  remove old bundles
d71480f is described below

commit d71480fbc3b711490eb81e4e02ae4a190ceef014
Author: Scott Aslan <sc...@gmail.com>
AuthorDate: Tue Feb 1 09:20:45 2022 -0500

    remove old bundles
---
 fds-demo.bundle.min.js     |   4044 -
 fds-demo.bundle.min.js.gz  |    Bin 131925 -> 0 bytes
 fds-demo.styles.min.css    |  24852 ------
 fds-demo.styles.min.css.gz |    Bin 151787 -> 0 bytes
 fds-demo.vendor.min.js     | 194055 ------------------------------------------
 fds-demo.vendor.min.js.gz  |    Bin 4211698 -> 0 bytes
 6 files changed, 222951 deletions(-)

diff --git a/fds-demo.bundle.min.js b/fds-demo.bundle.min.js
deleted file mode 100644
index afd3173..0000000
--- a/fds-demo.bundle.min.js
+++ /dev/null
@@ -1,4044 +0,0 @@
-/******/ (function(modules) { // webpackBootstrap
-/******/ 	// install a JSONP callback for chunk loading
-/******/ 	function webpackJsonpCallback(data) {
-/******/ 		var chunkIds = data[0];
-/******/ 		var moreModules = data[1];
-/******/ 		var executeModules = data[2];
-/******/
-/******/ 		// add "moreModules" to the modules object,
-/******/ 		// then flag all "chunkIds" as loaded and fire callback
-/******/ 		var moduleId, chunkId, i = 0, resolves = [];
-/******/ 		for(;i < chunkIds.length; i++) {
-/******/ 			chunkId = chunkIds[i];
-/******/ 			if(Object.prototype.hasOwnProperty.call(installedChunks, chunkId) && installedChunks[chunkId]) {
-/******/ 				resolves.push(installedChunks[chunkId][0]);
-/******/ 			}
-/******/ 			installedChunks[chunkId] = 0;
-/******/ 		}
-/******/ 		for(moduleId in moreModules) {
-/******/ 			if(Object.prototype.hasOwnProperty.call(moreModules, moduleId)) {
-/******/ 				modules[moduleId] = moreModules[moduleId];
-/******/ 			}
-/******/ 		}
-/******/ 		if(parentJsonpFunction) parentJsonpFunction(data);
-/******/
-/******/ 		while(resolves.length) {
-/******/ 			resolves.shift()();
-/******/ 		}
-/******/
-/******/ 		// add entry modules from loaded chunk to deferred list
-/******/ 		deferredModules.push.apply(deferredModules, executeModules || []);
-/******/
-/******/ 		// run deferred modules when all chunks ready
-/******/ 		return checkDeferredModules();
-/******/ 	};
-/******/ 	function checkDeferredModules() {
-/******/ 		var result;
-/******/ 		for(var i = 0; i < deferredModules.length; i++) {
-/******/ 			var deferredModule = deferredModules[i];
-/******/ 			var fulfilled = true;
-/******/ 			for(var j = 1; j < deferredModule.length; j++) {
-/******/ 				var depId = deferredModule[j];
-/******/ 				if(installedChunks[depId] !== 0) fulfilled = false;
-/******/ 			}
-/******/ 			if(fulfilled) {
-/******/ 				deferredModules.splice(i--, 1);
-/******/ 				result = __webpack_require__(__webpack_require__.s = deferredModule[0]);
-/******/ 			}
-/******/ 		}
-/******/
-/******/ 		return result;
-/******/ 	}
-/******/ 	function hotDisposeChunk(chunkId) {
-/******/ 		delete installedChunks[chunkId];
-/******/ 	}
-/******/ 	var parentHotUpdateCallback = window["webpackHotUpdate"];
-/******/ 	window["webpackHotUpdate"] = // eslint-disable-next-line no-unused-vars
-/******/ 	function webpackHotUpdateCallback(chunkId, moreModules) {
-/******/ 		hotAddUpdateChunk(chunkId, moreModules);
-/******/ 		if (parentHotUpdateCallback) parentHotUpdateCallback(chunkId, moreModules);
-/******/ 	} ;
-/******/
-/******/ 	// eslint-disable-next-line no-unused-vars
-/******/ 	function hotDownloadUpdateChunk(chunkId) {
-/******/ 		var script = document.createElement("script");
-/******/ 		script.charset = "utf-8";
-/******/ 		script.src = __webpack_require__.p + "" + chunkId + "." + hotCurrentHash + ".hot-update.js";
-/******/ 		if (null) script.crossOrigin = null;
-/******/ 		document.head.appendChild(script);
-/******/ 	}
-/******/
-/******/ 	// eslint-disable-next-line no-unused-vars
-/******/ 	function hotDownloadManifest(requestTimeout) {
-/******/ 		requestTimeout = requestTimeout || 10000;
-/******/ 		return new Promise(function(resolve, reject) {
-/******/ 			if (typeof XMLHttpRequest === "undefined") {
-/******/ 				return reject(new Error("No browser support"));
-/******/ 			}
-/******/ 			try {
-/******/ 				var request = new XMLHttpRequest();
-/******/ 				var requestPath = __webpack_require__.p + "" + hotCurrentHash + ".hot-update.json";
-/******/ 				request.open("GET", requestPath, true);
-/******/ 				request.timeout = requestTimeout;
-/******/ 				request.send(null);
-/******/ 			} catch (err) {
-/******/ 				return reject(err);
-/******/ 			}
-/******/ 			request.onreadystatechange = function() {
-/******/ 				if (request.readyState !== 4) return;
-/******/ 				if (request.status === 0) {
-/******/ 					// timeout
-/******/ 					reject(
-/******/ 						new Error("Manifest request to " + requestPath + " timed out.")
-/******/ 					);
-/******/ 				} else if (request.status === 404) {
-/******/ 					// no update available
-/******/ 					resolve();
-/******/ 				} else if (request.status !== 200 && request.status !== 304) {
-/******/ 					// other failure
-/******/ 					reject(new Error("Manifest request to " + requestPath + " failed."));
-/******/ 				} else {
-/******/ 					// success
-/******/ 					try {
-/******/ 						var update = JSON.parse(request.responseText);
-/******/ 					} catch (e) {
-/******/ 						reject(e);
-/******/ 						return;
-/******/ 					}
-/******/ 					resolve(update);
-/******/ 				}
-/******/ 			};
-/******/ 		});
-/******/ 	}
-/******/
-/******/ 	var hotApplyOnUpdate = true;
-/******/ 	// eslint-disable-next-line no-unused-vars
-/******/ 	var hotCurrentHash = "4ee9c6981ad183c43466";
-/******/ 	var hotRequestTimeout = 10000;
-/******/ 	var hotCurrentModuleData = {};
-/******/ 	var hotCurrentChildModule;
-/******/ 	// eslint-disable-next-line no-unused-vars
-/******/ 	var hotCurrentParents = [];
-/******/ 	// eslint-disable-next-line no-unused-vars
-/******/ 	var hotCurrentParentsTemp = [];
-/******/
-/******/ 	// eslint-disable-next-line no-unused-vars
-/******/ 	function hotCreateRequire(moduleId) {
-/******/ 		var me = installedModules[moduleId];
-/******/ 		if (!me) return __webpack_require__;
-/******/ 		var fn = function(request) {
-/******/ 			if (me.hot.active) {
-/******/ 				if (installedModules[request]) {
-/******/ 					if (installedModules[request].parents.indexOf(moduleId) === -1) {
-/******/ 						installedModules[request].parents.push(moduleId);
-/******/ 					}
-/******/ 				} else {
-/******/ 					hotCurrentParents = [moduleId];
-/******/ 					hotCurrentChildModule = request;
-/******/ 				}
-/******/ 				if (me.children.indexOf(request) === -1) {
-/******/ 					me.children.push(request);
-/******/ 				}
-/******/ 			} else {
-/******/ 				console.warn(
-/******/ 					"[HMR] unexpected require(" +
-/******/ 						request +
-/******/ 						") from disposed module " +
-/******/ 						moduleId
-/******/ 				);
-/******/ 				hotCurrentParents = [];
-/******/ 			}
-/******/ 			return __webpack_require__(request);
-/******/ 		};
-/******/ 		var ObjectFactory = function ObjectFactory(name) {
-/******/ 			return {
-/******/ 				configurable: true,
-/******/ 				enumerable: true,
-/******/ 				get: function() {
-/******/ 					return __webpack_require__[name];
-/******/ 				},
-/******/ 				set: function(value) {
-/******/ 					__webpack_require__[name] = value;
-/******/ 				}
-/******/ 			};
-/******/ 		};
-/******/ 		for (var name in __webpack_require__) {
-/******/ 			if (
-/******/ 				Object.prototype.hasOwnProperty.call(__webpack_require__, name) &&
-/******/ 				name !== "e" &&
-/******/ 				name !== "t"
-/******/ 			) {
-/******/ 				Object.defineProperty(fn, name, ObjectFactory(name));
-/******/ 			}
-/******/ 		}
-/******/ 		fn.e = function(chunkId) {
-/******/ 			if (hotStatus === "ready") hotSetStatus("prepare");
-/******/ 			hotChunksLoading++;
-/******/ 			return __webpack_require__.e(chunkId).then(finishChunkLoading, function(err) {
-/******/ 				finishChunkLoading();
-/******/ 				throw err;
-/******/ 			});
-/******/
-/******/ 			function finishChunkLoading() {
-/******/ 				hotChunksLoading--;
-/******/ 				if (hotStatus === "prepare") {
-/******/ 					if (!hotWaitingFilesMap[chunkId]) {
-/******/ 						hotEnsureUpdateChunk(chunkId);
-/******/ 					}
-/******/ 					if (hotChunksLoading === 0 && hotWaitingFiles === 0) {
-/******/ 						hotUpdateDownloaded();
-/******/ 					}
-/******/ 				}
-/******/ 			}
-/******/ 		};
-/******/ 		fn.t = function(value, mode) {
-/******/ 			if (mode & 1) value = fn(value);
-/******/ 			return __webpack_require__.t(value, mode & ~1);
-/******/ 		};
-/******/ 		return fn;
-/******/ 	}
-/******/
-/******/ 	// eslint-disable-next-line no-unused-vars
-/******/ 	function hotCreateModule(moduleId) {
-/******/ 		var hot = {
-/******/ 			// private stuff
-/******/ 			_acceptedDependencies: {},
-/******/ 			_declinedDependencies: {},
-/******/ 			_selfAccepted: false,
-/******/ 			_selfDeclined: false,
-/******/ 			_selfInvalidated: false,
-/******/ 			_disposeHandlers: [],
-/******/ 			_main: hotCurrentChildModule !== moduleId,
-/******/
-/******/ 			// Module API
-/******/ 			active: true,
-/******/ 			accept: function(dep, callback) {
-/******/ 				if (dep === undefined) hot._selfAccepted = true;
-/******/ 				else if (typeof dep === "function") hot._selfAccepted = dep;
-/******/ 				else if (typeof dep === "object")
-/******/ 					for (var i = 0; i < dep.length; i++)
-/******/ 						hot._acceptedDependencies[dep[i]] = callback || function() {};
-/******/ 				else hot._acceptedDependencies[dep] = callback || function() {};
-/******/ 			},
-/******/ 			decline: function(dep) {
-/******/ 				if (dep === undefined) hot._selfDeclined = true;
-/******/ 				else if (typeof dep === "object")
-/******/ 					for (var i = 0; i < dep.length; i++)
-/******/ 						hot._declinedDependencies[dep[i]] = true;
-/******/ 				else hot._declinedDependencies[dep] = true;
-/******/ 			},
-/******/ 			dispose: function(callback) {
-/******/ 				hot._disposeHandlers.push(callback);
-/******/ 			},
-/******/ 			addDisposeHandler: function(callback) {
-/******/ 				hot._disposeHandlers.push(callback);
-/******/ 			},
-/******/ 			removeDisposeHandler: function(callback) {
-/******/ 				var idx = hot._disposeHandlers.indexOf(callback);
-/******/ 				if (idx >= 0) hot._disposeHandlers.splice(idx, 1);
-/******/ 			},
-/******/ 			invalidate: function() {
-/******/ 				this._selfInvalidated = true;
-/******/ 				switch (hotStatus) {
-/******/ 					case "idle":
-/******/ 						hotUpdate = {};
-/******/ 						hotUpdate[moduleId] = modules[moduleId];
-/******/ 						hotSetStatus("ready");
-/******/ 						break;
-/******/ 					case "ready":
-/******/ 						hotApplyInvalidatedModule(moduleId);
-/******/ 						break;
-/******/ 					case "prepare":
-/******/ 					case "check":
-/******/ 					case "dispose":
-/******/ 					case "apply":
-/******/ 						(hotQueuedInvalidatedModules =
-/******/ 							hotQueuedInvalidatedModules || []).push(moduleId);
-/******/ 						break;
-/******/ 					default:
-/******/ 						// ignore requests in error states
-/******/ 						break;
-/******/ 				}
-/******/ 			},
-/******/
-/******/ 			// Management API
-/******/ 			check: hotCheck,
-/******/ 			apply: hotApply,
-/******/ 			status: function(l) {
-/******/ 				if (!l) return hotStatus;
-/******/ 				hotStatusHandlers.push(l);
-/******/ 			},
-/******/ 			addStatusHandler: function(l) {
-/******/ 				hotStatusHandlers.push(l);
-/******/ 			},
-/******/ 			removeStatusHandler: function(l) {
-/******/ 				var idx = hotStatusHandlers.indexOf(l);
-/******/ 				if (idx >= 0) hotStatusHandlers.splice(idx, 1);
-/******/ 			},
-/******/
-/******/ 			//inherit from previous dispose call
-/******/ 			data: hotCurrentModuleData[moduleId]
-/******/ 		};
-/******/ 		hotCurrentChildModule = undefined;
-/******/ 		return hot;
-/******/ 	}
-/******/
-/******/ 	var hotStatusHandlers = [];
-/******/ 	var hotStatus = "idle";
-/******/
-/******/ 	function hotSetStatus(newStatus) {
-/******/ 		hotStatus = newStatus;
-/******/ 		for (var i = 0; i < hotStatusHandlers.length; i++)
-/******/ 			hotStatusHandlers[i].call(null, newStatus);
-/******/ 	}
-/******/
-/******/ 	// while downloading
-/******/ 	var hotWaitingFiles = 0;
-/******/ 	var hotChunksLoading = 0;
-/******/ 	var hotWaitingFilesMap = {};
-/******/ 	var hotRequestedFilesMap = {};
-/******/ 	var hotAvailableFilesMap = {};
-/******/ 	var hotDeferred;
-/******/
-/******/ 	// The update info
-/******/ 	var hotUpdate, hotUpdateNewHash, hotQueuedInvalidatedModules;
-/******/
-/******/ 	function toModuleId(id) {
-/******/ 		var isNumber = +id + "" === id;
-/******/ 		return isNumber ? +id : id;
-/******/ 	}
-/******/
-/******/ 	function hotCheck(apply) {
-/******/ 		if (hotStatus !== "idle") {
-/******/ 			throw new Error("check() is only allowed in idle status");
-/******/ 		}
-/******/ 		hotApplyOnUpdate = apply;
-/******/ 		hotSetStatus("check");
-/******/ 		return hotDownloadManifest(hotRequestTimeout).then(function(update) {
-/******/ 			if (!update) {
-/******/ 				hotSetStatus(hotApplyInvalidatedModules() ? "ready" : "idle");
-/******/ 				return null;
-/******/ 			}
-/******/ 			hotRequestedFilesMap = {};
-/******/ 			hotWaitingFilesMap = {};
-/******/ 			hotAvailableFilesMap = update.c;
-/******/ 			hotUpdateNewHash = update.h;
-/******/
-/******/ 			hotSetStatus("prepare");
-/******/ 			var promise = new Promise(function(resolve, reject) {
-/******/ 				hotDeferred = {
-/******/ 					resolve: resolve,
-/******/ 					reject: reject
-/******/ 				};
-/******/ 			});
-/******/ 			hotUpdate = {};
-/******/ 			for(var chunkId in installedChunks)
-/******/ 			// eslint-disable-next-line no-lone-blocks
-/******/ 			{
-/******/ 				hotEnsureUpdateChunk(chunkId);
-/******/ 			}
-/******/ 			if (
-/******/ 				hotStatus === "prepare" &&
-/******/ 				hotChunksLoading === 0 &&
-/******/ 				hotWaitingFiles === 0
-/******/ 			) {
-/******/ 				hotUpdateDownloaded();
-/******/ 			}
-/******/ 			return promise;
-/******/ 		});
-/******/ 	}
-/******/
-/******/ 	// eslint-disable-next-line no-unused-vars
-/******/ 	function hotAddUpdateChunk(chunkId, moreModules) {
-/******/ 		if (!hotAvailableFilesMap[chunkId] || !hotRequestedFilesMap[chunkId])
-/******/ 			return;
-/******/ 		hotRequestedFilesMap[chunkId] = false;
-/******/ 		for (var moduleId in moreModules) {
-/******/ 			if (Object.prototype.hasOwnProperty.call(moreModules, moduleId)) {
-/******/ 				hotUpdate[moduleId] = moreModules[moduleId];
-/******/ 			}
-/******/ 		}
-/******/ 		if (--hotWaitingFiles === 0 && hotChunksLoading === 0) {
-/******/ 			hotUpdateDownloaded();
-/******/ 		}
-/******/ 	}
-/******/
-/******/ 	function hotEnsureUpdateChunk(chunkId) {
-/******/ 		if (!hotAvailableFilesMap[chunkId]) {
-/******/ 			hotWaitingFilesMap[chunkId] = true;
-/******/ 		} else {
-/******/ 			hotRequestedFilesMap[chunkId] = true;
-/******/ 			hotWaitingFiles++;
-/******/ 			hotDownloadUpdateChunk(chunkId);
-/******/ 		}
-/******/ 	}
-/******/
-/******/ 	function hotUpdateDownloaded() {
-/******/ 		hotSetStatus("ready");
-/******/ 		var deferred = hotDeferred;
-/******/ 		hotDeferred = null;
-/******/ 		if (!deferred) return;
-/******/ 		if (hotApplyOnUpdate) {
-/******/ 			// Wrap deferred object in Promise to mark it as a well-handled Promise to
-/******/ 			// avoid triggering uncaught exception warning in Chrome.
-/******/ 			// See https://bugs.chromium.org/p/chromium/issues/detail?id=465666
-/******/ 			Promise.resolve()
-/******/ 				.then(function() {
-/******/ 					return hotApply(hotApplyOnUpdate);
-/******/ 				})
-/******/ 				.then(
-/******/ 					function(result) {
-/******/ 						deferred.resolve(result);
-/******/ 					},
-/******/ 					function(err) {
-/******/ 						deferred.reject(err);
-/******/ 					}
-/******/ 				);
-/******/ 		} else {
-/******/ 			var outdatedModules = [];
-/******/ 			for (var id in hotUpdate) {
-/******/ 				if (Object.prototype.hasOwnProperty.call(hotUpdate, id)) {
-/******/ 					outdatedModules.push(toModuleId(id));
-/******/ 				}
-/******/ 			}
-/******/ 			deferred.resolve(outdatedModules);
-/******/ 		}
-/******/ 	}
-/******/
-/******/ 	function hotApply(options) {
-/******/ 		if (hotStatus !== "ready")
-/******/ 			throw new Error("apply() is only allowed in ready status");
-/******/ 		options = options || {};
-/******/ 		return hotApplyInternal(options);
-/******/ 	}
-/******/
-/******/ 	function hotApplyInternal(options) {
-/******/ 		hotApplyInvalidatedModules();
-/******/
-/******/ 		var cb;
-/******/ 		var i;
-/******/ 		var j;
-/******/ 		var module;
-/******/ 		var moduleId;
-/******/
-/******/ 		function getAffectedStuff(updateModuleId) {
-/******/ 			var outdatedModules = [updateModuleId];
-/******/ 			var outdatedDependencies = {};
-/******/
-/******/ 			var queue = outdatedModules.map(function(id) {
-/******/ 				return {
-/******/ 					chain: [id],
-/******/ 					id: id
-/******/ 				};
-/******/ 			});
-/******/ 			while (queue.length > 0) {
-/******/ 				var queueItem = queue.pop();
-/******/ 				var moduleId = queueItem.id;
-/******/ 				var chain = queueItem.chain;
-/******/ 				module = installedModules[moduleId];
-/******/ 				if (
-/******/ 					!module ||
-/******/ 					(module.hot._selfAccepted && !module.hot._selfInvalidated)
-/******/ 				)
-/******/ 					continue;
-/******/ 				if (module.hot._selfDeclined) {
-/******/ 					return {
-/******/ 						type: "self-declined",
-/******/ 						chain: chain,
-/******/ 						moduleId: moduleId
-/******/ 					};
-/******/ 				}
-/******/ 				if (module.hot._main) {
-/******/ 					return {
-/******/ 						type: "unaccepted",
-/******/ 						chain: chain,
-/******/ 						moduleId: moduleId
-/******/ 					};
-/******/ 				}
-/******/ 				for (var i = 0; i < module.parents.length; i++) {
-/******/ 					var parentId = module.parents[i];
-/******/ 					var parent = installedModules[parentId];
-/******/ 					if (!parent) continue;
-/******/ 					if (parent.hot._declinedDependencies[moduleId]) {
-/******/ 						return {
-/******/ 							type: "declined",
-/******/ 							chain: chain.concat([parentId]),
-/******/ 							moduleId: moduleId,
-/******/ 							parentId: parentId
-/******/ 						};
-/******/ 					}
-/******/ 					if (outdatedModules.indexOf(parentId) !== -1) continue;
-/******/ 					if (parent.hot._acceptedDependencies[moduleId]) {
-/******/ 						if (!outdatedDependencies[parentId])
-/******/ 							outdatedDependencies[parentId] = [];
-/******/ 						addAllToSet(outdatedDependencies[parentId], [moduleId]);
-/******/ 						continue;
-/******/ 					}
-/******/ 					delete outdatedDependencies[parentId];
-/******/ 					outdatedModules.push(parentId);
-/******/ 					queue.push({
-/******/ 						chain: chain.concat([parentId]),
-/******/ 						id: parentId
-/******/ 					});
-/******/ 				}
-/******/ 			}
-/******/
-/******/ 			return {
-/******/ 				type: "accepted",
-/******/ 				moduleId: updateModuleId,
-/******/ 				outdatedModules: outdatedModules,
-/******/ 				outdatedDependencies: outdatedDependencies
-/******/ 			};
-/******/ 		}
-/******/
-/******/ 		function addAllToSet(a, b) {
-/******/ 			for (var i = 0; i < b.length; i++) {
-/******/ 				var item = b[i];
-/******/ 				if (a.indexOf(item) === -1) a.push(item);
-/******/ 			}
-/******/ 		}
-/******/
-/******/ 		// at begin all updates modules are outdated
-/******/ 		// the "outdated" status can propagate to parents if they don't accept the children
-/******/ 		var outdatedDependencies = {};
-/******/ 		var outdatedModules = [];
-/******/ 		var appliedUpdate = {};
-/******/
-/******/ 		var warnUnexpectedRequire = function warnUnexpectedRequire() {
-/******/ 			console.warn(
-/******/ 				"[HMR] unexpected require(" + result.moduleId + ") to disposed module"
-/******/ 			);
-/******/ 		};
-/******/
-/******/ 		for (var id in hotUpdate) {
-/******/ 			if (Object.prototype.hasOwnProperty.call(hotUpdate, id)) {
-/******/ 				moduleId = toModuleId(id);
-/******/ 				/** @type {TODO} */
-/******/ 				var result;
-/******/ 				if (hotUpdate[id]) {
-/******/ 					result = getAffectedStuff(moduleId);
-/******/ 				} else {
-/******/ 					result = {
-/******/ 						type: "disposed",
-/******/ 						moduleId: id
-/******/ 					};
-/******/ 				}
-/******/ 				/** @type {Error|false} */
-/******/ 				var abortError = false;
-/******/ 				var doApply = false;
-/******/ 				var doDispose = false;
-/******/ 				var chainInfo = "";
-/******/ 				if (result.chain) {
-/******/ 					chainInfo = "\nUpdate propagation: " + result.chain.join(" -> ");
-/******/ 				}
-/******/ 				switch (result.type) {
-/******/ 					case "self-declined":
-/******/ 						if (options.onDeclined) options.onDeclined(result);
-/******/ 						if (!options.ignoreDeclined)
-/******/ 							abortError = new Error(
-/******/ 								"Aborted because of self decline: " +
-/******/ 									result.moduleId +
-/******/ 									chainInfo
-/******/ 							);
-/******/ 						break;
-/******/ 					case "declined":
-/******/ 						if (options.onDeclined) options.onDeclined(result);
-/******/ 						if (!options.ignoreDeclined)
-/******/ 							abortError = new Error(
-/******/ 								"Aborted because of declined dependency: " +
-/******/ 									result.moduleId +
-/******/ 									" in " +
-/******/ 									result.parentId +
-/******/ 									chainInfo
-/******/ 							);
-/******/ 						break;
-/******/ 					case "unaccepted":
-/******/ 						if (options.onUnaccepted) options.onUnaccepted(result);
-/******/ 						if (!options.ignoreUnaccepted)
-/******/ 							abortError = new Error(
-/******/ 								"Aborted because " + moduleId + " is not accepted" + chainInfo
-/******/ 							);
-/******/ 						break;
-/******/ 					case "accepted":
-/******/ 						if (options.onAccepted) options.onAccepted(result);
-/******/ 						doApply = true;
-/******/ 						break;
-/******/ 					case "disposed":
-/******/ 						if (options.onDisposed) options.onDisposed(result);
-/******/ 						doDispose = true;
-/******/ 						break;
-/******/ 					default:
-/******/ 						throw new Error("Unexception type " + result.type);
-/******/ 				}
-/******/ 				if (abortError) {
-/******/ 					hotSetStatus("abort");
-/******/ 					return Promise.reject(abortError);
-/******/ 				}
-/******/ 				if (doApply) {
-/******/ 					appliedUpdate[moduleId] = hotUpdate[moduleId];
-/******/ 					addAllToSet(outdatedModules, result.outdatedModules);
-/******/ 					for (moduleId in result.outdatedDependencies) {
-/******/ 						if (
-/******/ 							Object.prototype.hasOwnProperty.call(
-/******/ 								result.outdatedDependencies,
-/******/ 								moduleId
-/******/ 							)
-/******/ 						) {
-/******/ 							if (!outdatedDependencies[moduleId])
-/******/ 								outdatedDependencies[moduleId] = [];
-/******/ 							addAllToSet(
-/******/ 								outdatedDependencies[moduleId],
-/******/ 								result.outdatedDependencies[moduleId]
-/******/ 							);
-/******/ 						}
-/******/ 					}
-/******/ 				}
-/******/ 				if (doDispose) {
-/******/ 					addAllToSet(outdatedModules, [result.moduleId]);
-/******/ 					appliedUpdate[moduleId] = warnUnexpectedRequire;
-/******/ 				}
-/******/ 			}
-/******/ 		}
-/******/
-/******/ 		// Store self accepted outdated modules to require them later by the module system
-/******/ 		var outdatedSelfAcceptedModules = [];
-/******/ 		for (i = 0; i < outdatedModules.length; i++) {
-/******/ 			moduleId = outdatedModules[i];
-/******/ 			if (
-/******/ 				installedModules[moduleId] &&
-/******/ 				installedModules[moduleId].hot._selfAccepted &&
-/******/ 				// removed self-accepted modules should not be required
-/******/ 				appliedUpdate[moduleId] !== warnUnexpectedRequire &&
-/******/ 				// when called invalidate self-accepting is not possible
-/******/ 				!installedModules[moduleId].hot._selfInvalidated
-/******/ 			) {
-/******/ 				outdatedSelfAcceptedModules.push({
-/******/ 					module: moduleId,
-/******/ 					parents: installedModules[moduleId].parents.slice(),
-/******/ 					errorHandler: installedModules[moduleId].hot._selfAccepted
-/******/ 				});
-/******/ 			}
-/******/ 		}
-/******/
-/******/ 		// Now in "dispose" phase
-/******/ 		hotSetStatus("dispose");
-/******/ 		Object.keys(hotAvailableFilesMap).forEach(function(chunkId) {
-/******/ 			if (hotAvailableFilesMap[chunkId] === false) {
-/******/ 				hotDisposeChunk(chunkId);
-/******/ 			}
-/******/ 		});
-/******/
-/******/ 		var idx;
-/******/ 		var queue = outdatedModules.slice();
-/******/ 		while (queue.length > 0) {
-/******/ 			moduleId = queue.pop();
-/******/ 			module = installedModules[moduleId];
-/******/ 			if (!module) continue;
-/******/
-/******/ 			var data = {};
-/******/
-/******/ 			// Call dispose handlers
-/******/ 			var disposeHandlers = module.hot._disposeHandlers;
-/******/ 			for (j = 0; j < disposeHandlers.length; j++) {
-/******/ 				cb = disposeHandlers[j];
-/******/ 				cb(data);
-/******/ 			}
-/******/ 			hotCurrentModuleData[moduleId] = data;
-/******/
-/******/ 			// disable module (this disables requires from this module)
-/******/ 			module.hot.active = false;
-/******/
-/******/ 			// remove module from cache
-/******/ 			delete installedModules[moduleId];
-/******/
-/******/ 			// when disposing there is no need to call dispose handler
-/******/ 			delete outdatedDependencies[moduleId];
-/******/
-/******/ 			// remove "parents" references from all children
-/******/ 			for (j = 0; j < module.children.length; j++) {
-/******/ 				var child = installedModules[module.children[j]];
-/******/ 				if (!child) continue;
-/******/ 				idx = child.parents.indexOf(moduleId);
-/******/ 				if (idx >= 0) {
-/******/ 					child.parents.splice(idx, 1);
-/******/ 				}
-/******/ 			}
-/******/ 		}
-/******/
-/******/ 		// remove outdated dependency from module children
-/******/ 		var dependency;
-/******/ 		var moduleOutdatedDependencies;
-/******/ 		for (moduleId in outdatedDependencies) {
-/******/ 			if (
-/******/ 				Object.prototype.hasOwnProperty.call(outdatedDependencies, moduleId)
-/******/ 			) {
-/******/ 				module = installedModules[moduleId];
-/******/ 				if (module) {
-/******/ 					moduleOutdatedDependencies = outdatedDependencies[moduleId];
-/******/ 					for (j = 0; j < moduleOutdatedDependencies.length; j++) {
-/******/ 						dependency = moduleOutdatedDependencies[j];
-/******/ 						idx = module.children.indexOf(dependency);
-/******/ 						if (idx >= 0) module.children.splice(idx, 1);
-/******/ 					}
-/******/ 				}
-/******/ 			}
-/******/ 		}
-/******/
-/******/ 		// Now in "apply" phase
-/******/ 		hotSetStatus("apply");
-/******/
-/******/ 		if (hotUpdateNewHash !== undefined) {
-/******/ 			hotCurrentHash = hotUpdateNewHash;
-/******/ 			hotUpdateNewHash = undefined;
-/******/ 		}
-/******/ 		hotUpdate = undefined;
-/******/
-/******/ 		// insert new code
-/******/ 		for (moduleId in appliedUpdate) {
-/******/ 			if (Object.prototype.hasOwnProperty.call(appliedUpdate, moduleId)) {
-/******/ 				modules[moduleId] = appliedUpdate[moduleId];
-/******/ 			}
-/******/ 		}
-/******/
-/******/ 		// call accept handlers
-/******/ 		var error = null;
-/******/ 		for (moduleId in outdatedDependencies) {
-/******/ 			if (
-/******/ 				Object.prototype.hasOwnProperty.call(outdatedDependencies, moduleId)
-/******/ 			) {
-/******/ 				module = installedModules[moduleId];
-/******/ 				if (module) {
-/******/ 					moduleOutdatedDependencies = outdatedDependencies[moduleId];
-/******/ 					var callbacks = [];
-/******/ 					for (i = 0; i < moduleOutdatedDependencies.length; i++) {
-/******/ 						dependency = moduleOutdatedDependencies[i];
-/******/ 						cb = module.hot._acceptedDependencies[dependency];
-/******/ 						if (cb) {
-/******/ 							if (callbacks.indexOf(cb) !== -1) continue;
-/******/ 							callbacks.push(cb);
-/******/ 						}
-/******/ 					}
-/******/ 					for (i = 0; i < callbacks.length; i++) {
-/******/ 						cb = callbacks[i];
-/******/ 						try {
-/******/ 							cb(moduleOutdatedDependencies);
-/******/ 						} catch (err) {
-/******/ 							if (options.onErrored) {
-/******/ 								options.onErrored({
-/******/ 									type: "accept-errored",
-/******/ 									moduleId: moduleId,
-/******/ 									dependencyId: moduleOutdatedDependencies[i],
-/******/ 									error: err
-/******/ 								});
-/******/ 							}
-/******/ 							if (!options.ignoreErrored) {
-/******/ 								if (!error) error = err;
-/******/ 							}
-/******/ 						}
-/******/ 					}
-/******/ 				}
-/******/ 			}
-/******/ 		}
-/******/
-/******/ 		// Load self accepted modules
-/******/ 		for (i = 0; i < outdatedSelfAcceptedModules.length; i++) {
-/******/ 			var item = outdatedSelfAcceptedModules[i];
-/******/ 			moduleId = item.module;
-/******/ 			hotCurrentParents = item.parents;
-/******/ 			hotCurrentChildModule = moduleId;
-/******/ 			try {
-/******/ 				__webpack_require__(moduleId);
-/******/ 			} catch (err) {
-/******/ 				if (typeof item.errorHandler === "function") {
-/******/ 					try {
-/******/ 						item.errorHandler(err);
-/******/ 					} catch (err2) {
-/******/ 						if (options.onErrored) {
-/******/ 							options.onErrored({
-/******/ 								type: "self-accept-error-handler-errored",
-/******/ 								moduleId: moduleId,
-/******/ 								error: err2,
-/******/ 								originalError: err
-/******/ 							});
-/******/ 						}
-/******/ 						if (!options.ignoreErrored) {
-/******/ 							if (!error) error = err2;
-/******/ 						}
-/******/ 						if (!error) error = err;
-/******/ 					}
-/******/ 				} else {
-/******/ 					if (options.onErrored) {
-/******/ 						options.onErrored({
-/******/ 							type: "self-accept-errored",
-/******/ 							moduleId: moduleId,
-/******/ 							error: err
-/******/ 						});
-/******/ 					}
-/******/ 					if (!options.ignoreErrored) {
-/******/ 						if (!error) error = err;
-/******/ 					}
-/******/ 				}
-/******/ 			}
-/******/ 		}
-/******/
-/******/ 		// handle errors in accept handlers and self accepted module load
-/******/ 		if (error) {
-/******/ 			hotSetStatus("fail");
-/******/ 			return Promise.reject(error);
-/******/ 		}
-/******/
-/******/ 		if (hotQueuedInvalidatedModules) {
-/******/ 			return hotApplyInternal(options).then(function(list) {
-/******/ 				outdatedModules.forEach(function(moduleId) {
-/******/ 					if (list.indexOf(moduleId) < 0) list.push(moduleId);
-/******/ 				});
-/******/ 				return list;
-/******/ 			});
-/******/ 		}
-/******/
-/******/ 		hotSetStatus("idle");
-/******/ 		return new Promise(function(resolve) {
-/******/ 			resolve(outdatedModules);
-/******/ 		});
-/******/ 	}
-/******/
-/******/ 	function hotApplyInvalidatedModules() {
-/******/ 		if (hotQueuedInvalidatedModules) {
-/******/ 			if (!hotUpdate) hotUpdate = {};
-/******/ 			hotQueuedInvalidatedModules.forEach(hotApplyInvalidatedModule);
-/******/ 			hotQueuedInvalidatedModules = undefined;
-/******/ 			return true;
-/******/ 		}
-/******/ 	}
-/******/
-/******/ 	function hotApplyInvalidatedModule(moduleId) {
-/******/ 		if (!Object.prototype.hasOwnProperty.call(hotUpdate, moduleId))
-/******/ 			hotUpdate[moduleId] = modules[moduleId];
-/******/ 	}
-/******/
-/******/ 	// The module cache
-/******/ 	var installedModules = {};
-/******/
-/******/ 	// object to store loaded and loading chunks
-/******/ 	// undefined = chunk not loaded, null = chunk preloaded/prefetched
-/******/ 	// Promise = chunk loading, 0 = chunk loaded
-/******/ 	var installedChunks = {
-/******/ 		"fds-demo.bundle.min": 0
-/******/ 	};
-/******/
-/******/ 	var deferredModules = [];
-/******/
-/******/ 	// The require function
-/******/ 	function __webpack_require__(moduleId) {
-/******/
-/******/ 		// Check if module is in cache
-/******/ 		if(installedModules[moduleId]) {
-/******/ 			return installedModules[moduleId].exports;
-/******/ 		}
-/******/ 		// Create a new module (and put it into the cache)
-/******/ 		var module = installedModules[moduleId] = {
-/******/ 			i: moduleId,
-/******/ 			l: false,
-/******/ 			exports: {},
-/******/ 			hot: hotCreateModule(moduleId),
-/******/ 			parents: (hotCurrentParentsTemp = hotCurrentParents, hotCurrentParents = [], hotCurrentParentsTemp),
-/******/ 			children: []
-/******/ 		};
-/******/
-/******/ 		// Execute the module function
-/******/ 		modules[moduleId].call(module.exports, module, module.exports, hotCreateRequire(moduleId));
-/******/
-/******/ 		// Flag the module as loaded
-/******/ 		module.l = true;
-/******/
-/******/ 		// Return the exports of the module
-/******/ 		return module.exports;
-/******/ 	}
-/******/
-/******/
-/******/ 	// expose the modules object (__webpack_modules__)
-/******/ 	__webpack_require__.m = modules;
-/******/
-/******/ 	// expose the module cache
-/******/ 	__webpack_require__.c = installedModules;
-/******/
-/******/ 	// define getter function for harmony exports
-/******/ 	__webpack_require__.d = function(exports, name, getter) {
-/******/ 		if(!__webpack_require__.o(exports, name)) {
-/******/ 			Object.defineProperty(exports, name, { enumerable: true, get: getter });
-/******/ 		}
-/******/ 	};
-/******/
-/******/ 	// define __esModule on exports
-/******/ 	__webpack_require__.r = function(exports) {
-/******/ 		if(typeof Symbol !== 'undefined' && Symbol.toStringTag) {
-/******/ 			Object.defineProperty(exports, Symbol.toStringTag, { value: 'Module' });
-/******/ 		}
-/******/ 		Object.defineProperty(exports, '__esModule', { value: true });
-/******/ 	};
-/******/
-/******/ 	// create a fake namespace object
-/******/ 	// mode & 1: value is a module id, require it
-/******/ 	// mode & 2: merge all properties of value into the ns
-/******/ 	// mode & 4: return value when already ns object
-/******/ 	// mode & 8|1: behave like require
-/******/ 	__webpack_require__.t = function(value, mode) {
-/******/ 		if(mode & 1) value = __webpack_require__(value);
-/******/ 		if(mode & 8) return value;
-/******/ 		if((mode & 4) && typeof value === 'object' && value && value.__esModule) return value;
-/******/ 		var ns = Object.create(null);
-/******/ 		__webpack_require__.r(ns);
-/******/ 		Object.defineProperty(ns, 'default', { enumerable: true, value: value });
-/******/ 		if(mode & 2 && typeof value != 'string') for(var key in value) __webpack_require__.d(ns, key, function(key) { return value[key]; }.bind(null, key));
-/******/ 		return ns;
-/******/ 	};
-/******/
-/******/ 	// getDefaultExport function for compatibility with non-harmony modules
-/******/ 	__webpack_require__.n = function(module) {
-/******/ 		var getter = module && module.__esModule ?
-/******/ 			function getDefault() { return module['default']; } :
-/******/ 			function getModuleExports() { return module; };
-/******/ 		__webpack_require__.d(getter, 'a', getter);
-/******/ 		return getter;
-/******/ 	};
-/******/
-/******/ 	// Object.prototype.hasOwnProperty.call
-/******/ 	__webpack_require__.o = function(object, property) { return Object.prototype.hasOwnProperty.call(object, property); };
-/******/
-/******/ 	// __webpack_public_path__
-/******/ 	__webpack_require__.p = "";
-/******/
-/******/ 	// __webpack_hash__
-/******/ 	__webpack_require__.h = function() { return hotCurrentHash; };
-/******/
-/******/ 	var jsonpArray = window["webpackJsonp"] = window["webpackJsonp"] || [];
-/******/ 	var oldJsonpFunction = jsonpArray.push.bind(jsonpArray);
-/******/ 	jsonpArray.push = webpackJsonpCallback;
-/******/ 	jsonpArray = jsonpArray.slice();
-/******/ 	for(var i = 0; i < jsonpArray.length; i++) webpackJsonpCallback(jsonpArray[i]);
-/******/ 	var parentJsonpFunction = oldJsonpFunction;
-/******/
-/******/
-/******/ 	// add entry module to deferred list
-/******/ 	deferredModules.push(["./webapp/fds-bootstrap.js","fds-demo.vendor.min"]);
-/******/ 	// run deferred modules when ready
-/******/ 	return checkDeferredModules();
-/******/ })
-/************************************************************************/
-/******/ ({
-
-/***/ "./node_modules/@angular/core/fesm2015 lazy recursive":
-/*!*******************************************************************!*\
-  !*** ./node_modules/@angular/core/fesm2015 lazy namespace object ***!
-  \*******************************************************************/
-/*! no static exports found */
-/***/ (function(module, exports) {
-
-function webpackEmptyAsyncContext(req) {
-	// Here Promise.resolve().then() is used instead of new Promise() to prevent
-	// uncaught exception popping up in devtools
-	return Promise.resolve().then(function() {
-		var e = new Error("Cannot find module '" + req + "'");
-		e.code = 'MODULE_NOT_FOUND';
-		throw e;
-	});
-}
-webpackEmptyAsyncContext.keys = function() { return []; };
-webpackEmptyAsyncContext.resolve = webpackEmptyAsyncContext;
-module.exports = webpackEmptyAsyncContext;
-webpackEmptyAsyncContext.id = "./node_modules/@angular/core/fesm2015 lazy recursive";
-
-/***/ }),
-
-/***/ "./package.json":
-/*!**********************!*\
-  !*** ./package.json ***!
-  \**********************/
-/*! exports provided: //-01, //-02, //-03, //-04, //-05, //-06, //-07, //-08, //-09, //-10, //-11, //-12, //-13, //-14, name, version, scripts, husky, description, module, keywords, repository, bugs, license, dependencies, devDependencies, engines, resolutions, default */
-/***/ (function(module) {
-
-module.exports = JSON.parse("{\"//-01\":\"Licensed to the Apache Software Foundation (ASF) under one or more\",\"//-02\":\"contributor license agreements.  See the NOTICE file distributed with\",\"//-03\":\"this work for additional information regarding copyright ownership.\",\"//-04\":\"The ASF licenses this file to You under the Apache License, Version 2.0\",\"//-05\":\"(the \\\"License\\\"); you may not use this file except in compliance with\",\"//-06\":\"the License.  You may obtain [...]
-
-/***/ }),
-
-/***/ "./platform/core/common/fds-common.module.js":
-/*!***************************************************!*\
-  !*** ./platform/core/common/fds-common.module.js ***!
-  \***************************************************/
-/*! exports provided: FdsCommonsModule, FdsStorageService */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsCommonsModule", function() { return FdsCommonsModule; });
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/* harmony import */ var _services_fds_storage_service__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! ./services/fds-storage.service */ "./platform/core/common/services/fds-storage.service.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsStorageService", function() { return _services_fds_storage_service__WEBPACK_IMPORTED_MODULE_1__["default"]; });
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-/**
- * FdsCommonsModule constructor.
- *
- * @constructor
- */
-
-function FdsCommonsModule() {}
-
-FdsCommonsModule.prototype = {
-  constructor: FdsCommonsModule
-};
-FdsCommonsModule.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_0__["NgModule"]({
-  imports: [],
-  declarations: [],
-  exports: [],
-  providers: [_services_fds_storage_service__WEBPACK_IMPORTED_MODULE_1__["default"]]
-})];
-
-
-/***/ }),
-
-/***/ "./platform/core/common/fds.animations.js":
-/*!************************************************!*\
-  !*** ./platform/core/common/fds.animations.js ***!
-  \************************************************/
-/*! exports provided: default */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony import */ var _angular_animations__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/animations */ "./node_modules/@angular/animations/fesm2015/animations.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-/**
- * FdsAnimations constructor.
- *
- * @constructor
- */
-
-function FdsAnimations() {}
-
-FdsAnimations.prototype = {
-  constructor: FdsAnimations,
-
-  /**
-   * Fade animation
-   */
-  fadeAnimation: Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["trigger"])('routeAnimation', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["state"])('*', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 1
-  })), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["transition"])(':enter', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 0
-  }), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["animate"])('0.5s ease-in')]), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["transition"])(':leave', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["animate"])('0.5s ease-out', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 0
-  }))])]),
-
-  /**
-   * Slide in from the left animation
-   */
-  slideInLeftAnimation: Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["trigger"])('routeAnimation', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["state"])('*', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 1,
-    transform: 'translateX(0)'
-  })), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["transition"])(':enter', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 0,
-    transform: 'translateX(-100%)'
-  }), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["animate"])('0.5s ease-in')]), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["transition"])(':leave', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["animate"])('0.5s ease-out', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 0,
-    transform: 'translateX(100%)'
-  }))])]),
-
-  /**
-   * Slide in from the top animation
-   */
-  slideInDownAnimation: Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["trigger"])('routeAnimation', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["state"])('*', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 1,
-    transform: 'translateY(0)'
-  })), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["transition"])(':enter', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 0,
-    transform: 'translateY(-100%)'
-  }), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["animate"])('0.5s ease-in')]), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["transition"])(':leave', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["animate"])('0.5s ease-out', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 0,
-    transform: 'translateY(100%)'
-  }))])]),
-
-  /**
-   * Fly in/out animation
-   */
-  flyInOutAnimation: Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["trigger"])('flyInOut', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["state"])('in', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    transform: 'translateX(0)'
-  })), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["transition"])('void => *', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    transform: 'translateX(100%)'
-  }), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["animate"])('0.4s 0.1s ease-in')]), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["transition"])('* => void', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["animate"])('0.2s ease-out', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    transform: 'translateX(-100%)'
-  })))]),
-
-  /**
-   * Fly in/out animation
-   */
-  fadeInOutAnimation: Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["trigger"])('fadeInOut', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["state"])('in', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 1
-  })), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["transition"])('void => *', [Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 0
-  }), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["animate"])('0.5s 0.1s ease-in')]), Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["transition"])('* => void', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["animate"])('0.5s ease-out', Object(_angular_animations__WEBPACK_IMPORTED_MODULE_0__["style"])({
-    opacity: 0
-  })))])
-};
-/* harmony default export */ __webpack_exports__["default"] = (new FdsAnimations());
-
-/***/ }),
-
-/***/ "./platform/core/common/services/fds-storage.service.js":
-/*!**************************************************************!*\
-  !*** ./platform/core/common/services/fds-storage.service.js ***!
-  \**************************************************************/
-/*! exports provided: default */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-// Store items for two days before being eligible for removal.
-var MILLIS_PER_DAY = 86400000;
-var TWO_DAYS = MILLIS_PER_DAY * 2;
-
-var isUndefined = function isUndefined(obj) {
-  return typeof obj === 'undefined';
-};
-
-var isNull = function isNull(obj) {
-  return obj === null;
-};
-
-var isDefinedAndNotNull = function isDefinedAndNotNull(obj) {
-  return !isUndefined(obj) && !isNull(obj);
-};
-/**
- * Checks the expiration for the specified entry.
- *
- * @param {object} entry
- * @returns {boolean}
- */
-
-
-var checkExpiration = function checkExpiration(entry) {
-  if (isDefinedAndNotNull(entry.expires)) {
-    // get the expiration
-    var expires = new Date(entry.expires);
-    var now = new Date(); // return whether the expiration date has passed
-
-    return expires.valueOf() < now.valueOf();
-  }
-
-  return false;
-};
-/**
- * Gets an enty for the key. The entry expiration is not checked.
- *
- * @param {string} key
- */
-
-
-var getEntry = function getEntry(key) {
-  try {
-    // parse the entry
-    var entry = JSON.parse(localStorage.getItem(key)); // ensure the entry and item are present
-
-    if (isDefinedAndNotNull(entry)) {
-      return entry;
-    }
-
-    return null;
-  } catch (e) {
-    return null;
-  }
-};
-/**
- * FdsStorageService constructor.
- * @constructor
- */
-
-
-function FdsStorageService() {}
-
-FdsStorageService.prototype = {
-  constructor: FdsStorageService,
-
-  /**
-   * Initializes the storage. Items will be persisted for two days. Once the scripts runs
-   * thereafter, all eligible items will be removed. This strategy does not support persistence.
-   */
-  init: function init() {
-    for (var i = 0; i < localStorage.length; i++) {
-      try {
-        // get the next item
-        var key = localStorage.key(i); // attempt to get the item which will expire if necessary
-
-        this.getItem(key);
-      } catch (e) {// Do nothing
-      }
-    }
-  },
-
-  /**
-   * Stores the specified item.
-   *
-   * @param {string} key
-   * @param {object} item
-   * @param {integer} expires
-   */
-  setItem: function setItem(key, item, expires) {
-    // calculate the expiration
-    expires = isDefinedAndNotNull(expires) ? expires : new Date().valueOf() + TWO_DAYS; // create the entry
-
-    var entry = {
-      expires: expires,
-      item: item
-    }; // store the item
-
-    localStorage.setItem(key, JSON.stringify(entry));
-  },
-
-  /**
-   * Returns whether there is an entry for this key. This will not check the expiration. If
-   * the entry is expired, it will return null on a subsequent getItem invocation.
-   *
-   * @param {string} key
-   * @returns {boolean}
-   */
-  hasItem: function hasItem(key) {
-    return getEntry(key) !== null;
-  },
-
-  /**
-   * Gets the item with the specified key. If an item with this key does
-   * not exist, null is returned. If an item exists but cannot be parsed
-   * or is malformed/unrecognized, null is returned.
-   *
-   * @param {type} key
-   */
-  getItem: function getItem(key) {
-    var entry = getEntry(key);
-
-    if (entry === null) {
-      return null;
-    } // if the entry is expired, drop it and return null
-
-
-    if (checkExpiration(entry)) {
-      this.removeItem(key);
-      return null;
-    } // if the entry has the specified field return its value
-
-
-    if (isDefinedAndNotNull(entry['item'])) {
-      return entry['item'];
-    }
-
-    return null;
-  },
-
-  /**
-   * Gets the expiration for the specified item. This will not check the expiration. If
-   * the entry is expired, it will return null on a subsequent getItem invocation.
-   *
-   * @param {string} key
-   * @returns {integer}
-   */
-  getItemExpiration: function getItemExpiration(key) {
-    var entry = getEntry(key);
-
-    if (entry === null) {
-      return null;
-    } // if the entry has the specified field return its value
-
-
-    if (isDefinedAndNotNull(entry['expires'])) {
-      return entry['expires'];
-    }
-
-    return null;
-  },
-
-  /**
-   * Extracts the subject from the specified jwt. If the jwt is not as expected
-   * an empty string is returned.
-   *
-   * @param {string} jwt
-   * @returns {string}
-   */
-  getJwtPayload: function getJwtPayload(jwt) {
-    if (isDefinedAndNotNull(jwt)) {
-      var segments = jwt.split(/\./);
-
-      if (segments.length !== 3) {
-        return '';
-      }
-
-      var rawPayload = window.atob(segments[1]);
-      var payload = JSON.parse(rawPayload);
-
-      if (isDefinedAndNotNull(payload)) {
-        return payload;
-      }
-
-      return null;
-    }
-
-    return null;
-  },
-
-  /**
-   * Removes the item with the specified key.
-   *
-   * @param {type} key
-   */
-  removeItem: function removeItem(key) {
-    localStorage.removeItem(key);
-  }
-};
-FdsStorageService.parameters = [];
-/* harmony default export */ __webpack_exports__["default"] = (FdsStorageService);
-
-/***/ }),
-
-/***/ "./platform/core/dialogs/confirm-dialog/confirm-dialog.component.html":
-/*!****************************************************************************!*\
-  !*** ./platform/core/dialogs/confirm-dialog/confirm-dialog.component.html ***!
-  \****************************************************************************/
-/*! no static exports found */
-/***/ (function(module, exports) {
-
-module.exports = "<!--\nLicensed to the Apache Software Foundation (ASF) under one or more\ncontributor license agreements.  See the NOTICE file distributed with\nthis work for additional information regarding copyright ownership.\nThe ASF licenses this file to You under the Apache License, Version 2.0\n(the \"License\"); you may not use this file except in compliance with\nthe License.  You may obtain a copy of the License at\n\nhttp://www.apache.org/licenses/LICENSE-2.0\n\nUnless requi [...]
-
-/***/ }),
-
-/***/ "./platform/core/dialogs/confirm-dialog/confirm-dialog.component.js":
-/*!**************************************************************************!*\
-  !*** ./platform/core/dialogs/confirm-dialog/confirm-dialog.component.js ***!
-  \**************************************************************************/
-/*! exports provided: FdsConfirmDialogComponent */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsConfirmDialogComponent", function() { return FdsConfirmDialogComponent; });
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-/**
- * FdsConfirmDialogComponent constructor.
- *
- * @constructor
- */
-
-function FdsConfirmDialogComponent() {
-  this.title = '';
-  this.message = '';
-  this.acceptButton = '';
-  this.acceptButtonColor = 'fds-primary';
-  this.cancelButton = '';
-  this.cancelButtonColor = 'fds-regular';
-  this.dialogRef = undefined;
-  this.viewContainerRef = undefined;
-  this.disableClose = true;
-}
-
-FdsConfirmDialogComponent.prototype = {
-  constructor: FdsConfirmDialogComponent,
-
-  /**
-   * Close the dialog and send a cancel response to any subscribers.
-   */
-  cancel: function cancel() {
-    this.dialogRef.close(false);
-  },
-
-  /**
-   * Close the dialog and send an accept response to any subscribers.
-   */
-  accept: function accept() {
-    this.dialogRef.close(true);
-  }
-};
-FdsConfirmDialogComponent.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_0__["Component"]({
-  selector: 'fds-confirm-dialog',
-  template: __webpack_require__(/*! ./confirm-dialog.component.html */ "./platform/core/dialogs/confirm-dialog/confirm-dialog.component.html")})];
-FdsConfirmDialogComponent.parameters = [];
-
-
-/***/ }),
-
-/***/ "./platform/core/dialogs/fds-dialog.component.html":
-/*!*********************************************************!*\
-  !*** ./platform/core/dialogs/fds-dialog.component.html ***!
-  \*********************************************************/
-/*! no static exports found */
-/***/ (function(module, exports) {
-
-module.exports = "<!--\nLicensed to the Apache Software Foundation (ASF) under one or more\ncontributor license agreements.  See the NOTICE file distributed with\nthis work for additional information regarding copyright ownership.\nThe ASF licenses this file to You under the Apache License, Version 2.0\n(the \"License\"); you may not use this file except in compliance with\nthe License.  You may obtain a copy of the License at\n\nhttp://www.apache.org/licenses/LICENSE-2.0\n\nUnless requi [...]
-
-/***/ }),
-
-/***/ "./platform/core/dialogs/fds-dialog.component.js":
-/*!*******************************************************!*\
-  !*** ./platform/core/dialogs/fds-dialog.component.js ***!
-  \*******************************************************/
-/*! exports provided: FdsDialogTitleDirective, FdsDialogContentDirective, FdsDialogActionsDirective, FdsDialogComponent */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsDialogTitleDirective", function() { return FdsDialogTitleDirective; });
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsDialogContentDirective", function() { return FdsDialogContentDirective; });
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsDialogActionsDirective", function() { return FdsDialogActionsDirective; });
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsDialogComponent", function() { return FdsDialogComponent; });
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-function FdsDialogTitleDirective() {}
-FdsDialogTitleDirective.prototype = {
-  contstructor: FdsDialogTitleDirective
-};
-FdsDialogTitleDirective.decorators = [{
-  type: _angular_core__WEBPACK_IMPORTED_MODULE_0__["Directive"],
-  args: [{
-    selector: 'fds-dialog-title'
-  }]
-}];
-function FdsDialogContentDirective() {}
-FdsDialogContentDirective.prototype = {
-  contstructor: FdsDialogContentDirective
-};
-FdsDialogContentDirective.decorators = [{
-  type: _angular_core__WEBPACK_IMPORTED_MODULE_0__["Directive"],
-  args: [{
-    selector: 'fds-dialog-content'
-  }]
-}];
-function FdsDialogActionsDirective() {}
-FdsDialogActionsDirective.prototype = {
-  contstructor: FdsDialogActionsDirective
-};
-FdsDialogActionsDirective.decorators = [{
-  type: _angular_core__WEBPACK_IMPORTED_MODULE_0__["Directive"],
-  args: [{
-    selector: 'fds-dialog-actions'
-  }]
-}];
-/**
- * FdsDialogComponent constructor
- *
- * @constructor
- */
-
-function FdsDialogComponent() {
-  this.dialogTitle = '';
-  this.dialogContent = '';
-  this.dialogActions = '';
-}
-
-FdsDialogComponent.prototype = {
-  constructor: FdsDialogComponent,
-
-  /**
-   * Respond after Angular projects external content into the component's view.
-   */
-  ngAfterContentInit: function ngAfterContentInit() {
-    if (this.dialogTitle.length > 1) {
-      throw new Error('Duplicate fds-dialog-title component at in fds-dialog.');
-    }
-
-    if (this.dialogContent.length > 1) {
-      throw new Error('Duplicate fds-dialog-content component at in fds-dialog.');
-    }
-
-    if (this.dialogActions.length > 1) {
-      throw new Error('Duplicate fds-dialog-actions component at in fds-dialog.');
-    }
-  }
-};
-FdsDialogComponent.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_0__["Component"]({
-  selector: 'fds-dialog',
-  template: __webpack_require__(/*! ./fds-dialog.component.html */ "./platform/core/dialogs/fds-dialog.component.html"),
-  queries: {
-    dialogTitle: new _angular_core__WEBPACK_IMPORTED_MODULE_0__["ContentChildren"](FdsDialogTitleDirective),
-    dialogContent: new _angular_core__WEBPACK_IMPORTED_MODULE_0__["ContentChildren"](FdsDialogContentDirective),
-    dialogActions: new _angular_core__WEBPACK_IMPORTED_MODULE_0__["ContentChildren"](FdsDialogActionsDirective)
-  }
-})];
-FdsDialogComponent.parameters = [];
-
-
-/***/ }),
-
-/***/ "./platform/core/dialogs/fds-dialogs.module.js":
-/*!*****************************************************!*\
-  !*** ./platform/core/dialogs/fds-dialogs.module.js ***!
-  \*****************************************************/
-/*! exports provided: FdsDialogsModule, IConfirmConfig, FdsDialogService, FdsDialogComponent, FdsDialogTitleDirective, FdsDialogContentDirective, FdsDialogActionsDirective, FdsConfirmDialogComponent */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsDialogsModule", function() { return FdsDialogsModule; });
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/* harmony import */ var _angular_material_dialog__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! @angular/material/dialog */ "./node_modules/@angular/material/fesm2015/dialog.js");
-/* harmony import */ var _angular_material_input__WEBPACK_IMPORTED_MODULE_2__ = __webpack_require__(/*! @angular/material/input */ "./node_modules/@angular/material/fesm2015/input.js");
-/* harmony import */ var _angular_material_button__WEBPACK_IMPORTED_MODULE_3__ = __webpack_require__(/*! @angular/material/button */ "./node_modules/@angular/material/fesm2015/button.js");
-/* harmony import */ var _angular_material_icon__WEBPACK_IMPORTED_MODULE_4__ = __webpack_require__(/*! @angular/material/icon */ "./node_modules/@angular/material/fesm2015/icon.js");
-/* harmony import */ var _angular_flex_layout__WEBPACK_IMPORTED_MODULE_5__ = __webpack_require__(/*! @angular/flex-layout */ "./node_modules/@angular/flex-layout/esm5/flex-layout.es5.js");
-/* harmony import */ var _angular_common__WEBPACK_IMPORTED_MODULE_6__ = __webpack_require__(/*! @angular/common */ "./node_modules/@angular/common/fesm2015/common.js");
-/* harmony import */ var _angular_forms__WEBPACK_IMPORTED_MODULE_7__ = __webpack_require__(/*! @angular/forms */ "./node_modules/@angular/forms/fesm2015/forms.js");
-/* harmony import */ var _fds_dialog_component__WEBPACK_IMPORTED_MODULE_8__ = __webpack_require__(/*! ./fds-dialog.component */ "./platform/core/dialogs/fds-dialog.component.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsDialogComponent", function() { return _fds_dialog_component__WEBPACK_IMPORTED_MODULE_8__["FdsDialogComponent"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsDialogTitleDirective", function() { return _fds_dialog_component__WEBPACK_IMPORTED_MODULE_8__["FdsDialogTitleDirective"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsDialogContentDirective", function() { return _fds_dialog_component__WEBPACK_IMPORTED_MODULE_8__["FdsDialogContentDirective"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsDialogActionsDirective", function() { return _fds_dialog_component__WEBPACK_IMPORTED_MODULE_8__["FdsDialogActionsDirective"]; });
-
-/* harmony import */ var _services_dialog_service__WEBPACK_IMPORTED_MODULE_9__ = __webpack_require__(/*! ./services/dialog.service */ "./platform/core/dialogs/services/dialog.service.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "IConfirmConfig", function() { return _services_dialog_service__WEBPACK_IMPORTED_MODULE_9__["IConfirmConfig"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsDialogService", function() { return _services_dialog_service__WEBPACK_IMPORTED_MODULE_9__["FdsDialogService"]; });
-
-/* harmony import */ var _confirm_dialog_confirm_dialog_component__WEBPACK_IMPORTED_MODULE_10__ = __webpack_require__(/*! ./confirm-dialog/confirm-dialog.component */ "./platform/core/dialogs/confirm-dialog/confirm-dialog.component.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsConfirmDialogComponent", function() { return _confirm_dialog_confirm_dialog_component__WEBPACK_IMPORTED_MODULE_10__["FdsConfirmDialogComponent"]; });
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-
-
-
-
-
-
-
-
-
-var FDS_DIALOGS = [_fds_dialog_component__WEBPACK_IMPORTED_MODULE_8__["FdsDialogComponent"], _fds_dialog_component__WEBPACK_IMPORTED_MODULE_8__["FdsDialogTitleDirective"], _fds_dialog_component__WEBPACK_IMPORTED_MODULE_8__["FdsDialogActionsDirective"], _fds_dialog_component__WEBPACK_IMPORTED_MODULE_8__["FdsDialogContentDirective"], _confirm_dialog_confirm_dialog_component__WEBPACK_IMPORTED_MODULE_10__["FdsConfirmDialogComponent"]];
-var FDS_DIALOGS_ENTRY_COMPONENTS = [_confirm_dialog_confirm_dialog_component__WEBPACK_IMPORTED_MODULE_10__["FdsConfirmDialogComponent"]];
-/**
- * FdsDialogsModule constructor.
- *
- * @constructor
- */
-
-function FdsDialogsModule() {}
-
-FdsDialogsModule.prototype = {
-  constructor: FdsDialogsModule
-};
-FdsDialogsModule.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_0__["NgModule"]({
-  imports: [_angular_flex_layout__WEBPACK_IMPORTED_MODULE_5__["FlexLayoutModule"], _angular_forms__WEBPACK_IMPORTED_MODULE_7__["FormsModule"], _angular_common__WEBPACK_IMPORTED_MODULE_6__["CommonModule"], _angular_material_dialog__WEBPACK_IMPORTED_MODULE_1__["MatDialogModule"], _angular_material_input__WEBPACK_IMPORTED_MODULE_2__["MatInputModule"], _angular_material_button__WEBPACK_IMPORTED_MODULE_3__["MatButtonModule"], _angular_material_icon__WEBPACK_IMPORTED_MODULE_4__["MatIconModule"]],
-  declarations: [FDS_DIALOGS],
-  exports: [FDS_DIALOGS],
-  providers: [_services_dialog_service__WEBPACK_IMPORTED_MODULE_9__["FdsDialogService"]],
-  entryComponents: [FDS_DIALOGS_ENTRY_COMPONENTS]
-})];
-
-
-/***/ }),
-
-/***/ "./platform/core/dialogs/services/dialog.service.js":
-/*!**********************************************************!*\
-  !*** ./platform/core/dialogs/services/dialog.service.js ***!
-  \**********************************************************/
-/*! exports provided: IDialogConfig, IConfirmConfig, FdsDialogService */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "IDialogConfig", function() { return IDialogConfig; });
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "IConfirmConfig", function() { return IConfirmConfig; });
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsDialogService", function() { return FdsDialogService; });
-/* harmony import */ var jquery__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! jquery */ "./node_modules/jquery/dist/jquery.js");
-/* harmony import */ var jquery__WEBPACK_IMPORTED_MODULE_0___default = /*#__PURE__*/__webpack_require__.n(jquery__WEBPACK_IMPORTED_MODULE_0__);
-/* harmony import */ var _angular_material_dialog__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! @angular/material/dialog */ "./node_modules/@angular/material/fesm2015/dialog.js");
-/* harmony import */ var _confirm_dialog_confirm_dialog_component__WEBPACK_IMPORTED_MODULE_2__ = __webpack_require__(/*! ../confirm-dialog/confirm-dialog.component */ "./platform/core/dialogs/confirm-dialog/confirm-dialog.component.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-
-
-function IDialogConfig() {
-  this.title = '';
-  this.message = '';
-  this.dialogRef = undefined;
-  this.viewContainerRef = undefined;
-  this.disableClose = true;
-}
-
-IDialogConfig.prototype = {
-  contstructor: IDialogConfig
-};
-jquery__WEBPACK_IMPORTED_MODULE_0___default.a.extend(IDialogConfig, _angular_material_dialog__WEBPACK_IMPORTED_MODULE_1__["MatDialogConfig"]);
-
-function IConfirmConfig() {
-  this.acceptButton = 'ACCEPT';
-  this.acceptButtonColor = 'fds-primary';
-  this.cancelButton = 'CANCEL';
-  this.cancelButtonColor = 'fds-secondary';
-}
-
-IConfirmConfig.prototype = {
-  contstructor: IConfirmConfig
-};
-jquery__WEBPACK_IMPORTED_MODULE_0___default.a.extend(IConfirmConfig, IDialogConfig);
-
-function createConfig(config) {
-  var dialogConfig = new IConfirmConfig();
-  dialogConfig.viewContainerRef = config.viewContainerRef;
-  dialogConfig.disableClose = config.disableClose;
-  return dialogConfig;
-}
-/**
- * FdsDialogService constructor.
- *
- * @param MatDialog      The angular material MatDialog.
- * @constructor
- */
-
-
-function FdsDialogService(MatDialog) {
-  this.dialogService = MatDialog;
-}
-
-FdsDialogService.prototype = {
-  contstructor: FdsDialogService,
-
-  /**
-   * Wrapper function over the open() method in MatDialog.
-   * Opens a modal dialog containing the given component.
-   *
-   * @param component     The angular ComponentType<T>.
-   * @param config        The angular material MatDialogConfig.
-   *
-   * @returns {MatDialoRef}    The reference to the dialog.
-   */
-  open: function open(component, config) {
-    return this.dialogService.open(component, config);
-  },
-
-  /**
-   * Wrapper function over the closeAll() method in MatDialog.
-   * Closes all of the currently-open dialogs.
-   */
-  closeAll: function closeAll() {
-    this.dialogService.closeAll();
-  },
-
-  /**
-   * Opens a confirm dialog with the provided config.
-   *
-   * @param config     IConfirmConfig {
-   *                                      message?: string;
-   *                                      title?: string;
-   *                                      dialogRef?: MatDialoRef;
-   *                                      viewContainerRef?: ViewContainerRef;
-   *                                      disableClose?: boolean;
-   *                                      acceptButton?: string;
-   *                                      acceptButtonColor?: string;
-   *                                      cancelButton?: string;
-   *                                      cancelButtonColor?: string;
-   *                                   }
-   *
-   * @returns {MatDialoRef}    The reference to the dialog.
-   */
-  openConfirm: function openConfirm(config) {
-    var dialogConfig = createConfig(config);
-    var dialogRef = this.dialogService.open(_confirm_dialog_confirm_dialog_component__WEBPACK_IMPORTED_MODULE_2__["FdsConfirmDialogComponent"], dialogConfig);
-    var confirmDialogComponent = dialogRef.componentInstance;
-    confirmDialogComponent.dialogRef = dialogRef;
-
-    if (config.title) {
-      confirmDialogComponent.title = config.title;
-    }
-
-    if (config.message) {
-      confirmDialogComponent.message = config.message;
-    }
-
-    if (config.acceptButton) {
-      confirmDialogComponent.acceptButton = config.acceptButton;
-    }
-
-    if (config.acceptButtonColor) {
-      confirmDialogComponent.acceptButtonColor = config.acceptButtonColor;
-    }
-
-    if (config.cancelButton) {
-      confirmDialogComponent.cancelButton = config.cancelButton;
-    }
-
-    if (config.cancelButtonColor) {
-      confirmDialogComponent.cancelButtonColor = config.cancelButtonColor;
-    }
-
-    return dialogRef;
-  }
-};
-FdsDialogService.parameters = [_angular_material_dialog__WEBPACK_IMPORTED_MODULE_1__["MatDialog"]];
-
-
-/***/ }),
-
-/***/ "./platform/core/flow-design-system.module.js":
-/*!****************************************************!*\
-  !*** ./platform/core/flow-design-system.module.js ***!
-  \****************************************************/
-/*! exports provided: default */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony import */ var jquery__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! jquery */ "./node_modules/jquery/dist/jquery.js");
-/* harmony import */ var jquery__WEBPACK_IMPORTED_MODULE_0___default = /*#__PURE__*/__webpack_require__.n(jquery__WEBPACK_IMPORTED_MODULE_0__);
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/* harmony import */ var _angular_flex_layout__WEBPACK_IMPORTED_MODULE_2__ = __webpack_require__(/*! @angular/flex-layout */ "./node_modules/@angular/flex-layout/esm5/flex-layout.es5.js");
-/* harmony import */ var _angular_common__WEBPACK_IMPORTED_MODULE_3__ = __webpack_require__(/*! @angular/common */ "./node_modules/@angular/common/fesm2015/common.js");
-/* harmony import */ var _angular_platform_browser__WEBPACK_IMPORTED_MODULE_4__ = __webpack_require__(/*! @angular/platform-browser */ "./node_modules/@angular/platform-browser/fesm2015/platform-browser.js");
-/* harmony import */ var _angular_platform_browser_animations__WEBPACK_IMPORTED_MODULE_5__ = __webpack_require__(/*! @angular/platform-browser/animations */ "./node_modules/@angular/platform-browser/fesm2015/animations.js");
-/* harmony import */ var _covalent_core_steps__WEBPACK_IMPORTED_MODULE_6__ = __webpack_require__(/*! @covalent/core/steps */ "./node_modules/@covalent/core/fesm2015/covalent-core-steps.js");
-/* harmony import */ var _covalent_core_data_table__WEBPACK_IMPORTED_MODULE_7__ = __webpack_require__(/*! @covalent/core/data-table */ "./node_modules/@covalent/core/fesm2015/covalent-core-data-table.js");
-/* harmony import */ var _covalent_core_common__WEBPACK_IMPORTED_MODULE_8__ = __webpack_require__(/*! @covalent/core/common */ "./node_modules/@covalent/core/fesm2015/covalent-core-common.js");
-/* harmony import */ var _covalent_core_chips__WEBPACK_IMPORTED_MODULE_9__ = __webpack_require__(/*! @covalent/core/chips */ "./node_modules/@covalent/core/fesm2015/covalent-core-chips.js");
-/* harmony import */ var _covalent_core_dialogs__WEBPACK_IMPORTED_MODULE_10__ = __webpack_require__(/*! @covalent/core/dialogs */ "./node_modules/@covalent/core/fesm2015/covalent-core-dialogs.js");
-/* harmony import */ var _covalent_core_paging__WEBPACK_IMPORTED_MODULE_11__ = __webpack_require__(/*! @covalent/core/paging */ "./node_modules/@covalent/core/fesm2015/covalent-core-paging.js");
-/* harmony import */ var _covalent_core_expansion_panel__WEBPACK_IMPORTED_MODULE_12__ = __webpack_require__(/*! @covalent/core/expansion-panel */ "./node_modules/@covalent/core/fesm2015/covalent-core-expansion-panel.js");
-/* harmony import */ var _angular_material_autocomplete__WEBPACK_IMPORTED_MODULE_13__ = __webpack_require__(/*! @angular/material/autocomplete */ "./node_modules/@angular/material/fesm2015/autocomplete.js");
-/* harmony import */ var _angular_material_button__WEBPACK_IMPORTED_MODULE_14__ = __webpack_require__(/*! @angular/material/button */ "./node_modules/@angular/material/fesm2015/button.js");
-/* harmony import */ var _angular_material_button_toggle__WEBPACK_IMPORTED_MODULE_15__ = __webpack_require__(/*! @angular/material/button-toggle */ "./node_modules/@angular/material/fesm2015/button-toggle.js");
-/* harmony import */ var _angular_material_card__WEBPACK_IMPORTED_MODULE_16__ = __webpack_require__(/*! @angular/material/card */ "./node_modules/@angular/material/fesm2015/card.js");
-/* harmony import */ var _angular_material_checkbox__WEBPACK_IMPORTED_MODULE_17__ = __webpack_require__(/*! @angular/material/checkbox */ "./node_modules/@angular/material/fesm2015/checkbox.js");
-/* harmony import */ var _angular_material_chips__WEBPACK_IMPORTED_MODULE_18__ = __webpack_require__(/*! @angular/material/chips */ "./node_modules/@angular/material/fesm2015/chips.js");
-/* harmony import */ var _angular_material_datepicker__WEBPACK_IMPORTED_MODULE_19__ = __webpack_require__(/*! @angular/material/datepicker */ "./node_modules/@angular/material/fesm2015/datepicker.js");
-/* harmony import */ var _angular_material_dialog__WEBPACK_IMPORTED_MODULE_20__ = __webpack_require__(/*! @angular/material/dialog */ "./node_modules/@angular/material/fesm2015/dialog.js");
-/* harmony import */ var _angular_material_expansion__WEBPACK_IMPORTED_MODULE_21__ = __webpack_require__(/*! @angular/material/expansion */ "./node_modules/@angular/material/fesm2015/expansion.js");
-/* harmony import */ var _angular_material_form_field__WEBPACK_IMPORTED_MODULE_22__ = __webpack_require__(/*! @angular/material/form-field */ "./node_modules/@angular/material/fesm2015/form-field.js");
-/* harmony import */ var _angular_material_grid_list__WEBPACK_IMPORTED_MODULE_23__ = __webpack_require__(/*! @angular/material/grid-list */ "./node_modules/@angular/material/fesm2015/grid-list.js");
-/* harmony import */ var _angular_material_icon__WEBPACK_IMPORTED_MODULE_24__ = __webpack_require__(/*! @angular/material/icon */ "./node_modules/@angular/material/fesm2015/icon.js");
-/* harmony import */ var _angular_material_input__WEBPACK_IMPORTED_MODULE_25__ = __webpack_require__(/*! @angular/material/input */ "./node_modules/@angular/material/fesm2015/input.js");
-/* harmony import */ var _angular_material_list__WEBPACK_IMPORTED_MODULE_26__ = __webpack_require__(/*! @angular/material/list */ "./node_modules/@angular/material/fesm2015/list.js");
-/* harmony import */ var _angular_material_menu__WEBPACK_IMPORTED_MODULE_27__ = __webpack_require__(/*! @angular/material/menu */ "./node_modules/@angular/material/fesm2015/menu.js");
-/* harmony import */ var _angular_material_progress_bar__WEBPACK_IMPORTED_MODULE_28__ = __webpack_require__(/*! @angular/material/progress-bar */ "./node_modules/@angular/material/fesm2015/progress-bar.js");
-/* harmony import */ var _angular_material_progress_spinner__WEBPACK_IMPORTED_MODULE_29__ = __webpack_require__(/*! @angular/material/progress-spinner */ "./node_modules/@angular/material/fesm2015/progress-spinner.js");
-/* harmony import */ var _angular_material_radio__WEBPACK_IMPORTED_MODULE_30__ = __webpack_require__(/*! @angular/material/radio */ "./node_modules/@angular/material/fesm2015/radio.js");
-/* harmony import */ var _angular_material_select__WEBPACK_IMPORTED_MODULE_31__ = __webpack_require__(/*! @angular/material/select */ "./node_modules/@angular/material/fesm2015/select.js");
-/* harmony import */ var _angular_material_slide_toggle__WEBPACK_IMPORTED_MODULE_32__ = __webpack_require__(/*! @angular/material/slide-toggle */ "./node_modules/@angular/material/fesm2015/slide-toggle.js");
-/* harmony import */ var _angular_material_slider__WEBPACK_IMPORTED_MODULE_33__ = __webpack_require__(/*! @angular/material/slider */ "./node_modules/@angular/material/fesm2015/slider.js");
-/* harmony import */ var _angular_material_sidenav__WEBPACK_IMPORTED_MODULE_34__ = __webpack_require__(/*! @angular/material/sidenav */ "./node_modules/@angular/material/fesm2015/sidenav.js");
-/* harmony import */ var _angular_material_snack_bar__WEBPACK_IMPORTED_MODULE_35__ = __webpack_require__(/*! @angular/material/snack-bar */ "./node_modules/@angular/material/fesm2015/snack-bar.js");
-/* harmony import */ var _angular_material_stepper__WEBPACK_IMPORTED_MODULE_36__ = __webpack_require__(/*! @angular/material/stepper */ "./node_modules/@angular/material/fesm2015/stepper.js");
-/* harmony import */ var _angular_material_tabs__WEBPACK_IMPORTED_MODULE_37__ = __webpack_require__(/*! @angular/material/tabs */ "./node_modules/@angular/material/fesm2015/tabs.js");
-/* harmony import */ var _angular_material_toolbar__WEBPACK_IMPORTED_MODULE_38__ = __webpack_require__(/*! @angular/material/toolbar */ "./node_modules/@angular/material/fesm2015/toolbar.js");
-/* harmony import */ var _angular_material_tooltip__WEBPACK_IMPORTED_MODULE_39__ = __webpack_require__(/*! @angular/material/tooltip */ "./node_modules/@angular/material/fesm2015/tooltip.js");
-/* harmony import */ var _angular_material_paginator__WEBPACK_IMPORTED_MODULE_40__ = __webpack_require__(/*! @angular/material/paginator */ "./node_modules/@angular/material/fesm2015/paginator.js");
-/* harmony import */ var _angular_material_sort__WEBPACK_IMPORTED_MODULE_41__ = __webpack_require__(/*! @angular/material/sort */ "./node_modules/@angular/material/fesm2015/sort.js");
-/* harmony import */ var _angular_material_table__WEBPACK_IMPORTED_MODULE_42__ = __webpack_require__(/*! @angular/material/table */ "./node_modules/@angular/material/fesm2015/table.js");
-/* harmony import */ var _dialogs_fds_dialogs_module__WEBPACK_IMPORTED_MODULE_43__ = __webpack_require__(/*! ./dialogs/fds-dialogs.module */ "./platform/core/dialogs/fds-dialogs.module.js");
-/* harmony import */ var _snackbars_fds_snackbars_module__WEBPACK_IMPORTED_MODULE_44__ = __webpack_require__(/*! ./snackbars/fds-snackbars.module */ "./platform/core/snackbars/fds-snackbars.module.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-
-/**
- * FlowDesignSystemModule constructor.
- *
- * @constructor
- */
-
-function FlowDesignSystemModule() {
-  jquery__WEBPACK_IMPORTED_MODULE_0___default()(document).ready(function () {
-    //add fds attr to body tag to allow fine grain style overrides
-    document.body.setAttribute('fds', ''); //override the hover styles for checkbox borders
-
-    jquery__WEBPACK_IMPORTED_MODULE_0___default()(document.body).on('mouseenter', '.mat-checkbox-inner-container', function () {
-      jquery__WEBPACK_IMPORTED_MODULE_0___default()(this).find('.mat-checkbox-frame').css('border-color', '#1491C1');
-    });
-    jquery__WEBPACK_IMPORTED_MODULE_0___default()(document.body).on('mouseleave', '.mat-checkbox-inner-container', function () {
-      jquery__WEBPACK_IMPORTED_MODULE_0___default()(this).find('.mat-checkbox-frame').css('border-color', '#DDDDDD');
-    });
-  });
-}
-
-FlowDesignSystemModule.prototype = {
-  constructor: FlowDesignSystemModule
-};
-FlowDesignSystemModule.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_1__["NgModule"]({
-  imports: [_angular_flex_layout__WEBPACK_IMPORTED_MODULE_2__["FlexLayoutModule"], _angular_platform_browser_animations__WEBPACK_IMPORTED_MODULE_5__["BrowserAnimationsModule"], _angular_common__WEBPACK_IMPORTED_MODULE_3__["CommonModule"], _angular_platform_browser__WEBPACK_IMPORTED_MODULE_4__["BrowserModule"], _angular_material_autocomplete__WEBPACK_IMPORTED_MODULE_13__["MatAutocompleteModule"], _angular_material_button__WEBPACK_IMPORTED_MODULE_14__["MatButtonModule"], _angular_material_ [...]
-  exports: [_angular_flex_layout__WEBPACK_IMPORTED_MODULE_2__["FlexLayoutModule"], _angular_platform_browser_animations__WEBPACK_IMPORTED_MODULE_5__["BrowserAnimationsModule"], _angular_common__WEBPACK_IMPORTED_MODULE_3__["CommonModule"], _angular_platform_browser__WEBPACK_IMPORTED_MODULE_4__["BrowserModule"], _angular_material_autocomplete__WEBPACK_IMPORTED_MODULE_13__["MatAutocompleteModule"], _angular_material_button__WEBPACK_IMPORTED_MODULE_14__["MatButtonModule"], _angular_material_ [...]
-})];
-/* harmony default export */ __webpack_exports__["default"] = (FlowDesignSystemModule);
-
-/***/ }),
-
-/***/ "./platform/core/index.js":
-/*!********************************!*\
-  !*** ./platform/core/index.js ***!
-  \********************************/
-/*! exports provided: FdsDialogsModule, FdsConfirmDialogComponent, FdsDialogActionsDirective, FdsDialogComponent, FdsDialogContentDirective, FdsDialogService, FdsDialogTitleDirective, IConfirmConfig, FdsCommonsModule, FdsStorageService, FdsAnimations, FdsCoasterComponent, FdsSnackBarActionsDirective, FdsSnackBarComponent, FdsSnackBarContentDirective, FdsSnackBarService, FdsSnackBarsModule, FdsSnackBarTitleDirective, ICoasterConfig, FdsCoreModule */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony import */ var _dialogs_fds_dialogs_module__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! ./dialogs/fds-dialogs.module */ "./platform/core/dialogs/fds-dialogs.module.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsDialogsModule", function() { return _dialogs_fds_dialogs_module__WEBPACK_IMPORTED_MODULE_0__["FdsDialogsModule"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsConfirmDialogComponent", function() { return _dialogs_fds_dialogs_module__WEBPACK_IMPORTED_MODULE_0__["FdsConfirmDialogComponent"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsDialogActionsDirective", function() { return _dialogs_fds_dialogs_module__WEBPACK_IMPORTED_MODULE_0__["FdsDialogActionsDirective"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsDialogComponent", function() { return _dialogs_fds_dialogs_module__WEBPACK_IMPORTED_MODULE_0__["FdsDialogComponent"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsDialogContentDirective", function() { return _dialogs_fds_dialogs_module__WEBPACK_IMPORTED_MODULE_0__["FdsDialogContentDirective"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsDialogService", function() { return _dialogs_fds_dialogs_module__WEBPACK_IMPORTED_MODULE_0__["FdsDialogService"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsDialogTitleDirective", function() { return _dialogs_fds_dialogs_module__WEBPACK_IMPORTED_MODULE_0__["FdsDialogTitleDirective"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "IConfirmConfig", function() { return _dialogs_fds_dialogs_module__WEBPACK_IMPORTED_MODULE_0__["IConfirmConfig"]; });
-
-/* harmony import */ var _common_fds_common_module__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! ./common/fds-common.module */ "./platform/core/common/fds-common.module.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsCommonsModule", function() { return _common_fds_common_module__WEBPACK_IMPORTED_MODULE_1__["FdsCommonsModule"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsStorageService", function() { return _common_fds_common_module__WEBPACK_IMPORTED_MODULE_1__["FdsStorageService"]; });
-
-/* harmony import */ var _common_fds_animations__WEBPACK_IMPORTED_MODULE_2__ = __webpack_require__(/*! ./common/fds.animations */ "./platform/core/common/fds.animations.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsAnimations", function() { return _common_fds_animations__WEBPACK_IMPORTED_MODULE_2__["default"]; });
-
-/* harmony import */ var _snackbars_fds_snackbars_module__WEBPACK_IMPORTED_MODULE_3__ = __webpack_require__(/*! ./snackbars/fds-snackbars.module */ "./platform/core/snackbars/fds-snackbars.module.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsCoasterComponent", function() { return _snackbars_fds_snackbars_module__WEBPACK_IMPORTED_MODULE_3__["FdsCoasterComponent"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarActionsDirective", function() { return _snackbars_fds_snackbars_module__WEBPACK_IMPORTED_MODULE_3__["FdsSnackBarActionsDirective"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarComponent", function() { return _snackbars_fds_snackbars_module__WEBPACK_IMPORTED_MODULE_3__["FdsSnackBarComponent"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarContentDirective", function() { return _snackbars_fds_snackbars_module__WEBPACK_IMPORTED_MODULE_3__["FdsSnackBarContentDirective"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarService", function() { return _snackbars_fds_snackbars_module__WEBPACK_IMPORTED_MODULE_3__["FdsSnackBarService"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarsModule", function() { return _snackbars_fds_snackbars_module__WEBPACK_IMPORTED_MODULE_3__["FdsSnackBarsModule"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarTitleDirective", function() { return _snackbars_fds_snackbars_module__WEBPACK_IMPORTED_MODULE_3__["FdsSnackBarTitleDirective"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "ICoasterConfig", function() { return _snackbars_fds_snackbars_module__WEBPACK_IMPORTED_MODULE_3__["ICoasterConfig"]; });
-
-/* harmony import */ var _flow_design_system_module__WEBPACK_IMPORTED_MODULE_4__ = __webpack_require__(/*! ./flow-design-system.module */ "./platform/core/flow-design-system.module.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsCoreModule", function() { return _flow_design_system_module__WEBPACK_IMPORTED_MODULE_4__["default"]; });
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-
-
-
-
-
-/***/ }),
-
-/***/ "./platform/core/snackbars/coaster/coaster.component.html":
-/*!****************************************************************!*\
-  !*** ./platform/core/snackbars/coaster/coaster.component.html ***!
-  \****************************************************************/
-/*! no static exports found */
-/***/ (function(module, exports) {
-
-module.exports = "<!--\nLicensed to the Apache Software Foundation (ASF) under one or more\ncontributor license agreements.  See the NOTICE file distributed with\nthis work for additional information regarding copyright ownership.\nThe ASF licenses this file to You under the Apache License, Version 2.0\n(the \"License\"); you may not use this file except in compliance with\nthe License.  You may obtain a copy of the License at\n\nhttp://www.apache.org/licenses/LICENSE-2.0\n\nUnless requi [...]
-
-/***/ }),
-
-/***/ "./platform/core/snackbars/coaster/coaster.component.js":
-/*!**************************************************************!*\
-  !*** ./platform/core/snackbars/coaster/coaster.component.js ***!
-  \**************************************************************/
-/*! exports provided: FdsCoasterComponent */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsCoasterComponent", function() { return FdsCoasterComponent; });
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/* harmony import */ var jquery__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! jquery */ "./node_modules/jquery/dist/jquery.js");
-/* harmony import */ var jquery__WEBPACK_IMPORTED_MODULE_1___default = /*#__PURE__*/__webpack_require__.n(jquery__WEBPACK_IMPORTED_MODULE_1__);
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-/**
- * FdsCoasterComponent constructor.
- *
- * @constructor
- */
-
-function FdsCoasterComponent() {
-  this.title = '';
-  this.message = '';
-  this.icon = '';
-  this.color = '';
-  this.snackBarRef = undefined;
-  this.viewContainerRef = undefined;
-}
-
-FdsCoasterComponent.prototype = {
-  constructor: FdsCoasterComponent,
-
-  /**
-   * Initialize the component.
-   */
-  ngAfterViewChecked: function ngAfterViewChecked() {
-    jquery__WEBPACK_IMPORTED_MODULE_1___default()('.fds-snackbar-wrapper').css('border-color', this.color);
-    jquery__WEBPACK_IMPORTED_MODULE_1___default()('.fds-snackbar-title').css('color', this.color);
-    jquery__WEBPACK_IMPORTED_MODULE_1___default()('.fds-coaster-icon').css('color', this.color);
-
-    if (this.icon) {
-      jquery__WEBPACK_IMPORTED_MODULE_1___default()('.fds-snackbar-wrapper').css('padding', '15px 15px 15px 45px');
-    } else {
-      jquery__WEBPACK_IMPORTED_MODULE_1___default()('.fds-snackbar-wrapper').css('padding', '15px 15px 15px 15px');
-    }
-  },
-
-  /**
-   * Close the snackbar and send a cancel response to any subscribers.
-   */
-  cancel: function cancel() {
-    this.snackBarRef.dismiss(false);
-  }
-};
-FdsCoasterComponent.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_0__["Component"]({
-  selector: 'fds-coaster',
-  template: __webpack_require__(/*! ./coaster.component.html */ "./platform/core/snackbars/coaster/coaster.component.html")})];
-FdsCoasterComponent.parameters = [];
-
-
-/***/ }),
-
-/***/ "./platform/core/snackbars/fds-snackbar.component.html":
-/*!*************************************************************!*\
-  !*** ./platform/core/snackbars/fds-snackbar.component.html ***!
-  \*************************************************************/
-/*! no static exports found */
-/***/ (function(module, exports) {
-
-module.exports = "<!--\nLicensed to the Apache Software Foundation (ASF) under one or more\ncontributor license agreements.  See the NOTICE file distributed with\nthis work for additional information regarding copyright ownership.\nThe ASF licenses this file to You under the Apache License, Version 2.0\n(the \"License\"); you may not use this file except in compliance with\nthe License.  You may obtain a copy of the License at\n\nhttp://www.apache.org/licenses/LICENSE-2.0\n\nUnless requi [...]
-
-/***/ }),
-
-/***/ "./platform/core/snackbars/fds-snackbar.component.js":
-/*!***********************************************************!*\
-  !*** ./platform/core/snackbars/fds-snackbar.component.js ***!
-  \***********************************************************/
-/*! exports provided: FdsSnackBarTitleDirective, FdsSnackBarContentDirective, FdsSnackBarActionsDirective, FdsSnackBarComponent */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarTitleDirective", function() { return FdsSnackBarTitleDirective; });
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarContentDirective", function() { return FdsSnackBarContentDirective; });
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarActionsDirective", function() { return FdsSnackBarActionsDirective; });
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarComponent", function() { return FdsSnackBarComponent; });
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-function FdsSnackBarTitleDirective() {}
-FdsSnackBarTitleDirective.prototype = {
-  contstructor: FdsSnackBarTitleDirective
-};
-FdsSnackBarTitleDirective.decorators = [{
-  type: _angular_core__WEBPACK_IMPORTED_MODULE_0__["Directive"],
-  args: [{
-    selector: 'fds-snackbar-title'
-  }]
-}];
-function FdsSnackBarContentDirective() {}
-FdsSnackBarContentDirective.prototype = {
-  contstructor: FdsSnackBarContentDirective
-};
-FdsSnackBarContentDirective.decorators = [{
-  type: _angular_core__WEBPACK_IMPORTED_MODULE_0__["Directive"],
-  args: [{
-    selector: 'fds-snackbar-content'
-  }]
-}];
-function FdsSnackBarActionsDirective() {}
-FdsSnackBarActionsDirective.prototype = {
-  contstructor: FdsSnackBarActionsDirective
-};
-FdsSnackBarActionsDirective.decorators = [{
-  type: _angular_core__WEBPACK_IMPORTED_MODULE_0__["Directive"],
-  args: [{
-    selector: 'fds-snackbar-actions'
-  }]
-}];
-/**
- * FdsSnackBarComponent constructor
- *
- * @constructor
- */
-
-function FdsSnackBarComponent() {
-  this.snackBarTitle = '';
-  this.snackBarContent = '';
-  this.snackBarActions = '';
-}
-
-FdsSnackBarComponent.prototype = {
-  constructor: FdsSnackBarComponent,
-
-  /**
-   * Respond after Angular projects external content into the component's view.
-   */
-  ngAfterContentInit: function ngAfterContentInit() {
-    if (this.snackBarTitle.length > 1) {
-      throw new Error('Duplicate fds-snackbar-title component at in fds-snackbar.');
-    }
-
-    if (this.snackBarContent.length > 1) {
-      throw new Error('Duplicate fds-snackbar-content component at in fds-snackbar.');
-    }
-
-    if (this.snackBarActions.length > 1) {
-      throw new Error('Duplicate fds-snackbar-actions component at in fds-snackbar.');
-    }
-  }
-};
-FdsSnackBarComponent.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_0__["Component"]({
-  selector: 'fds-snackbar',
-  template: __webpack_require__(/*! ./fds-snackbar.component.html */ "./platform/core/snackbars/fds-snackbar.component.html"),
-  queries: {
-    snackBarTitle: new _angular_core__WEBPACK_IMPORTED_MODULE_0__["ContentChildren"](FdsSnackBarTitleDirective),
-    snackBarContent: new _angular_core__WEBPACK_IMPORTED_MODULE_0__["ContentChildren"](FdsSnackBarContentDirective),
-    snackBarActions: new _angular_core__WEBPACK_IMPORTED_MODULE_0__["ContentChildren"](FdsSnackBarActionsDirective)
-  }
-})];
-FdsSnackBarComponent.parameters = [];
-
-
-/***/ }),
-
-/***/ "./platform/core/snackbars/fds-snackbars.module.js":
-/*!*********************************************************!*\
-  !*** ./platform/core/snackbars/fds-snackbars.module.js ***!
-  \*********************************************************/
-/*! exports provided: FdsSnackBarsModule, ICoasterConfig, FdsSnackBarService, FdsSnackBarComponent, FdsSnackBarTitleDirective, FdsSnackBarContentDirective, FdsSnackBarActionsDirective, FdsCoasterComponent */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarsModule", function() { return FdsSnackBarsModule; });
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/* harmony import */ var _angular_material_snack_bar__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! @angular/material/snack-bar */ "./node_modules/@angular/material/fesm2015/snack-bar.js");
-/* harmony import */ var _angular_material_input__WEBPACK_IMPORTED_MODULE_2__ = __webpack_require__(/*! @angular/material/input */ "./node_modules/@angular/material/fesm2015/input.js");
-/* harmony import */ var _angular_material_button__WEBPACK_IMPORTED_MODULE_3__ = __webpack_require__(/*! @angular/material/button */ "./node_modules/@angular/material/fesm2015/button.js");
-/* harmony import */ var _angular_material_icon__WEBPACK_IMPORTED_MODULE_4__ = __webpack_require__(/*! @angular/material/icon */ "./node_modules/@angular/material/fesm2015/icon.js");
-/* harmony import */ var _angular_flex_layout__WEBPACK_IMPORTED_MODULE_5__ = __webpack_require__(/*! @angular/flex-layout */ "./node_modules/@angular/flex-layout/esm5/flex-layout.es5.js");
-/* harmony import */ var _angular_common__WEBPACK_IMPORTED_MODULE_6__ = __webpack_require__(/*! @angular/common */ "./node_modules/@angular/common/fesm2015/common.js");
-/* harmony import */ var _angular_forms__WEBPACK_IMPORTED_MODULE_7__ = __webpack_require__(/*! @angular/forms */ "./node_modules/@angular/forms/fesm2015/forms.js");
-/* harmony import */ var _fds_snackbar_component__WEBPACK_IMPORTED_MODULE_8__ = __webpack_require__(/*! ./fds-snackbar.component */ "./platform/core/snackbars/fds-snackbar.component.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarComponent", function() { return _fds_snackbar_component__WEBPACK_IMPORTED_MODULE_8__["FdsSnackBarComponent"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarTitleDirective", function() { return _fds_snackbar_component__WEBPACK_IMPORTED_MODULE_8__["FdsSnackBarTitleDirective"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarContentDirective", function() { return _fds_snackbar_component__WEBPACK_IMPORTED_MODULE_8__["FdsSnackBarContentDirective"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarActionsDirective", function() { return _fds_snackbar_component__WEBPACK_IMPORTED_MODULE_8__["FdsSnackBarActionsDirective"]; });
-
-/* harmony import */ var _services_snackbar_service__WEBPACK_IMPORTED_MODULE_9__ = __webpack_require__(/*! ./services/snackbar.service */ "./platform/core/snackbars/services/snackbar.service.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "ICoasterConfig", function() { return _services_snackbar_service__WEBPACK_IMPORTED_MODULE_9__["ICoasterConfig"]; });
-
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarService", function() { return _services_snackbar_service__WEBPACK_IMPORTED_MODULE_9__["FdsSnackBarService"]; });
-
-/* harmony import */ var _coaster_coaster_component__WEBPACK_IMPORTED_MODULE_10__ = __webpack_require__(/*! ./coaster/coaster.component */ "./platform/core/snackbars/coaster/coaster.component.js");
-/* harmony reexport (safe) */ __webpack_require__.d(__webpack_exports__, "FdsCoasterComponent", function() { return _coaster_coaster_component__WEBPACK_IMPORTED_MODULE_10__["FdsCoasterComponent"]; });
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-
-
-
-
-
-
-
-
-
-var FDS_SNACKBARS = [_fds_snackbar_component__WEBPACK_IMPORTED_MODULE_8__["FdsSnackBarComponent"], _fds_snackbar_component__WEBPACK_IMPORTED_MODULE_8__["FdsSnackBarTitleDirective"], _fds_snackbar_component__WEBPACK_IMPORTED_MODULE_8__["FdsSnackBarActionsDirective"], _fds_snackbar_component__WEBPACK_IMPORTED_MODULE_8__["FdsSnackBarContentDirective"], _coaster_coaster_component__WEBPACK_IMPORTED_MODULE_10__["FdsCoasterComponent"]];
-var FDS_SNACKBARS_ENTRY_COMPONENTS = [_coaster_coaster_component__WEBPACK_IMPORTED_MODULE_10__["FdsCoasterComponent"]];
-/**
- * FdsSnackBarsModule constructor.
- *
- * @constructor
- */
-
-function FdsSnackBarsModule() {}
-
-FdsSnackBarsModule.prototype = {
-  constructor: FdsSnackBarsModule
-};
-FdsSnackBarsModule.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_0__["NgModule"]({
-  imports: [_angular_flex_layout__WEBPACK_IMPORTED_MODULE_5__["FlexLayoutModule"], _angular_forms__WEBPACK_IMPORTED_MODULE_7__["FormsModule"], _angular_common__WEBPACK_IMPORTED_MODULE_6__["CommonModule"], _angular_material_snack_bar__WEBPACK_IMPORTED_MODULE_1__["MatSnackBarModule"], _angular_material_input__WEBPACK_IMPORTED_MODULE_2__["MatInputModule"], _angular_material_button__WEBPACK_IMPORTED_MODULE_3__["MatButtonModule"], _angular_material_icon__WEBPACK_IMPORTED_MODULE_4__["MatIconMo [...]
-  declarations: [FDS_SNACKBARS],
-  exports: [FDS_SNACKBARS],
-  providers: [_services_snackbar_service__WEBPACK_IMPORTED_MODULE_9__["FdsSnackBarService"]],
-  entryComponents: [FDS_SNACKBARS_ENTRY_COMPONENTS]
-})];
-
-
-/***/ }),
-
-/***/ "./platform/core/snackbars/services/snackbar.service.js":
-/*!**************************************************************!*\
-  !*** ./platform/core/snackbars/services/snackbar.service.js ***!
-  \**************************************************************/
-/*! exports provided: ISnackBarConfig, ICoasterConfig, FdsSnackBarService */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "ISnackBarConfig", function() { return ISnackBarConfig; });
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "ICoasterConfig", function() { return ICoasterConfig; });
-/* harmony export (binding) */ __webpack_require__.d(__webpack_exports__, "FdsSnackBarService", function() { return FdsSnackBarService; });
-/* harmony import */ var jquery__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! jquery */ "./node_modules/jquery/dist/jquery.js");
-/* harmony import */ var jquery__WEBPACK_IMPORTED_MODULE_0___default = /*#__PURE__*/__webpack_require__.n(jquery__WEBPACK_IMPORTED_MODULE_0__);
-/* harmony import */ var _angular_material_snack_bar__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! @angular/material/snack-bar */ "./node_modules/@angular/material/fesm2015/snack-bar.js");
-/* harmony import */ var _coaster_coaster_component__WEBPACK_IMPORTED_MODULE_2__ = __webpack_require__(/*! ../coaster/coaster.component */ "./platform/core/snackbars/coaster/coaster.component.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-
-function ISnackBarConfig() {
-  this.title = '';
-  this.message = '';
-  this.snackBarRef = undefined;
-  this.viewContainerRef = undefined;
-}
-ISnackBarConfig.prototype = {
-  contstructor: ISnackBarConfig
-};
-jquery__WEBPACK_IMPORTED_MODULE_0___default.a.extend(ISnackBarConfig, _angular_material_snack_bar__WEBPACK_IMPORTED_MODULE_1__["MatSnackBarConfig"]);
-function ICoasterConfig() {
-  this.icon = '';
-  this.color = '';
-}
-ICoasterConfig.prototype = {
-  contstructor: ICoasterConfig
-};
-jquery__WEBPACK_IMPORTED_MODULE_0___default.a.extend(ICoasterConfig, ISnackBarConfig);
-/**
- * FdsSnackBarService constructor.
- *
- * @param MatSnackBar      The angular material MatSnackBar.
- * @constructor
- */
-
-function FdsSnackBarService(MatSnackBar) {
-  this.snackBarService = MatSnackBar;
-}
-FdsSnackBarService.prototype = {
-  contstructor: FdsSnackBarService,
-
-  /**
-   * Wrapper function over the open() method in MatSnackBar.
-   *
-   * @param message               The message to show in the snackbar.
-   * @param action                The label for the snackbar action.
-   * @param config                Additional configuration options for the snackbar.
-   *
-   * @returns {MatSnackBarRef}    The reference to the snackbar.
-   */
-  open: function open(message, action, config) {
-    return this.snackBarService.open(message, action, config);
-  },
-
-  /**
-   * Wrapper function over the openFromComponent() method in MatSnackBar.
-   * Opens a snackbar containing the given component.
-   *
-   * @param component     The angular ComponentType<T>.
-   * @param config        The angular material MatSnackBarConfig.
-   *
-   * @returns {MatSnackBarRef}    The reference to the snackbar.
-   */
-  openFromComponent: function openFromComponent(component, config) {
-    return this.snackBarService.openFromComponent(component, config);
-  },
-
-  /**
-   * Wrapper function over the dismiss() method in MatSnackBar.
-   * Dismisses the currently-open snackbar.
-   */
-  dismiss: function dismiss() {
-    this.snackBarService.dismiss();
-  },
-
-  /**
-   * Opens a coaster snackbar with the provided config.
-   *
-   * @param config     ICoasterConfig {
-   *                                      message?: string;
-   *                                      title?: string;
-   *                                      snackBarRef?: MatSnackBarRef;
-   *                                      viewContainerRef?: ViewContainerRef;
-   *                                      icon?: string;
-   *                                      color?: string;
-   *                                   }
-   *
-   * @returns {MatSnackBarRef}    The reference to the snackbar.
-   */
-  openCoaster: function openCoaster(config) {
-    var snackBarConfig = new ICoasterConfig();
-    snackBarConfig.verticalPosition = config.verticalPosition;
-    snackBarConfig.horizontalPosition = config.horizontalPosition;
-    snackBarConfig.duration = config.duration;
-    var snackBarRef = this.snackBarService.openFromComponent(_coaster_coaster_component__WEBPACK_IMPORTED_MODULE_2__["FdsCoasterComponent"], snackBarConfig);
-    var coasterComponent = snackBarRef.instance;
-    coasterComponent.snackBarRef = snackBarRef;
-
-    if (config.title) {
-      coasterComponent.title = config.title;
-    }
-
-    if (config.message) {
-      coasterComponent.message = config.message;
-    }
-
-    if (config.icon) {
-      coasterComponent.icon = config.icon;
-    }
-
-    if (config.color) {
-      coasterComponent.color = config.color;
-    }
-
-    return snackBarRef;
-  }
-};
-FdsSnackBarService.parameters = [_angular_material_snack_bar__WEBPACK_IMPORTED_MODULE_1__["MatSnackBar"]];
-
-/***/ }),
-
-/***/ "./webapp/components/flow-design-system/dialogs/demo/fds-demo-dialog.html":
-/*!********************************************************************************!*\
-  !*** ./webapp/components/flow-design-system/dialogs/demo/fds-demo-dialog.html ***!
-  \********************************************************************************/
-/*! no static exports found */
-/***/ (function(module, exports) {
-
-module.exports = "<!--\nLicensed to the Apache Software Foundation (ASF) under one or more\ncontributor license agreements.  See the NOTICE file distributed with\nthis work for additional information regarding copyright ownership.\nThe ASF licenses this file to You under the Apache License, Version 2.0\n(the \"License\"); you may not use this file except in compliance with\nthe License.  You may obtain a copy of the License at\n\nhttp://www.apache.org/licenses/LICENSE-2.0\n\nUnless requi [...]
-
-/***/ }),
-
-/***/ "./webapp/components/flow-design-system/dialogs/demo/fds-demo-dialog.js":
-/*!******************************************************************************!*\
-  !*** ./webapp/components/flow-design-system/dialogs/demo/fds-demo-dialog.js ***!
-  \******************************************************************************/
-/*! exports provided: default */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony import */ var _angular_material_dialog__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/material/dialog */ "./node_modules/@angular/material/fesm2015/dialog.js");
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-/**
- * NfRegistryEditBucketPolicy constructor.
- *
- * @param nfRegistryApi         The api service.
- * @param nfRegistryService     The nf-registry.service module.
- * @param activatedRoute        The angular route module.
- * @param matDialogRef          The angular material dialog ref.
- * @param data                  The data passed into this component.
- * @constructor
- */
-
-function FdsDemoDialog(matDialogRef, data) {
-  // Services
-  this.dialogRef = matDialogRef;
-  this.data = data;
-}
-
-FdsDemoDialog.prototype = {
-  constructor: FdsDemoDialog,
-
-  /**
-   * Cancel creation of a new policy and close dialog.
-   */
-  cancel: function cancel() {
-    this.dialogRef.close();
-  }
-};
-FdsDemoDialog.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_1__["Component"]({
-  template: __webpack_require__(/*! ./fds-demo-dialog.html */ "./webapp/components/flow-design-system/dialogs/demo/fds-demo-dialog.html")})];
-FdsDemoDialog.parameters = [_angular_material_dialog__WEBPACK_IMPORTED_MODULE_0__["MatDialogRef"], _angular_material_dialog__WEBPACK_IMPORTED_MODULE_0__["MAT_DIALOG_DATA"]];
-/* harmony default export */ __webpack_exports__["default"] = (FdsDemoDialog);
-
-/***/ }),
-
-/***/ "./webapp/components/flow-design-system/fds-demo.html":
-/*!************************************************************!*\
-  !*** ./webapp/components/flow-design-system/fds-demo.html ***!
-  \************************************************************/
-/*! no static exports found */
-/***/ (function(module, exports) {
-
-module.exports = "<!--\nLicensed to the Apache Software Foundation (ASF) under one or more\ncontributor license agreements.  See the NOTICE file distributed with\nthis work for additional information regarding copyright ownership.\nThe ASF licenses this file to You under the Apache License, Version 2.0\n(the \"License\"); you may not use this file except in compliance with\nthe License.  You may obtain a copy of the License at\n\nhttp://www.apache.org/licenses/LICENSE-2.0\n\nUnless requi [...]
-
-/***/ }),
-
-/***/ "./webapp/components/flow-design-system/fds-demo.js":
-/*!**********************************************************!*\
-  !*** ./webapp/components/flow-design-system/fds-demo.js ***!
-  \**********************************************************/
-/*! exports provided: default */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/* harmony import */ var _covalent_core_data_table__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! @covalent/core/data-table */ "./node_modules/@covalent/core/fesm2015/covalent-core-data-table.js");
-/* harmony import */ var _angular_material_dialog__WEBPACK_IMPORTED_MODULE_2__ = __webpack_require__(/*! @angular/material/dialog */ "./node_modules/@angular/material/fesm2015/dialog.js");
-/* harmony import */ var _nifi_fds_core__WEBPACK_IMPORTED_MODULE_3__ = __webpack_require__(/*! @nifi-fds/core */ "./platform/core/index.js");
-/* harmony import */ var webapp_services_fds_service_js__WEBPACK_IMPORTED_MODULE_4__ = __webpack_require__(/*! webapp/services/fds.service.js */ "./webapp/services/fds.service.js");
-/* harmony import */ var webapp_components_flow_design_system_dialogs_demo_fds_demo_dialog_js__WEBPACK_IMPORTED_MODULE_5__ = __webpack_require__(/*! webapp/components/flow-design-system/dialogs/demo/fds-demo-dialog.js */ "./webapp/components/flow-design-system/dialogs/demo/fds-demo-dialog.js");
-function _typeof(obj) { "@babel/helpers - typeof"; return _typeof = "function" == typeof Symbol && "symbol" == typeof Symbol.iterator ? function (obj) { return typeof obj; } : function (obj) { return obj && "function" == typeof Symbol && obj.constructor === Symbol && obj !== Symbol.prototype ? "symbol" : typeof obj; }, _typeof(obj); }
-
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the 'License'); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an 'AS IS' BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-
-
-
-
-
-var NUMBER_FORMAT = function NUMBER_FORMAT(v) {
-  return v;
-};
-
-var DECIMAL_FORMAT = function DECIMAL_FORMAT(v) {
-  return v.toFixed(2);
-};
-
-var date = new Date();
-/**
- * FdsDemo constructor.
- *
- * @param FdsSnackBarService    The FDS snack bar service module.
- * @param FdsService            The FDS service module.
- * @param dialog                The angular material dialog module.
- * @param TdDialogService       The covalent dialog service module.
- * @param TdDataTableService    The covalent data table service module.
- * @constructor
- */
-
-function FdsDemo(FdsSnackBarService, FdsService, dialog, TdDataTableService, FdsDialogService) {
-  this.fdsService = FdsService; //<editor-fold desc='Snack Bars'>
-
-  this.snackBarService = FdsSnackBarService; //</editor-fold>
-  //<editor-fold desc='Dialog'>
-
-  this.dialog = dialog; //</editor-fold>
-  //<editor-fold desc='Simple Dialogs'>
-
-  this.dialogService = FdsDialogService; //</editor-fold>
-  //<editor-fold desc='Expansion Panel'>
-
-  this.expandCollapseExpansion1Msg = 'No expanded/collapsed detected yet';
-  this.expansion1 = false;
-  this.disabled = false; //</editor-fold>
-  //<editor-fold desc='Autocomplete'>
-
-  this.currentState = '';
-  this.reactiveStates = '';
-  this.tdStates = [];
-  this.tdDisabled = false;
-  this.states = [{
-    code: 'AL',
-    name: 'Alabama'
-  }, {
-    code: 'AK',
-    name: 'Alaska'
-  }, {
-    code: 'AZ',
-    name: 'Arizona'
-  }, {
-    code: 'AR',
-    name: 'Arkansas'
-  }, {
-    code: 'CA',
-    name: 'California'
-  }, {
-    code: 'CO',
-    name: 'Colorado'
-  }, {
-    code: 'CT',
-    name: 'Connecticut'
-  }, {
-    code: 'DE',
-    name: 'Delaware'
-  }, {
-    code: 'FL',
-    name: 'Florida'
-  }, {
-    code: 'GA',
-    name: 'Georgia'
-  }, {
-    code: 'HI',
-    name: 'Hawaii'
-  }, {
-    code: 'ID',
-    name: 'Idaho'
-  }, {
-    code: 'IL',
-    name: 'Illinois'
-  }, {
-    code: 'IN',
-    name: 'Indiana'
-  }, {
-    code: 'IA',
-    name: 'Iowa'
-  }, {
-    code: 'KS',
-    name: 'Kansas'
-  }, {
-    code: 'KY',
-    name: 'Kentucky'
-  }, {
-    code: 'LA',
-    name: 'Louisiana'
-  }, {
-    code: 'ME',
-    name: 'Maine'
-  }, {
-    code: 'MD',
-    name: 'Maryland'
-  }, {
-    code: 'MA',
-    name: 'Massachusetts'
-  }, {
-    code: 'MI',
-    name: 'Michigan'
-  }, {
-    code: 'MN',
-    name: 'Minnesota'
-  }, {
-    code: 'MS',
-    name: 'Mississippi'
-  }, {
-    code: 'MO',
-    name: 'Missouri'
-  }, {
-    code: 'MT',
-    name: 'Montana'
-  }, {
-    code: 'NE',
-    name: 'Nebraska'
-  }, {
-    code: 'NV',
-    name: 'Nevada'
-  }, {
-    code: 'NH',
-    name: 'New Hampshire'
-  }, {
-    code: 'NJ',
-    name: 'New Jersey'
-  }, {
-    code: 'NM',
-    name: 'New Mexico'
-  }, {
-    code: 'NY',
-    name: 'New York'
-  }, {
-    code: 'NC',
-    name: 'North Carolina'
-  }, {
-    code: 'ND',
-    name: 'North Dakota'
-  }, {
-    code: 'OH',
-    name: 'Ohio'
-  }, {
-    code: 'OK',
-    name: 'Oklahoma'
-  }, {
-    code: 'OR',
-    name: 'Oregon'
-  }, {
-    code: 'PA',
-    name: 'Pennsylvania'
-  }, {
-    code: 'RI',
-    name: 'Rhode Island'
-  }, {
-    code: 'SC',
-    name: 'South Carolina'
-  }, {
-    code: 'SD',
-    name: 'South Dakota'
-  }, {
-    code: 'TN',
-    name: 'Tennessee'
-  }, {
-    code: 'TX',
-    name: 'Texas'
-  }, {
-    code: 'UT',
-    name: 'Utah'
-  }, {
-    code: 'VT',
-    name: 'Vermont'
-  }, {
-    code: 'VA',
-    name: 'Virginia'
-  }, {
-    code: 'WA',
-    name: 'Washington'
-  }, {
-    code: 'WV',
-    name: 'West Virginia'
-  }, {
-    code: 'WI',
-    name: 'Wisconsin'
-  }, {
-    code: 'WY',
-    name: 'Wyoming'
-  }]; //</editor-fold>
-  //<editor-fold desc='Searchable Expansion Panels'>
-
-  this.dataTableService = TdDataTableService;
-  this.droplets = [{
-    id: '23f6cc59-0156-1000-09b4-2b0610089090',
-    name: 'Decompression_Circular_Flow',
-    displayName: 'Decompressed Circular flow',
-    type: 'flow',
-    sublabel: 'A sublabel',
-    compliant: {
-      id: '25fd6vv87-3549-0001-05g6-4d4567890765',
-      label: 'Compliant',
-      type: 'certification'
-    },
-    fleet: {
-      id: '23f6cc59-3549-0001-05g6-4d4567890765',
-      label: 'Fleet',
-      type: 'certification'
-    },
-    prod: {
-      id: '52fd6vv87-3549-0001-05g6-4d4567890765',
-      label: 'Production Ready',
-      type: 'certification'
-    },
-    secure: {
-      id: '32f6cc59-3549-0001-05g6-4d4567890765',
-      label: 'Secure',
-      type: 'certification'
-    },
-    versions: [{
-      id: '23f6cc59-0156-1000-06b4-2b0810089090',
-      revision: '1',
-      dependentFlows: [{
-        id: '25fd6vv87-3549-0001-05g6-4d4567890765'
-      }],
-      created: date.setDate(date.getDate() - 1),
-      updated: new Date()
-    }, {
-      id: '25fd6vv87-3549-0001-05g6-4d4567890765',
-      revision: '2',
-      dependentFlows: [{
-        id: '23f6cc59-0156-1000-06b4-2b0810089090'
-      }],
-      created: new Date(),
-      updated: new Date()
-    }],
-    flows: [],
-    extensions: [],
-    assets: [],
-    actions: [{
-      'name': 'Delete',
-      'icon': 'fa fa-close',
-      'tooltip': 'Delete User'
-    }, {
-      'name': 'Manage',
-      'icon': 'fa fa-user',
-      'tooltip': 'Manage User'
-    }, {
-      'name': 'Action 3',
-      'icon': 'fa fa-question',
-      'tooltip': 'Whatever else we want to do...'
-    }]
-  }, {
-    id: '25fd6vv87-3249-0001-05g6-4d4767890765',
-    name: 'DateConversion',
-    displayName: 'Date conversion',
-    type: 'asset',
-    sublabel: 'A sublabel',
-    compliant: {
-      id: '25fd6vv34-3549-0001-05g6-4d4567890765',
-      label: 'Compliant',
-      type: 'certification'
-    },
-    prod: {
-      id: '52vn6vv87-3549-0001-05g6-4d4567890765',
-      label: 'Production Ready',
-      type: 'certification'
-    },
-    versions: [{
-      id: '23f6ic59-0156-1000-06b4-2b0810089090',
-      revision: '1',
-      dependentFlows: [{
-        id: '23f6cc19-0156-1000-06b4-2b0810089090'
-      }],
-      created: new Date(),
-      updated: new Date()
-    }],
-    flows: [],
-    extensions: [],
-    assets: [],
-    actions: [{
-      'name': 'Delete',
-      'icon': 'fa fa-close',
-      'tooltip': 'Delete User'
-    }]
-  }, {
-    id: '52fd6vv87-3294-0001-05g6-4d4767890765',
-    name: 'nifi-email-bundle',
-    displayName: 'nifi-email-bundle',
-    type: 'extension',
-    sublabel: 'A sublabel',
-    compliant: {
-      id: '33fd6vv87-3549-0001-05g6-4d4567890765',
-      label: 'Compliant',
-      test: {
-        label: 'test'
-      },
-      type: 'certification'
-    },
-    versions: [{
-      id: '23d3cc59-0156-1000-06b4-2b0810089090',
-      revision: '1',
-      dependentFlows: [{
-        id: '23f6cc89-0156-1000-06b4-2b0810089090'
-      }],
-      created: new Date(),
-      updated: new Date()
-    }],
-    flows: [],
-    extensions: [],
-    assets: [],
-    actions: [{
-      'name': 'Delete',
-      'icon': 'fa fa-close',
-      'tooltip': 'Delete User'
-    }, {
-      'name': 'Manage',
-      'icon': 'fa fa-user',
-      'tooltip': 'Manage User'
-    }]
-  }];
-  this.filteredDroplets = [];
-  this.dropletColumns = [{
-    name: 'id',
-    label: 'ID',
-    sortable: true
-  }, {
-    name: 'name',
-    label: 'Name',
-    sortable: true
-  }, {
-    name: 'displayName',
-    label: 'Display Name',
-    sortable: true
-  }, {
-    name: 'sublabel',
-    label: 'Label',
-    sortable: true
-  }, {
-    name: 'type',
-    label: 'Type',
-    sortable: true
-  }];
-  this.activeDropletColumn = this.dropletColumns[0];
-  this.autoCompleteDroplets = [];
-  this.dropletsSearchTerms = []; //</editor-fold>
-  //<editor-fold desc='Data Tables'>
-
-  this.data = [{
-    'id': 1,
-    'name': 'Frozen yogurt',
-    'type': 'Ice cream',
-    'calories': 159.0,
-    'fat': 6.0,
-    'carbs': 24.0,
-    'protein': 4.0,
-    'sodium': 87.0,
-    'calcium': 14.0,
-    'iron': 1.0,
-    'comments': 'I love froyo!',
-    'actions': [{
-      'name': 'Action 1',
-      'icon': 'fa fa-user',
-      'tooltip': 'Manage Users'
-    }, {
-      'name': 'Action 2',
-      'icon': 'fa fa-key',
-      'tooltip': 'Manage Permissions'
-    }]
-  }, {
-    'id': 2,
-    'name': 'Ice cream sandwich',
-    'type': 'Ice cream',
-    'calories': 237.0,
-    'fat': 9.0,
-    'carbs': 37.0,
-    'protein': 4.3,
-    'sodium': 129.0,
-    'calcium': 8.0,
-    'iron': 1.0,
-    'actions': [{
-      'name': 'Action 1',
-      'icon': 'fa fa-user',
-      'tooltip': 'Manage Users'
-    }, {
-      'name': 'Action 2',
-      'icon': 'fa fa-key',
-      'tooltip': 'Manage Permissions'
-    }, {
-      'name': 'Action 3',
-      'tooltip': 'Action 3'
-    }, {
-      'name': 'Action 4',
-      'disabled': true,
-      'tooltip': 'Action 4'
-    }, {
-      'name': 'Action 5',
-      'tooltip': 'Action 5'
-    }]
-  }, {
-    'id': 3,
-    'name': 'Eclair',
-    'type': 'Pastry',
-    'calories': 262.0,
-    'fat': 16.0,
-    'carbs': 24.0,
-    'protein': 6.0,
-    'sodium': 337.0,
-    'calcium': 6.0,
-    'iron': 7.0,
-    'actions': [{
-      'name': 'Action 1',
-      'icon': 'fa fa-user',
-      'tooltip': 'Manage Users'
-    }, {
-      'name': 'Action 2',
-      'icon': 'fa fa-key',
-      'tooltip': 'Manage Permissions'
-    }, {
-      'name': 'Action 3',
-      'tooltip': 'Action 3'
-    }, {
-      'name': 'Action 4',
-      'disabled': true,
-      'tooltip': 'Action 4'
-    }, {
-      'name': 'Action 5',
-      'tooltip': 'Action 5'
-    }]
-  }, {
-    'id': 4,
-    'name': 'Cupcake',
-    'type': 'Pastry',
-    'calories': 305.0,
-    'fat': 3.7,
-    'carbs': 67.0,
-    'protein': 4.3,
-    'sodium': 413.0,
-    'calcium': 3.0,
-    'iron': 8.0,
-    'actions': [{
-      'name': 'Action 1',
-      'icon': 'fa fa-user',
-      'tooltip': 'Manage Users'
-    }, {
-      'name': 'Action 2',
-      'icon': 'fa fa-key',
-      'tooltip': 'Manage Permissions'
-    }, {
-      'name': 'Action 3',
-      'tooltip': 'Action 3'
-    }, {
-      'name': 'Action 4',
-      'disabled': true,
-      'tooltip': 'Action 4'
-    }, {
-      'name': 'Action 5',
-      'tooltip': 'Action 5'
-    }]
-  }, {
-    'id': 5,
-    'name': 'Jelly bean',
-    'type': 'Candy',
-    'calories': 375.0,
-    'fat': 0.0,
-    'carbs': 94.0,
-    'protein': 0.0,
-    'sodium': 50.0,
-    'calcium': 0.0,
-    'iron': 0.0
-  }, {
-    'id': 6,
-    'name': 'Lollipop',
-    'type': 'Candy',
-    'calories': 392.0,
-    'fat': 0.2,
-    'carbs': 98.0,
-    'protein': 0.0,
-    'sodium': 38.0,
-    'calcium': 0.0,
-    'iron': 2.0
-  }, {
-    'id': 7,
-    'name': 'Honeycomb',
-    'type': 'Other',
-    'calories': 408.0,
-    'fat': 3.2,
-    'carbs': 87.0,
-    'protein': 6.5,
-    'sodium': 562.0,
-    'calcium': 0.0,
-    'iron': 45.0
-  }, {
-    'id': 8,
-    'name': 'Donut',
-    'type': 'Pastry',
-    'calories': 452.0,
-    'fat': 25.0,
-    'carbs': 51.0,
-    'protein': 4.9,
-    'sodium': 326.0,
-    'calcium': 2.0,
-    'iron': 22.0
-  }, {
-    'id': 9,
-    'name': 'KitKat',
-    'type': 'Candy',
-    'calories': 518.0,
-    'fat': 26.0,
-    'carbs': 65.0,
-    'protein': 7.0,
-    'sodium': 54.0,
-    'calcium': 12.0,
-    'iron': 6.0
-  }, {
-    'id': 10,
-    'name': 'Chocolate',
-    'type': 'Candy',
-    'calories': 518.0,
-    'fat': 26.0,
-    'carbs': 65.0,
-    'protein': 7.0,
-    'sodium': 54.0,
-    'calcium': 12.0,
-    'iron': 6.0
-  }, {
-    'id': 11,
-    'name': 'Chamoy',
-    'type': 'Candy',
-    'calories': 518.0,
-    'fat': 26.0,
-    'carbs': 65.0,
-    'protein': 7.0,
-    'sodium': 54.0,
-    'calcium': 12.0,
-    'iron': 6.0
-  }];
-  this.filteredData = this.data;
-  this.filteredTotal = this.data.length;
-  this.columns = [{
-    name: 'comments',
-    label: 'Comments',
-    width: 10
-  }, {
-    name: 'name',
-    label: 'Dessert (100g serving)',
-    sortable: true,
-    width: 10
-  }, {
-    name: 'type',
-    label: 'Type',
-    sortable: true,
-    width: 10
-  }, {
-    name: 'calories',
-    label: 'Calories',
-    numeric: true,
-    format: NUMBER_FORMAT,
-    sortable: true,
-    width: 10
-  }, {
-    name: 'fat',
-    label: 'Fat (g)',
-    numeric: true,
-    format: DECIMAL_FORMAT,
-    sortable: true,
-    width: 10
-  }, {
-    name: 'carbs',
-    label: 'Carbs (g)',
-    numeric: true,
-    format: NUMBER_FORMAT,
-    sortable: true,
-    width: 10
-  }, {
-    name: 'protein',
-    label: 'Protein (g)',
-    numeric: true,
-    format: DECIMAL_FORMAT,
-    sortable: true,
-    width: 10
-  }, {
-    name: 'sodium',
-    label: 'Sodium (mg)',
-    numeric: true,
-    format: NUMBER_FORMAT,
-    sortable: true,
-    width: 10
-  }, {
-    name: 'calcium',
-    label: 'Calcium (%)',
-    numeric: true,
-    format: NUMBER_FORMAT,
-    sortable: true,
-    width: 10
-  }, {
-    name: 'iron',
-    label: 'Iron (%)',
-    numeric: true,
-    format: NUMBER_FORMAT,
-    width: 10
-  }];
-  this.allRowsSelected = false;
-  this.autoCompleteData = [];
-  this.selectedRows = [];
-  this.searchTerm = [];
-  this.fromRow = 1;
-  this.currentPage = 1;
-  this.pageSize = 5;
-  this.pageCount = 0; //</editor-fold>
-  //<editor-fold desc='Chips $ Autocomplete'>
-
-  this.readOnly = false;
-  this.items = ['stepper', 'expansion-panel', 'markdown', 'highlight', 'loading', 'media', 'chips', 'http', 'json-formatter', 'pipes', 'need more?'];
-  this.itemsRequireMatch = this.items.slice(0, 6); //</editor-fold>
-  //<editor-fold desc='Radios'>
-
-  this.favoriteSeason = 'Autumn';
-  this.seasonOptions = ['Winter', 'Spring', 'Summer', 'Autumn']; //</editor-fold>
-  //<editor-fold desc='Select'>
-
-  this.selectedValue = '';
-  this.foods = [{
-    value: 'steak-0',
-    viewValue: 'Steak'
-  }, {
-    value: 'pizza-1',
-    viewValue: 'Pizza'
-  }, {
-    value: 'tacos-2',
-    viewValue: 'Tacos'
-  }]; //</editor-fold>
-  //<editor-fold desc='Checkbox'>
-
-  this.user = {
-    agreesToTOS: false
-  };
-  this.groceries = [{
-    bought: true,
-    name: 'Seitan'
-  }, {
-    bought: false,
-    name: 'Almond Meal Flour'
-  }, {
-    bought: false,
-    name: 'Organic Eggs'
-  }]; //</editor-fold>
-  //<editor-fold desc='Slide Toggle'>
-
-  this.systems = [{
-    name: 'Lights',
-    on: false,
-    color: 'primary'
-  }, {
-    name: 'Surround Sound',
-    on: true,
-    color: 'accent'
-  }, {
-    name: 'T.V.',
-    on: true,
-    color: 'warn'
-  }];
-  this.house = {
-    lockHouse: false
-  }; //</editor-fold>
-}
-
-FdsDemo.prototype = {
-  constructor: FdsDemo,
-  //<editor-fold desc='Autocomplete'>
-  displayFn: function displayFn(value) {
-    return value && _typeof(value) === 'object' ? value.name : value;
-  },
-  filterStates: function filterStates(val) {
-    return val ? this.states.filter(function (s) {
-      return s.name.match(new RegExp(val, 'gi'));
-    }) : this.states;
-  },
-  //</editor-fold>
-  //<editor-fold desc='Snack Bars'>
-  showSuccessSnackBar: function showSuccessSnackBar() {
-    this.snackBarService.openCoaster({
-      title: 'Success',
-      message: 'Some help text regarding the successful event.',
-      verticalPosition: 'top',
-      horizontalPosition: 'right',
-      icon: 'fa fa-check-circle-o',
-      color: '#1EB475',
-      duration: 3000
-    });
-  },
-  showWarnSnackBar: function showWarnSnackBar() {
-    this.snackBarService.openCoaster({
-      title: 'Warning',
-      message: 'Some help text regarding the warning.',
-      verticalPosition: 'top',
-      horizontalPosition: 'left',
-      icon: 'fa fa-exclamation-triangle',
-      color: '#E98A40',
-      duration: 3000
-    });
-  },
-  showErrorSnackBar: function showErrorSnackBar() {
-    this.snackBarService.openCoaster({
-      title: 'Error',
-      message: 'Some help text regarding the critical error. This coaster will stay open until closed with the `x` or if another coaster is created.',
-      verticalPosition: 'bottom',
-      horizontalPosition: 'right',
-      icon: 'fa fa-times-circle-o',
-      color: '#EF6162'
-    });
-  },
-  showRegularSnackBar: function showRegularSnackBar() {
-    this.snackBarService.openCoaster({
-      title: 'Regular',
-      message: 'Something interesting.',
-      verticalPosition: 'bottom',
-      horizontalPosition: 'left',
-      color: '#808793',
-      duration: 3000
-    });
-  },
-  //</editor-fold>
-  //<editor-fold desc='Dialog'>
-  openDialog: function openDialog() {
-    this.dialog.open(webapp_components_flow_design_system_dialogs_demo_fds_demo_dialog_js__WEBPACK_IMPORTED_MODULE_5__["default"]);
-  },
-  //</editor-fold>
-  //<editor-fold desc='Expansion Panel'>
-  toggleExpansion1: function toggleExpansion1() {
-    if (!this.disabled) {
-      this.expansion1 = !this.expansion1;
-    }
-  },
-  toggleDisabled: function toggleDisabled() {
-    this.disabled = !this.disabled;
-  },
-  expandExpansion1Event: function expandExpansion1Event() {
-    this.expandCollapseExpansion1Msg = 'Expand event emitted.';
-  },
-  collapseExpansion1Event: function collapseExpansion1Event() {
-    this.expandCollapseExpansion1Msg = 'Collapse event emitted.';
-  },
-  //</editor-fold>
-  //<editor-fold desc='Simple Dialogs'>
-  openAlert: function openAlert() {
-    this.dialogService.openAlert({
-      title: 'Alert',
-      disableClose: true,
-      message: 'This is how simple it is to create an alert with this wrapper service.'
-    });
-  },
-  openConfirm: function openConfirm() {
-    this.dialogService.openConfirm({
-      title: 'Confirm',
-      message: 'This is how simple it is to create a confirm with this wrapper service. Do you agree?',
-      cancelButton: 'Disagree',
-      acceptButton: 'Agree'
-    });
-  },
-  openPrompt: function openPrompt() {
-    this.dialogService.openPrompt({
-      title: 'Prompt',
-      message: 'This is how simple it is to create a prompt with this wrapper service. Prompt something.',
-      value: 'Populated value',
-      cancelButton: 'Cancel',
-      acceptButton: 'Ok'
-    });
-  },
-  //</editor-fold>
-  //<editor-fold desc='Searchable Expansion Panels'>
-  isDropletFilterChecked: function isDropletFilterChecked(term) {
-    return this.dropletsSearchTerms.indexOf(term) > -1;
-  },
-  getDropletTypeCount: function getDropletTypeCount(type) {
-    return this.filteredDroplets.filter(function (droplet) {
-      return droplet.type === type;
-    }).length;
-  },
-  getDropletCertificationCount: function getDropletCertificationCount(certification) {
-    return this.filteredDroplets.filter(function (droplet) {
-      return Object.keys(droplet).find(function (key) {
-        if (key === certification && droplet[certification].type === 'certification') {
-          return droplet;
-        }
-
-        return null;
-      });
-    }).length;
-  },
-  getSortBy: function getSortBy() {
-    var sortByColumnLabel;
-    var arrayLength = this.dropletColumns.length;
-
-    for (var i = 0; i < arrayLength; i++) {
-      if (this.dropletColumns[i].active === true) {
-        sortByColumnLabel = this.dropletColumns[i].label;
-        break;
-      }
-    }
-
-    return sortByColumnLabel;
-  },
-  sortDroplets: function sortDroplets(column) {
-    if (column.sortable === true) {
-      // toggle column sort order
-      column.sortOrder = column.sortOrder === 'ASC' ? 'DESC' : 'ASC';
-      var sortOrder = column.sortOrder;
-      this.filterDroplets(column.name, sortOrder); //only one column can be actively sorted so we reset all to inactive
-
-      this.dropletColumns.forEach(function (c) {
-        c.active = false;
-      }); //and set this column as the actively sorted column
-
-      column.active = true;
-      this.activeDropletColumn = column;
-    }
-  },
-  toggleDropletsFilter: function toggleDropletsFilter(searchTerm) {
-    var applySearchTerm = true; // check if the search term is already applied and remove it if true
-
-    if (this.dropletsSearchTerms.length > 0) {
-      var arrayLength = this.dropletsSearchTerms.length;
-
-      for (var i = 0; i < arrayLength; i++) {
-        var index = this.dropletsSearchTerms.indexOf(searchTerm);
-
-        if (index > -1) {
-          this.dropletsSearchTerms.splice(index, 1);
-          applySearchTerm = false;
-        }
-      }
-    } // if we just removed the search term do NOT apply it again
-
-
-    if (applySearchTerm) {
-      this.dropletsSearchTerms.push(searchTerm);
-    }
-
-    this.filterDroplets(this.activeDropletColumn.name, this.activeDropletColumn.sortOrder);
-  },
-  filterDroplets: function filterDroplets(sortBy, sortOrder) {
-    // if `sortOrder` is `undefined` then use 'ASC'
-    if (sortOrder === undefined) {
-      sortOrder = 'ASC';
-    } // if `sortBy` is `undefined` then find the first sortable column in this.dropletColumns
-
-
-    if (sortBy === undefined) {
-      var arrayLength = this.dropletColumns.length;
-
-      for (var i = 0; i < arrayLength; i++) {
-        if (this.dropletColumns[i].sortable === true) {
-          sortBy = this.dropletColumns[i].name;
-          this.activeDropletColumn = this.dropletColumns[i]; //only one column can be actively sorted so we reset all to inactive
-
-          this.dropletColumns.forEach(function (c) {
-            c.active = false;
-          }); //and set this column as the actively sorted column
-
-          this.dropletColumns[i].active = true;
-          this.dropletColumns[i].sortOrder = sortOrder;
-          break;
-        }
-      }
-    }
-
-    var newData = this.droplets;
-
-    for (var _i = 0; _i < this.dropletsSearchTerms.length; _i++) {
-      newData = this.filterData(newData, this.dropletsSearchTerms[_i], true, this.activeDropletColumn.name);
-    }
-
-    newData = this.dataTableService.sortData(newData, sortBy, sortOrder);
-    this.filteredDroplets = newData;
-    this.getAutoCompleteDroplets();
-  },
-  getAutoCompleteDroplets: function getAutoCompleteDroplets() {
-    var self = this;
-    this.autoCompleteDroplets = [];
-    this.dropletColumns.forEach(function (c) {
-      self.filteredDroplets.forEach(function (r) {
-        return r[c.name.toLowerCase()] ? self.autoCompleteDroplets.push(r[c.name.toLowerCase()].toString()) : '';
-      });
-    });
-  },
-  //</editor-fold>
-  filterData: function filterData(data, searchTerm, ignoreCase) {
-    var field = '';
-
-    if (searchTerm.indexOf(':') > -1) {
-      field = searchTerm.split(':')[0].trim();
-      searchTerm = searchTerm.split(':')[1].trim();
-    }
-
-    var filter = searchTerm ? ignoreCase ? searchTerm.toLowerCase() : searchTerm : '';
-
-    if (filter) {
-      data = data.filter(function (item) {
-        var res = Object.keys(item).find(function (key) {
-          if (field.indexOf('.') > -1) {
-            var objArray = field.split('.');
-            var obj = item;
-            var arrayLength = objArray.length;
-
-            for (var i = 0; i < arrayLength; i++) {
-              try {
-                obj = obj[objArray[i]];
-              } catch (e) {
-                return false;
-              }
-            }
-
-            var _preItemValue = '' + obj;
-
-            var _itemValue = ignoreCase ? _preItemValue.toLowerCase() : _preItemValue;
-
-            return _itemValue.indexOf(filter) > -1;
-          }
-
-          if (key !== field && field !== '') {
-            return false;
-          }
-
-          var preItemValue = '' + item[key];
-          var itemValue = ignoreCase ? preItemValue.toLowerCase() : preItemValue;
-          return itemValue.indexOf(filter) > -1;
-        });
-        return !(typeof res === 'undefined');
-      });
-    }
-
-    return data;
-  },
-  //<editor-fold desc='Data Tables'>
-  sort: function sort(sortEvent, column) {
-    if (column.sortable) {
-      var sortBy = column.name;
-      column.sortOrder = column.sortOrder === 'ASC' ? 'DESC' : 'ASC';
-      var sortOrder = column.sortOrder;
-      this.filter(sortBy, sortOrder); //only one column can be actively sorted so we reset all to inactive
-
-      this.columns.forEach(function (c) {
-        c.active = false;
-      }); //and set this column as the actively sorted column
-
-      column.active = true;
-    }
-  },
-  searchRemove: function searchRemove(searchTerm) {
-    //only remove the first occurrence of the search term
-    var index = this.searchTerm.indexOf(searchTerm);
-
-    if (index !== -1) {
-      this.searchTerm.splice(index, 1);
-    }
-
-    this.fromRow = 1;
-    this.currentPage = 1;
-    this.filter();
-  },
-  searchAdd: function searchAdd(searchTerm) {
-    this.searchTerm.push(searchTerm);
-    this.fromRow = 1;
-    this.currentPage = 1;
-    this.filter();
-  },
-  page: function page(pagingEvent) {
-    this.fromRow = pagingEvent.fromRow;
-    this.currentPage = pagingEvent.page;
-    this.pageSize = pagingEvent.pageSize;
-    this.allRowsSelected = false;
-    this.filter();
-  },
-  filter: function filter(sortBy, sortOrder) {
-    if (this.allRowsSelected) {
-      this.toggleSelectAll();
-    }
-
-    this.deselectAll();
-    var newData = this.data;
-
-    for (var i = 0; i < this.searchTerm.length; i++) {
-      newData = this.filterData(newData, this.searchTerm[i], true);
-    }
-
-    this.filteredTotal = newData.length;
-    newData = this.dataTableService.sortData(newData, sortBy, sortOrder);
-    this.pageCount = newData.length;
-    newData = this.dataTableService.pageData(newData, this.fromRow, this.currentPage * this.pageSize);
-    this.filteredData = newData;
-    this.getAutoCompleteData();
-  },
-  toggleSelect: function toggleSelect() {
-    if (this.allFilteredRowsSelected()) {
-      this.allRowsSelected = true;
-    } else {
-      this.allRowsSelected = false;
-    }
-  },
-  toggleSelectAll: function toggleSelectAll() {
-    if (this.allRowsSelected) {
-      this.selectAll();
-    } else {
-      this.deselectAll();
-    }
-  },
-  selectAll: function selectAll() {
-    this.filteredData.forEach(function (c) {
-      c.checked = true;
-    });
-  },
-  deselectAll: function deselectAll() {
-    this.filteredData.forEach(function (c) {
-      c.checked = false;
-    });
-  },
-  allFilteredRowsSelected: function allFilteredRowsSelected() {
-    var allFilteredRowsSelected = true;
-    this.filteredData.forEach(function (c) {
-      if (c.checked === undefined || c.checked === false) {
-        allFilteredRowsSelected = false;
-      }
-    });
-    return allFilteredRowsSelected;
-  },
-  areTooltipsOn: function areTooltipsOn() {
-    return this.columns[0].hasOwnProperty('tooltip');
-  },
-  toggleTooltips: function toggleTooltips() {
-    if (this.columns[0].tooltip) {
-      this.columns.forEach(function (c) {
-        delete c.tooltip;
-      });
-    } else {
-      this.columns.forEach(function (c) {
-        c.tooltip = 'This is ' + c.label + '!';
-      });
-    }
-  },
-  openDataTablePrompt: function openDataTablePrompt(row, name) {
-    this.dialogService.openPrompt({
-      message: 'Enter comment?',
-      value: row[name]
-    }).afterClosed().subscribe(function (value) {
-      if (value !== undefined) {
-        row[name] = value;
-      }
-    });
-  },
-  getAutoCompleteData: function getAutoCompleteData() {
-    var self = this;
-    this.autoCompleteData = [];
-    this.columns.forEach(function (c) {
-      self.filteredData.forEach(function (r) {
-        return r[c.name.toLowerCase()] ? self.autoCompleteData.push(r[c.name.toLowerCase()].toString()) : '';
-      });
-    });
-  },
-  //</editor-fold>
-  //<editor-fold desc='Chips $ Autocomplete'>
-  toggleReadOnly: function toggleReadOnly() {
-    this.readOnly = !this.readOnly;
-  },
-  //</editor-fold>
-  //<editor-fold desc='Life Cycle Listeners'>
-
-  /**
-   * Initialize the component
-   */
-  ngOnInit: function ngOnInit() {
-    this.filter();
-    this.filterDroplets();
-  },
-
-  /**
-   * Respond after Angular checks the component's views and child views
-   */
-  ngAfterViewChecked: function ngAfterViewChecked() {
-    this.fdsService.inProgress = false;
-  } //</editor-fold>
-
-};
-FdsDemo.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_0__["Component"]({
-  template: __webpack_require__(/*! ./fds-demo.html */ "./webapp/components/flow-design-system/fds-demo.html"),
-  animations: [_nifi_fds_core__WEBPACK_IMPORTED_MODULE_3__["FdsAnimations"].slideInLeftAnimation],
-  host: {
-    '[@routeAnimation]': 'routeAnimation'
-  }
-})];
-FdsDemo.parameters = [_nifi_fds_core__WEBPACK_IMPORTED_MODULE_3__["FdsSnackBarService"], webapp_services_fds_service_js__WEBPACK_IMPORTED_MODULE_4__["default"], _angular_material_dialog__WEBPACK_IMPORTED_MODULE_2__["MatDialog"], _covalent_core_data_table__WEBPACK_IMPORTED_MODULE_1__["TdDataTableService"], _nifi_fds_core__WEBPACK_IMPORTED_MODULE_3__["FdsDialogService"]];
-/* harmony default export */ __webpack_exports__["default"] = (FdsDemo);
-
-/***/ }),
-
-/***/ "./webapp/fds-bootstrap.js":
-/*!*********************************!*\
-  !*** ./webapp/fds-bootstrap.js ***!
-  \*********************************/
-/*! no exports provided */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony import */ var core_js__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! core-js */ "./node_modules/core-js/index.js");
-/* harmony import */ var core_js__WEBPACK_IMPORTED_MODULE_0___default = /*#__PURE__*/__webpack_require__.n(core_js__WEBPACK_IMPORTED_MODULE_0__);
-/* harmony import */ var zone_js__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! zone.js */ "./node_modules/zone.js/fesm2015/zone.js");
-/* harmony import */ var zone_js__WEBPACK_IMPORTED_MODULE_1___default = /*#__PURE__*/__webpack_require__.n(zone_js__WEBPACK_IMPORTED_MODULE_1__);
-/* harmony import */ var jquery__WEBPACK_IMPORTED_MODULE_2__ = __webpack_require__(/*! jquery */ "./node_modules/jquery/dist/jquery.js");
-/* harmony import */ var jquery__WEBPACK_IMPORTED_MODULE_2___default = /*#__PURE__*/__webpack_require__.n(jquery__WEBPACK_IMPORTED_MODULE_2__);
-/* harmony import */ var _angular_platform_browser_dynamic__WEBPACK_IMPORTED_MODULE_3__ = __webpack_require__(/*! @angular/platform-browser-dynamic */ "./node_modules/@angular/platform-browser-dynamic/fesm2015/platform-browser-dynamic.js");
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_4__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/* harmony import */ var webapp_fds_module_js__WEBPACK_IMPORTED_MODULE_5__ = __webpack_require__(/*! webapp/fds.module.js */ "./webapp/fds.module.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-
-
-
- // Comment out this line when developing to assert for unidirectional data flow
-
-Object(_angular_core__WEBPACK_IMPORTED_MODULE_4__["enableProdMode"])(); // Get the locale id from the global
-
-var locale = navigator.language.toLowerCase();
-var providers = []; // No locale or U.S. English: no translation providers so go ahead and bootstrap the app
-
-if (!locale || locale === 'en-us') {
-  Object(_angular_platform_browser_dynamic__WEBPACK_IMPORTED_MODULE_3__["platformBrowserDynamic"])().bootstrapModule(webapp_fds_module_js__WEBPACK_IMPORTED_MODULE_5__["default"], {
-    providers: providers
-  });
-} else {
-  //load the translation providers and bootstrap the module
-  var translationFile = './webapp/locale/messages.' + locale + '.xlf';
-  jquery__WEBPACK_IMPORTED_MODULE_2___default.a.ajax({
-    url: translationFile,
-    dataType: 'text'
-  }).done(function (translations) {
-    // add providers if translation file for locale is loaded
-    if (translations) {
-      providers.push({
-        provide: _angular_core__WEBPACK_IMPORTED_MODULE_4__["TRANSLATIONS"],
-        useValue: translations
-      });
-      providers.push({
-        provide: _angular_core__WEBPACK_IMPORTED_MODULE_4__["TRANSLATIONS_FORMAT"],
-        useValue: 'xlf'
-      });
-      providers.push({
-        provide: _angular_core__WEBPACK_IMPORTED_MODULE_4__["LOCALE_ID"],
-        useValue: locale
-      });
-    }
-
-    Object(_angular_platform_browser_dynamic__WEBPACK_IMPORTED_MODULE_3__["platformBrowserDynamic"])().bootstrapModule(webapp_fds_module_js__WEBPACK_IMPORTED_MODULE_5__["default"], {
-      providers: providers
-    });
-  }).fail(function () {
-    // was this a country specific locale? if so, try to get the generic version of the language
-    var localeTokens = locale.split('-');
-
-    if (localeTokens.length === 2) {
-      translationFile = './webapp/locale/messages.' + localeTokens[0] + '.xlf';
-      jquery__WEBPACK_IMPORTED_MODULE_2___default.a.ajax({
-        url: translationFile,
-        dataType: 'text'
-      }).done(function (translations) {
-        // add providers if translation file for locale is loaded
-        if (translations) {
-          providers.push({
-            provide: _angular_core__WEBPACK_IMPORTED_MODULE_4__["TRANSLATIONS"],
-            useValue: translations
-          });
-          providers.push({
-            provide: _angular_core__WEBPACK_IMPORTED_MODULE_4__["TRANSLATIONS_FORMAT"],
-            useValue: 'xlf'
-          });
-          providers.push({
-            provide: _angular_core__WEBPACK_IMPORTED_MODULE_4__["LOCALE_ID"],
-            useValue: localeTokens[0]
-          });
-        }
-
-        Object(_angular_platform_browser_dynamic__WEBPACK_IMPORTED_MODULE_3__["platformBrowserDynamic"])().bootstrapModule(webapp_fds_module_js__WEBPACK_IMPORTED_MODULE_5__["default"], {
-          providers: providers
-        });
-      }).fail(function () {
-        Object(_angular_platform_browser_dynamic__WEBPACK_IMPORTED_MODULE_3__["platformBrowserDynamic"])().bootstrapModule(webapp_fds_module_js__WEBPACK_IMPORTED_MODULE_5__["default"], {
-          providers: providers
-        });
-      });
-    } else {
-      Object(_angular_platform_browser_dynamic__WEBPACK_IMPORTED_MODULE_3__["platformBrowserDynamic"])().bootstrapModule(webapp_fds_module_js__WEBPACK_IMPORTED_MODULE_5__["default"], {
-        providers: providers
-      });
-    }
-  });
-}
-
-/***/ }),
-
-/***/ "./webapp/fds.html":
-/*!*************************!*\
-  !*** ./webapp/fds.html ***!
-  \*************************/
-/*! no static exports found */
-/***/ (function(module, exports) {
-
-module.exports = "<!--\nLicensed to the Apache Software Foundation (ASF) under one or more\ncontributor license agreements.  See the NOTICE file distributed with\nthis work for additional information regarding copyright ownership.\nThe ASF licenses this file to You under the Apache License, Version 2.0\n(the \"License\"); you may not use this file except in compliance with\nthe License.  You may obtain a copy of the License at\n\nhttp://www.apache.org/licenses/LICENSE-2.0\n\nUnless requi [...]
-
-/***/ }),
-
-/***/ "./webapp/fds.js":
-/*!***********************!*\
-  !*** ./webapp/fds.js ***!
-  \***********************/
-/*! exports provided: default */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/* harmony import */ var webapp_services_fds_service_js__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! webapp/services/fds.service.js */ "./webapp/services/fds.service.js");
-/* harmony import */ var _nifi_fds_core__WEBPACK_IMPORTED_MODULE_2__ = __webpack_require__(/*! @nifi-fds/core */ "./platform/core/index.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-
-/**
- * Fds constructor.
- *
- * @param fdsService            The fds service.
- * @param changeDetectorRef     The change detector ref.
- * @constructor
- */
-
-function Fds(fdsService, changeDetectorRef) {
-  this.fdsService = fdsService;
-  this.cd = changeDetectorRef;
-}
-
-Fds.prototype = {
-  constructor: Fds,
-
-  /**
-   * Initialize the component
-   */
-  ngOnInit: function ngOnInit() {
-    this.fdsService.sidenav = this.sidenav; //ngCore.ViewChild
-  },
-
-  /**
-   * Since the child views are updating the fdsService values that are used to display
-   * the breadcrumbs in this component's view we need to manually detect changes at the correct
-   * point in the lifecycle.
-   */
-  ngAfterViewChecked: function ngAfterViewChecked() {
-    this.cd.detectChanges();
-  }
-};
-Fds.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_0__["Component"]({
-  selector: 'fds-app',
-  template: __webpack_require__(/*! ./fds.html */ "./webapp/fds.html"),
-  queries: {
-    sidenav: new _angular_core__WEBPACK_IMPORTED_MODULE_0__["ViewChild"]('sidenav')
-  },
-  animations: [_nifi_fds_core__WEBPACK_IMPORTED_MODULE_2__["FdsAnimations"].flyInOutAnimation]
-})];
-Fds.parameters = [webapp_services_fds_service_js__WEBPACK_IMPORTED_MODULE_1__["default"], _angular_core__WEBPACK_IMPORTED_MODULE_0__["ChangeDetectorRef"]];
-/* harmony default export */ __webpack_exports__["default"] = (Fds);
-
-/***/ }),
-
-/***/ "./webapp/fds.module.js":
-/*!******************************!*\
-  !*** ./webapp/fds.module.js ***!
-  \******************************/
-/*! exports provided: default */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony import */ var _angular_core__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/core */ "./node_modules/@angular/core/fesm2015/core.js");
-/* harmony import */ var _nifi_fds_core__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! @nifi-fds/core */ "./platform/core/index.js");
-/* harmony import */ var webapp_fds_routes_js__WEBPACK_IMPORTED_MODULE_2__ = __webpack_require__(/*! webapp/fds.routes.js */ "./webapp/fds.routes.js");
-/* harmony import */ var webapp_fds_js__WEBPACK_IMPORTED_MODULE_3__ = __webpack_require__(/*! webapp/fds.js */ "./webapp/fds.js");
-/* harmony import */ var webapp_components_flow_design_system_fds_demo_js__WEBPACK_IMPORTED_MODULE_4__ = __webpack_require__(/*! webapp/components/flow-design-system/fds-demo.js */ "./webapp/components/flow-design-system/fds-demo.js");
-/* harmony import */ var webapp_components_flow_design_system_dialogs_demo_fds_demo_dialog_js__WEBPACK_IMPORTED_MODULE_5__ = __webpack_require__(/*! webapp/components/flow-design-system/dialogs/demo/fds-demo-dialog.js */ "./webapp/components/flow-design-system/dialogs/demo/fds-demo-dialog.js");
-/* harmony import */ var webapp_services_fds_service_js__WEBPACK_IMPORTED_MODULE_6__ = __webpack_require__(/*! webapp/services/fds.service.js */ "./webapp/services/fds.service.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-
-
-
-
-
-
-function FdsModule() {}
-
-FdsModule.prototype = {
-  constructor: FdsModule
-};
-FdsModule.annotations = [new _angular_core__WEBPACK_IMPORTED_MODULE_0__["NgModule"]({
-  imports: [_nifi_fds_core__WEBPACK_IMPORTED_MODULE_1__["FdsCoreModule"], webapp_fds_routes_js__WEBPACK_IMPORTED_MODULE_2__["default"]],
-  declarations: [webapp_fds_js__WEBPACK_IMPORTED_MODULE_3__["default"], webapp_components_flow_design_system_fds_demo_js__WEBPACK_IMPORTED_MODULE_4__["default"], webapp_components_flow_design_system_dialogs_demo_fds_demo_dialog_js__WEBPACK_IMPORTED_MODULE_5__["default"]],
-  entryComponents: [webapp_components_flow_design_system_dialogs_demo_fds_demo_dialog_js__WEBPACK_IMPORTED_MODULE_5__["default"]],
-  providers: [webapp_services_fds_service_js__WEBPACK_IMPORTED_MODULE_6__["default"]],
-  bootstrap: [webapp_fds_js__WEBPACK_IMPORTED_MODULE_3__["default"]]
-})];
-/* harmony default export */ __webpack_exports__["default"] = (FdsModule);
-
-/***/ }),
-
-/***/ "./webapp/fds.routes.js":
-/*!******************************!*\
-  !*** ./webapp/fds.routes.js ***!
-  \******************************/
-/*! exports provided: default */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony import */ var _angular_router__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @angular/router */ "./node_modules/@angular/router/fesm2015/router.js");
-/* harmony import */ var webapp_components_flow_design_system_fds_demo_js__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! webapp/components/flow-design-system/fds-demo.js */ "./webapp/components/flow-design-system/fds-demo.js");
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the "License"); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-var FdsRoutes = _angular_router__WEBPACK_IMPORTED_MODULE_0__["RouterModule"].forRoot([{
-  path: '',
-  component: webapp_components_flow_design_system_fds_demo_js__WEBPACK_IMPORTED_MODULE_1__["default"]
-}], {
-  useHash: true
-});
-/* harmony default export */ __webpack_exports__["default"] = (FdsRoutes);
-
-/***/ }),
-
-/***/ "./webapp/services/fds.service.js":
-/*!****************************************!*\
-  !*** ./webapp/services/fds.service.js ***!
-  \****************************************/
-/*! exports provided: default */
-/***/ (function(module, __webpack_exports__, __webpack_require__) {
-
-"use strict";
-__webpack_require__.r(__webpack_exports__);
-/* harmony import */ var _covalent_core_data_table__WEBPACK_IMPORTED_MODULE_0__ = __webpack_require__(/*! @covalent/core/data-table */ "./node_modules/@covalent/core/fesm2015/covalent-core-data-table.js");
-/* harmony import */ var _nifi_fds_core__WEBPACK_IMPORTED_MODULE_1__ = __webpack_require__(/*! @nifi-fds/core */ "./platform/core/index.js");
-/* harmony import */ var _package_json__WEBPACK_IMPORTED_MODULE_2__ = __webpack_require__(/*! ../../package.json */ "./package.json");
-var _package_json__WEBPACK_IMPORTED_MODULE_2___namespace = /*#__PURE__*/__webpack_require__.t(/*! ../../package.json */ "./package.json", 1);
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the 'License'); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an 'AS IS' BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-
-
-
-/**
- * FdsService constructor.
- *
- * @param tdDataTableService    The covalent data table service module.
- * @param fdsDialogService      The FDS dialog service.
- * @param fdsSnackBarService    The FDS snack bar service module.
- * @constructor
- */
-
-function FdsService(tdDataTableService, fdsDialogService, fdsSnackBarService) {
-  // Services
-  this.dialogService = fdsDialogService;
-  this.snackBarService = fdsSnackBarService;
-  this.dataTableService = tdDataTableService; // General
-
-  this.title = 'Apache NiFi Flow Design System Demo v' + _package_json__WEBPACK_IMPORTED_MODULE_2__["version"];
-  this.inProgress = true;
-  this.perspective = '';
-}
-
-FdsService.prototype = {
-  constructor: FdsService
-};
-FdsService.parameters = [_covalent_core_data_table__WEBPACK_IMPORTED_MODULE_0__["TdDataTableService"], _nifi_fds_core__WEBPACK_IMPORTED_MODULE_1__["FdsDialogService"], _nifi_fds_core__WEBPACK_IMPORTED_MODULE_1__["FdsSnackBarService"]];
-/* harmony default export */ __webpack_exports__["default"] = (FdsService);
-
-/***/ })
-
-/******/ });
-//# sourceMappingURL=data:application/json;charset=utf-8;base64,eyJ2ZXJzaW9uIjozLCJzb3VyY2VzIjpbIndlYnBhY2s6Ly8vd2VicGFjay9ib290c3RyYXAiLCJ3ZWJwYWNrOi8vLy4vbm9kZV9tb2R1bGVzL0Bhbmd1bGFyL2NvcmUvZmVzbTIwMTUgbGF6eSBuYW1lc3BhY2Ugb2JqZWN0Iiwid2VicGFjazovLy8uL3BsYXRmb3JtL2NvcmUvY29tbW9uL2Zkcy1jb21tb24ubW9kdWxlLmpzIiwid2VicGFjazovLy8uL3BsYXRmb3JtL2NvcmUvY29tbW9uL2Zkcy5hbmltYXRpb25zLmpzIiwid2VicGFjazovLy8uL3BsYXRmb3JtL2NvcmUvY29tbW9uL3NlcnZpY2VzL2Zkcy1zdG9yYWdlLnNlcnZpY2UuanMiLCJ3ZWJwYWNrOi8vLy4v [...]
\ No newline at end of file
diff --git a/fds-demo.bundle.min.js.gz b/fds-demo.bundle.min.js.gz
deleted file mode 100644
index ba05aeb..0000000
Binary files a/fds-demo.bundle.min.js.gz and /dev/null differ
diff --git a/fds-demo.styles.min.css b/fds-demo.styles.min.css
deleted file mode 100644
index d5d66fe..0000000
--- a/fds-demo.styles.min.css
+++ /dev/null
@@ -1,24852 +0,0 @@
-@charset "UTF-8";
-/*
- * Licensed to the Apache Software Foundation (ASF) under one or more
- * contributor license agreements.  See the NOTICE file distributed with
- * this work for additional information regarding copyright ownership.
- * The ASF licenses this file to You under the Apache License, Version 2.0
- * (the 'License'); you may not use this file except in compliance with
- * the License.  You may obtain a copy of the License at
- *
- *     http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an 'AS IS' BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-/*!
- *  Font Awesome 4.7.0 by @davegandy - http://fontawesome.io - @fontawesome
- *  License - http://fontawesome.io/license (Font: SIL OFL 1.1, CSS: MIT License)
- */
-/* FONT PATH
- * -------------------------- */
-@font-face {
-  font-family: "FontAwesome";
-  src: url("node_modules/font-awesome/fonts/fontawesome-webfont.eot?v=4.7.0");
-  src: url("node_modules/font-awesome/fonts/fontawesome-webfont.eot?#iefix&v=4.7.0") format("embedded-opentype"), url("node_modules/font-awesome/fonts/fontawesome-webfont.woff2?v=4.7.0") format("woff2"), url("node_modules/font-awesome/fonts/fontawesome-webfont.woff?v=4.7.0") format("woff"), url("node_modules/font-awesome/fonts/fontawesome-webfont.ttf?v=4.7.0") format("truetype"), url("node_modules/font-awesome/fonts/fontawesome-webfont.svg?v=4.7.0#fontawesomeregular") format("svg");
-  font-weight: normal;
-  font-style: normal;
-}
-.fa {
-  display: inline-block;
-  font: normal normal normal 14px/1 FontAwesome;
-  font-size: inherit;
-  text-rendering: auto;
-  -webkit-font-smoothing: antialiased;
-  -moz-osx-font-smoothing: grayscale;
-}
-
-/* makes the font 33% larger relative to the icon container */
-.fa-lg {
-  font-size: 1.3333333333em;
-  line-height: 0.75em;
-  vertical-align: -15%;
-}
-
-.fa-2x {
-  font-size: 2em;
-}
-
-.fa-3x {
-  font-size: 3em;
-}
-
-.fa-4x {
-  font-size: 4em;
-}
-
-.fa-5x {
-  font-size: 5em;
-}
-
-.fa-fw {
-  width: 1.2857142857em;
-  text-align: center;
-}
-
-.fa-ul {
-  padding-left: 0;
-  margin-left: 2.1428571429em;
-  list-style-type: none;
-}
-.fa-ul > li {
-  position: relative;
-}
-
-.fa-li {
-  position: absolute;
-  left: -2.1428571429em;
-  width: 2.1428571429em;
-  top: 0.1428571429em;
-  text-align: center;
-}
-.fa-li.fa-lg {
-  left: -1.8571428571em;
-}
-
-.fa-border {
-  padding: 0.2em 0.25em 0.15em;
-  border: solid 0.08em #eee;
-  border-radius: 0.1em;
-}
-
-.fa-pull-left {
-  float: left;
-}
-
-.fa-pull-right {
-  float: right;
-}
-
-.fa.fa-pull-left {
-  margin-right: 0.3em;
-}
-.fa.fa-pull-right {
-  margin-left: 0.3em;
-}
-
-/* Deprecated as of 4.4.0 */
-.pull-right {
-  float: right;
-}
-
-.pull-left {
-  float: left;
-}
-
-.fa.pull-left {
-  margin-right: 0.3em;
-}
-.fa.pull-right {
-  margin-left: 0.3em;
-}
-
-.fa-spin {
-  -webkit-animation: fa-spin 2s infinite linear;
-  animation: fa-spin 2s infinite linear;
-}
-
-.fa-pulse {
-  -webkit-animation: fa-spin 1s infinite steps(8);
-  animation: fa-spin 1s infinite steps(8);
-}
-
-@-webkit-keyframes fa-spin {
-  0% {
-    -webkit-transform: rotate(0deg);
-    transform: rotate(0deg);
-  }
-  100% {
-    -webkit-transform: rotate(359deg);
-    transform: rotate(359deg);
-  }
-}
-@keyframes fa-spin {
-  0% {
-    -webkit-transform: rotate(0deg);
-    transform: rotate(0deg);
-  }
-  100% {
-    -webkit-transform: rotate(359deg);
-    transform: rotate(359deg);
-  }
-}
-.fa-rotate-90 {
-  -ms-filter: "progid:DXImageTransform.Microsoft.BasicImage(rotation=1)";
-  -webkit-transform: rotate(90deg);
-  -ms-transform: rotate(90deg);
-  transform: rotate(90deg);
-}
-
-.fa-rotate-180 {
-  -ms-filter: "progid:DXImageTransform.Microsoft.BasicImage(rotation=2)";
-  -webkit-transform: rotate(180deg);
-  -ms-transform: rotate(180deg);
-  transform: rotate(180deg);
-}
-
-.fa-rotate-270 {
-  -ms-filter: "progid:DXImageTransform.Microsoft.BasicImage(rotation=3)";
-  -webkit-transform: rotate(270deg);
-  -ms-transform: rotate(270deg);
-  transform: rotate(270deg);
-}
-
-.fa-flip-horizontal {
-  -ms-filter: "progid:DXImageTransform.Microsoft.BasicImage(rotation=0, mirror=1)";
-  -webkit-transform: scale(-1, 1);
-  -ms-transform: scale(-1, 1);
-  transform: scale(-1, 1);
-}
-
-.fa-flip-vertical {
-  -ms-filter: "progid:DXImageTransform.Microsoft.BasicImage(rotation=2, mirror=1)";
-  -webkit-transform: scale(1, -1);
-  -ms-transform: scale(1, -1);
-  transform: scale(1, -1);
-}
-
-:root .fa-rotate-90,
-:root .fa-rotate-180,
-:root .fa-rotate-270,
-:root .fa-flip-horizontal,
-:root .fa-flip-vertical {
-  filter: none;
-}
-
-.fa-stack {
-  position: relative;
-  display: inline-block;
-  width: 2em;
-  height: 2em;
-  line-height: 2em;
-  vertical-align: middle;
-}
-
-.fa-stack-1x, .fa-stack-2x {
-  position: absolute;
-  left: 0;
-  width: 100%;
-  text-align: center;
-}
-
-.fa-stack-1x {
-  line-height: inherit;
-}
-
-.fa-stack-2x {
-  font-size: 2em;
-}
-
-.fa-inverse {
-  color: #fff;
-}
-
-/* Font Awesome uses the Unicode Private Use Area (PUA) to ensure screen
-   readers do not read off random characters that represent icons */
-.fa-glass:before {
-  content: "";
-}
-
-.fa-music:before {
-  content: "";
-}
-
-.fa-search:before {
-  content: "";
-}
-
-.fa-envelope-o:before {
-  content: "";
-}
-
-.fa-heart:before {
-  content: "";
-}
-
-.fa-star:before {
-  content: "";
-}
-
-.fa-star-o:before {
-  content: "";
-}
-
-.fa-user:before {
-  content: "";
-}
-
-.fa-film:before {
-  content: "";
-}
-
-.fa-th-large:before {
-  content: "";
-}
-
-.fa-th:before {
-  content: "";
-}
-
-.fa-th-list:before {
-  content: "";
-}
-
-.fa-check:before {
-  content: "";
-}
-
-.fa-remove:before,
-.fa-close:before,
-.fa-times:before {
-  content: "";
-}
-
-.fa-search-plus:before {
-  content: "";
-}
-
-.fa-search-minus:before {
-  content: "";
-}
-
-.fa-power-off:before {
-  content: "";
-}
-
-.fa-signal:before {
-  content: "";
-}
-
-.fa-gear:before,
-.fa-cog:before {
-  content: "";
-}
-
-.fa-trash-o:before {
-  content: "";
-}
-
-.fa-home:before {
-  content: "";
-}
-
-.fa-file-o:before {
-  content: "";
-}
-
-.fa-clock-o:before {
-  content: "";
-}
-
-.fa-road:before {
-  content: "";
-}
-
-.fa-download:before {
-  content: "";
-}
-
-.fa-arrow-circle-o-down:before {
-  content: "";
-}
-
-.fa-arrow-circle-o-up:before {
-  content: "";
-}
-
-.fa-inbox:before {
-  content: "";
-}
-
-.fa-play-circle-o:before {
-  content: "";
-}
-
-.fa-rotate-right:before,
-.fa-repeat:before {
-  content: "";
-}
-
-.fa-refresh:before {
-  content: "";
-}
-
-.fa-list-alt:before {
-  content: "";
-}
-
-.fa-lock:before {
-  content: "";
-}
-
-.fa-flag:before {
-  content: "";
-}
-
-.fa-headphones:before {
-  content: "";
-}
-
-.fa-volume-off:before {
-  content: "";
-}
-
-.fa-volume-down:before {
-  content: "";
-}
-
-.fa-volume-up:before {
-  content: "";
-}
-
-.fa-qrcode:before {
-  content: "";
-}
-
-.fa-barcode:before {
-  content: "";
-}
-
-.fa-tag:before {
-  content: "";
-}
-
-.fa-tags:before {
-  content: "";
-}
-
-.fa-book:before {
-  content: "";
-}
-
-.fa-bookmark:before {
-  content: "";
-}
-
-.fa-print:before {
-  content: "";
-}
-
-.fa-camera:before {
-  content: "";
-}
-
-.fa-font:before {
-  content: "";
-}
-
-.fa-bold:before {
-  content: "";
-}
-
-.fa-italic:before {
-  content: "";
-}
-
-.fa-text-height:before {
-  content: "";
-}
-
-.fa-text-width:before {
-  content: "";
-}
-
-.fa-align-left:before {
-  content: "";
-}
-
-.fa-align-center:before {
-  content: "";
-}
-
-.fa-align-right:before {
-  content: "";
-}
-
-.fa-align-justify:before {
-  content: "";
-}
-
-.fa-list:before {
-  content: "";
-}
-
-.fa-dedent:before,
-.fa-outdent:before {
-  content: "";
-}
-
-.fa-indent:before {
-  content: "";
-}
-
-.fa-video-camera:before {
-  content: "";
-}
-
-.fa-photo:before,
-.fa-image:before,
-.fa-picture-o:before {
-  content: "";
-}
-
-.fa-pencil:before {
-  content: "";
-}
-
-.fa-map-marker:before {
-  content: "";
-}
-
-.fa-adjust:before {
-  content: "";
-}
-
-.fa-tint:before {
-  content: "";
-}
-
-.fa-edit:before,
-.fa-pencil-square-o:before {
-  content: "";
-}
-
-.fa-share-square-o:before {
-  content: "";
-}
-
-.fa-check-square-o:before {
-  content: "";
-}
-
-.fa-arrows:before {
-  content: "";
-}
-
-.fa-step-backward:before {
-  content: "";
-}
-
-.fa-fast-backward:before {
-  content: "";
-}
-
-.fa-backward:before {
-  content: "";
-}
-
-.fa-play:before {
-  content: "";
-}
-
-.fa-pause:before {
-  content: "";
-}
-
-.fa-stop:before {
-  content: "";
-}
-
-.fa-forward:before {
-  content: "";
-}
-
-.fa-fast-forward:before {
-  content: "";
-}
-
-.fa-step-forward:before {
-  content: "";
-}
-
-.fa-eject:before {
-  content: "";
-}
-
-.fa-chevron-left:before {
-  content: "";
-}
-
-.fa-chevron-right:before {
-  content: "";
-}
-
-.fa-plus-circle:before {
-  content: "";
-}
-
-.fa-minus-circle:before {
-  content: "";
-}
-
-.fa-times-circle:before {
-  content: "";
-}
-
-.fa-check-circle:before {
-  content: "";
-}
-
-.fa-question-circle:before {
-  content: "";
-}
-
-.fa-info-circle:before {
-  content: "";
-}
-
-.fa-crosshairs:before {
-  content: "";
-}
-
-.fa-times-circle-o:before {
-  content: "";
-}
-
-.fa-check-circle-o:before {
-  content: "";
-}
-
-.fa-ban:before {
-  content: "";
-}
-
-.fa-arrow-left:before {
-  content: "";
-}
-
-.fa-arrow-right:before {
-  content: "";
-}
-
-.fa-arrow-up:before {
-  content: "";
-}
-
-.fa-arrow-down:before {
-  content: "";
-}
-
-.fa-mail-forward:before,
-.fa-share:before {
-  content: "";
-}
-
-.fa-expand:before {
-  content: "";
-}
-
-.fa-compress:before {
-  content: "";
-}
-
-.fa-plus:before {
-  content: "";
-}
-
-.fa-minus:before {
-  content: "";
-}
-
-.fa-asterisk:before {
-  content: "";
-}
-
-.fa-exclamation-circle:before {
-  content: "";
-}
-
-.fa-gift:before {
-  content: "";
-}
-
-.fa-leaf:before {
-  content: "";
-}
-
-.fa-fire:before {
-  content: "";
-}
-
-.fa-eye:before {
-  content: "";
-}
-
-.fa-eye-slash:before {
-  content: "";
-}
-
-.fa-warning:before,
-.fa-exclamation-triangle:before {
-  content: "";
-}
-
-.fa-plane:before {
-  content: "";
-}
-
-.fa-calendar:before {
-  content: "";
-}
-
-.fa-random:before {
-  content: "";
-}
-
-.fa-comment:before {
-  content: "";
-}
-
-.fa-magnet:before {
-  content: "";
-}
-
-.fa-chevron-up:before {
-  content: "";
-}
-
-.fa-chevron-down:before {
-  content: "";
-}
-
-.fa-retweet:before {
-  content: "";
-}
-
-.fa-shopping-cart:before {
-  content: "";
-}
-
-.fa-folder:before {
-  content: "";
-}
-
-.fa-folder-open:before {
-  content: "";
-}
-
-.fa-arrows-v:before {
-  content: "";
-}
-
-.fa-arrows-h:before {
-  content: "";
-}
-
-.fa-bar-chart-o:before,
-.fa-bar-chart:before {
-  content: "";
-}
-
-.fa-twitter-square:before {
-  content: "";
-}
-
-.fa-facebook-square:before {
-  content: "";
-}
-
-.fa-camera-retro:before {
-  content: "";
-}
-
-.fa-key:before {
-  content: "";
-}
-
-.fa-gears:before,
-.fa-cogs:before {
-  content: "";
-}
-
-.fa-comments:before {
-  content: "";
-}
-
-.fa-thumbs-o-up:before {
-  content: "";
-}
-
-.fa-thumbs-o-down:before {
-  content: "";
-}
-
-.fa-star-half:before {
-  content: "";
-}
-
-.fa-heart-o:before {
-  content: "";
-}
-
-.fa-sign-out:before {
-  content: "";
-}
-
-.fa-linkedin-square:before {
-  content: "";
-}
-
-.fa-thumb-tack:before {
-  content: "";
-}
-
-.fa-external-link:before {
-  content: "";
-}
-
-.fa-sign-in:before {
-  content: "";
-}
-
-.fa-trophy:before {
-  content: "";
-}
-
-.fa-github-square:before {
-  content: "";
-}
-
-.fa-upload:before {
-  content: "";
-}
-
-.fa-lemon-o:before {
-  content: "";
-}
-
-.fa-phone:before {
-  content: "";
-}
-
-.fa-square-o:before {
-  content: "";
-}
-
-.fa-bookmark-o:before {
-  content: "";
-}
-
-.fa-phone-square:before {
-  content: "";
-}
-
-.fa-twitter:before {
-  content: "";
-}
-
-.fa-facebook-f:before,
-.fa-facebook:before {
-  content: "";
-}
-
-.fa-github:before {
-  content: "";
-}
-
-.fa-unlock:before {
-  content: "";
-}
-
-.fa-credit-card:before {
-  content: "";
-}
-
-.fa-feed:before,
-.fa-rss:before {
-  content: "";
-}
-
-.fa-hdd-o:before {
-  content: "";
-}
-
-.fa-bullhorn:before {
-  content: "";
-}
-
-.fa-bell:before {
-  content: "";
-}
-
-.fa-certificate:before {
-  content: "";
-}
-
-.fa-hand-o-right:before {
-  content: "";
-}
-
-.fa-hand-o-left:before {
-  content: "";
-}
-
-.fa-hand-o-up:before {
-  content: "";
-}
-
-.fa-hand-o-down:before {
-  content: "";
-}
-
-.fa-arrow-circle-left:before {
-  content: "";
-}
-
-.fa-arrow-circle-right:before {
-  content: "";
-}
-
-.fa-arrow-circle-up:before {
-  content: "";
-}
-
-.fa-arrow-circle-down:before {
-  content: "";
-}
-
-.fa-globe:before {
-  content: "";
-}
-
-.fa-wrench:before {
-  content: "";
-}
-
-.fa-tasks:before {
-  content: "";
-}
-
-.fa-filter:before {
-  content: "";
-}
-
-.fa-briefcase:before {
-  content: "";
-}
-
-.fa-arrows-alt:before {
-  content: "";
-}
-
-.fa-group:before,
-.fa-users:before {
-  content: "";
-}
-
-.fa-chain:before,
-.fa-link:before {
-  content: "";
-}
-
-.fa-cloud:before {
-  content: "";
-}
-
-.fa-flask:before {
-  content: "";
-}
-
-.fa-cut:before,
-.fa-scissors:before {
-  content: "";
-}
-
-.fa-copy:before,
-.fa-files-o:before {
-  content: "";
-}
-
-.fa-paperclip:before {
-  content: "";
-}
-
-.fa-save:before,
-.fa-floppy-o:before {
-  content: "";
-}
-
-.fa-square:before {
-  content: "";
-}
-
-.fa-navicon:before,
-.fa-reorder:before,
-.fa-bars:before {
-  content: "";
-}
-
-.fa-list-ul:before {
-  content: "";
-}
-
-.fa-list-ol:before {
-  content: "";
-}
-
-.fa-strikethrough:before {
-  content: "";
-}
-
-.fa-underline:before {
-  content: "";
-}
-
-.fa-table:before {
-  content: "";
-}
-
-.fa-magic:before {
-  content: "";
-}
-
-.fa-truck:before {
-  content: "";
-}
-
-.fa-pinterest:before {
-  content: "";
-}
-
-.fa-pinterest-square:before {
-  content: "";
-}
-
-.fa-google-plus-square:before {
-  content: "";
-}
-
-.fa-google-plus:before {
-  content: "";
-}
-
-.fa-money:before {
-  content: "";
-}
-
-.fa-caret-down:before {
-  content: "";
-}
-
-.fa-caret-up:before {
-  content: "";
-}
-
-.fa-caret-left:before {
-  content: "";
-}
-
-.fa-caret-right:before {
-  content: "";
-}
-
-.fa-columns:before {
-  content: "";
-}
-
-.fa-unsorted:before,
-.fa-sort:before {
-  content: "";
-}
-
-.fa-sort-down:before,
-.fa-sort-desc:before {
-  content: "";
-}
-
-.fa-sort-up:before,
-.fa-sort-asc:before {
-  content: "";
-}
-
-.fa-envelope:before {
-  content: "";
-}
-
-.fa-linkedin:before {
-  content: "";
-}
-
-.fa-rotate-left:before,
-.fa-undo:before {
-  content: "";
-}
-
-.fa-legal:before,
-.fa-gavel:before {
-  content: "";
-}
-
-.fa-dashboard:before,
-.fa-tachometer:before {
-  content: "";
-}
-
-.fa-comment-o:before {
-  content: "";
-}
-
-.fa-comments-o:before {
-  content: "";
-}
-
-.fa-flash:before,
-.fa-bolt:before {
-  content: "";
-}
-
-.fa-sitemap:before {
-  content: "";
-}
-
-.fa-umbrella:before {
-  content: "";
-}
-
-.fa-paste:before,
-.fa-clipboard:before {
-  content: "";
-}
-
-.fa-lightbulb-o:before {
-  content: "";
-}
-
-.fa-exchange:before {
-  content: "";
-}
-
-.fa-cloud-download:before {
-  content: "";
-}
-
-.fa-cloud-upload:before {
-  content: "";
-}
-
-.fa-user-md:before {
-  content: "";
-}
-
-.fa-stethoscope:before {
-  content: "";
-}
-
-.fa-suitcase:before {
-  content: "";
-}
-
-.fa-bell-o:before {
-  content: "";
-}
-
-.fa-coffee:before {
-  content: "";
-}
-
-.fa-cutlery:before {
-  content: "";
-}
-
-.fa-file-text-o:before {
-  content: "";
-}
-
-.fa-building-o:before {
-  content: "";
-}
-
-.fa-hospital-o:before {
-  content: "";
-}
-
-.fa-ambulance:before {
-  content: "";
-}
-
-.fa-medkit:before {
-  content: "";
-}
-
-.fa-fighter-jet:before {
-  content: "";
-}
-
-.fa-beer:before {
-  content: "";
-}
-
-.fa-h-square:before {
-  content: "";
-}
-
-.fa-plus-square:before {
-  content: "";
-}
-
-.fa-angle-double-left:before {
-  content: "";
-}
-
-.fa-angle-double-right:before {
-  content: "";
-}
-
-.fa-angle-double-up:before {
-  content: "";
-}
-
-.fa-angle-double-down:before {
-  content: "";
-}
-
-.fa-angle-left:before {
-  content: "";
-}
-
-.fa-angle-right:before {
-  content: "";
-}
-
-.fa-angle-up:before {
-  content: "";
-}
-
-.fa-angle-down:before {
-  content: "";
-}
-
-.fa-desktop:before {
-  content: "";
-}
-
-.fa-laptop:before {
-  content: "";
-}
-
-.fa-tablet:before {
-  content: "";
-}
-
-.fa-mobile-phone:before,
-.fa-mobile:before {
-  content: "";
-}
-
-.fa-circle-o:before {
-  content: "";
-}
-
-.fa-quote-left:before {
-  content: "";
-}
-
-.fa-quote-right:before {
-  content: "";
-}
-
-.fa-spinner:before {
-  content: "";
-}
-
-.fa-circle:before {
-  content: "";
-}
-
-.fa-mail-reply:before,
-.fa-reply:before {
-  content: "";
-}
-
-.fa-github-alt:before {
-  content: "";
-}
-
-.fa-folder-o:before {
-  content: "";
-}
-
-.fa-folder-open-o:before {
-  content: "";
-}
-
-.fa-smile-o:before {
-  content: "";
-}
-
-.fa-frown-o:before {
-  content: "";
-}
-
-.fa-meh-o:before {
-  content: "";
-}
-
-.fa-gamepad:before {
-  content: "";
-}
-
-.fa-keyboard-o:before {
-  content: "";
-}
-
-.fa-flag-o:before {
-  content: "";
-}
-
-.fa-flag-checkered:before {
-  content: "";
-}
-
-.fa-terminal:before {
-  content: "";
-}
-
-.fa-code:before {
-  content: "";
-}
-
-.fa-mail-reply-all:before,
-.fa-reply-all:before {
-  content: "";
-}
-
-.fa-star-half-empty:before,
-.fa-star-half-full:before,
-.fa-star-half-o:before {
-  content: "";
-}
-
-.fa-location-arrow:before {
-  content: "";
-}
-
-.fa-crop:before {
-  content: "";
-}
-
-.fa-code-fork:before {
-  content: "";
-}
-
-.fa-unlink:before,
-.fa-chain-broken:before {
-  content: "";
-}
-
-.fa-question:before {
-  content: "";
-}
-
-.fa-info:before {
-  content: "";
-}
-
-.fa-exclamation:before {
-  content: "";
-}
-
-.fa-superscript:before {
-  content: "";
-}
-
-.fa-subscript:before {
-  content: "";
-}
-
-.fa-eraser:before {
-  content: "";
-}
-
-.fa-puzzle-piece:before {
-  content: "";
-}
-
-.fa-microphone:before {
-  content: "";
-}
-
-.fa-microphone-slash:before {
-  content: "";
-}
-
-.fa-shield:before {
-  content: "";
-}
-
-.fa-calendar-o:before {
-  content: "";
-}
-
-.fa-fire-extinguisher:before {
-  content: "";
-}
-
-.fa-rocket:before {
-  content: "";
-}
-
-.fa-maxcdn:before {
-  content: "";
-}
-
-.fa-chevron-circle-left:before {
-  content: "";
-}
-
-.fa-chevron-circle-right:before {
-  content: "";
-}
-
-.fa-chevron-circle-up:before {
-  content: "";
-}
-
-.fa-chevron-circle-down:before {
-  content: "";
-}
-
-.fa-html5:before {
-  content: "";
-}
-
-.fa-css3:before {
-  content: "";
-}
-
-.fa-anchor:before {
-  content: "";
-}
-
-.fa-unlock-alt:before {
-  content: "";
-}
-
-.fa-bullseye:before {
-  content: "";
-}
-
-.fa-ellipsis-h:before {
-  content: "";
-}
-
-.fa-ellipsis-v:before {
-  content: "";
-}
-
-.fa-rss-square:before {
-  content: "";
-}
-
-.fa-play-circle:before {
-  content: "";
-}
-
-.fa-ticket:before {
-  content: "";
-}
-
-.fa-minus-square:before {
-  content: "";
-}
-
-.fa-minus-square-o:before {
-  content: "";
-}
-
-.fa-level-up:before {
-  content: "";
-}
-
-.fa-level-down:before {
-  content: "";
-}
-
-.fa-check-square:before {
-  content: "";
-}
-
-.fa-pencil-square:before {
-  content: "";
-}
-
-.fa-external-link-square:before {
-  content: "";
-}
-
-.fa-share-square:before {
-  content: "";
-}
-
-.fa-compass:before {
-  content: "";
-}
-
-.fa-toggle-down:before,
-.fa-caret-square-o-down:before {
-  content: "";
-}
-
-.fa-toggle-up:before,
-.fa-caret-square-o-up:before {
-  content: "";
-}
-
-.fa-toggle-right:before,
-.fa-caret-square-o-right:before {
-  content: "";
-}
-
-.fa-euro:before,
-.fa-eur:before {
-  content: "";
-}
-
-.fa-gbp:before {
-  content: "";
-}
-
-.fa-dollar:before,
-.fa-usd:before {
-  content: "";
-}
-
-.fa-rupee:before,
-.fa-inr:before {
-  content: "";
-}
-
-.fa-cny:before,
-.fa-rmb:before,
-.fa-yen:before,
-.fa-jpy:before {
-  content: "";
-}
-
-.fa-ruble:before,
-.fa-rouble:before,
-.fa-rub:before {
-  content: "";
-}
-
-.fa-won:before,
-.fa-krw:before {
-  content: "";
-}
-
-.fa-bitcoin:before,
-.fa-btc:before {
-  content: "";
-}
-
-.fa-file:before {
-  content: "";
-}
-
-.fa-file-text:before {
-  content: "";
-}
-
-.fa-sort-alpha-asc:before {
-  content: "";
-}
-
-.fa-sort-alpha-desc:before {
-  content: "";
-}
-
-.fa-sort-amount-asc:before {
-  content: "";
-}
-
-.fa-sort-amount-desc:before {
-  content: "";
-}
-
-.fa-sort-numeric-asc:before {
-  content: "";
-}
-
-.fa-sort-numeric-desc:before {
-  content: "";
-}
-
-.fa-thumbs-up:before {
-  content: "";
-}
-
-.fa-thumbs-down:before {
-  content: "";
-}
-
-.fa-youtube-square:before {
-  content: "";
-}
-
-.fa-youtube:before {
-  content: "";
-}
-
-.fa-xing:before {
-  content: "";
-}
-
-.fa-xing-square:before {
-  content: "";
-}
-
-.fa-youtube-play:before {
-  content: "";
-}
-
-.fa-dropbox:before {
-  content: "";
-}
-
-.fa-stack-overflow:before {
-  content: "";
-}
-
-.fa-instagram:before {
-  content: "";
-}
-
-.fa-flickr:before {
-  content: "";
-}
-
-.fa-adn:before {
-  content: "";
-}
-
-.fa-bitbucket:before {
-  content: "";
-}
-
-.fa-bitbucket-square:before {
-  content: "";
-}
-
-.fa-tumblr:before {
-  content: "";
-}
-
-.fa-tumblr-square:before {
-  content: "";
-}
-
-.fa-long-arrow-down:before {
-  content: "";
-}
-
-.fa-long-arrow-up:before {
-  content: "";
-}
-
-.fa-long-arrow-left:before {
-  content: "";
-}
-
-.fa-long-arrow-right:before {
-  content: "";
-}
-
-.fa-apple:before {
-  content: "";
-}
-
-.fa-windows:before {
-  content: "";
-}
-
-.fa-android:before {
-  content: "";
-}
-
-.fa-linux:before {
-  content: "";
-}
-
-.fa-dribbble:before {
-  content: "";
-}
-
-.fa-skype:before {
-  content: "";
-}
-
-.fa-foursquare:before {
-  content: "";
-}
-
-.fa-trello:before {
-  content: "";
-}
-
-.fa-female:before {
-  content: "";
-}
-
-.fa-male:before {
-  content: "";
-}
-
-.fa-gittip:before,
-.fa-gratipay:before {
-  content: "";
-}
-
-.fa-sun-o:before {
-  content: "";
-}
-
-.fa-moon-o:before {
-  content: "";
-}
-
-.fa-archive:before {
-  content: "";
-}
-
-.fa-bug:before {
-  content: "";
-}
-
-.fa-vk:before {
-  content: "";
-}
-
-.fa-weibo:before {
-  content: "";
-}
-
-.fa-renren:before {
-  content: "";
-}
-
-.fa-pagelines:before {
-  content: "";
-}
-
-.fa-stack-exchange:before {
-  content: "";
-}
-
-.fa-arrow-circle-o-right:before {
-  content: "";
-}
-
-.fa-arrow-circle-o-left:before {
-  content: "";
-}
-
-.fa-toggle-left:before,
-.fa-caret-square-o-left:before {
-  content: "";
-}
-
-.fa-dot-circle-o:before {
-  content: "";
-}
-
-.fa-wheelchair:before {
-  content: "";
-}
-
-.fa-vimeo-square:before {
-  content: "";
-}
-
-.fa-turkish-lira:before,
-.fa-try:before {
-  content: "";
-}
-
-.fa-plus-square-o:before {
-  content: "";
-}
-
-.fa-space-shuttle:before {
-  content: "";
-}
-
-.fa-slack:before {
-  content: "";
-}
-
-.fa-envelope-square:before {
-  content: "";
-}
-
-.fa-wordpress:before {
-  content: "";
-}
-
-.fa-openid:before {
-  content: "";
-}
-
-.fa-institution:before,
-.fa-bank:before,
-.fa-university:before {
-  content: "";
-}
-
-.fa-mortar-board:before,
-.fa-graduation-cap:before {
-  content: "";
-}
-
-.fa-yahoo:before {
-  content: "";
-}
-
-.fa-google:before {
-  content: "";
-}
-
-.fa-reddit:before {
-  content: "";
-}
-
-.fa-reddit-square:before {
-  content: "";
-}
-
-.fa-stumbleupon-circle:before {
-  content: "";
-}
-
-.fa-stumbleupon:before {
-  content: "";
-}
-
-.fa-delicious:before {
-  content: "";
-}
-
-.fa-digg:before {
-  content: "";
-}
-
-.fa-pied-piper-pp:before {
-  content: "";
-}
-
-.fa-pied-piper-alt:before {
-  content: "";
-}
-
-.fa-drupal:before {
-  content: "";
-}
-
-.fa-joomla:before {
-  content: "";
-}
-
-.fa-language:before {
-  content: "";
-}
-
-.fa-fax:before {
-  content: "";
-}
-
-.fa-building:before {
-  content: "";
-}
-
-.fa-child:before {
-  content: "";
-}
-
-.fa-paw:before {
-  content: "";
-}
-
-.fa-spoon:before {
-  content: "";
-}
-
-.fa-cube:before {
-  content: "";
-}
-
-.fa-cubes:before {
-  content: "";
-}
-
-.fa-behance:before {
-  content: "";
-}
-
-.fa-behance-square:before {
-  content: "";
-}
-
-.fa-steam:before {
-  content: "";
-}
-
-.fa-steam-square:before {
-  content: "";
-}
-
-.fa-recycle:before {
-  content: "";
-}
-
-.fa-automobile:before,
-.fa-car:before {
-  content: "";
-}
-
-.fa-cab:before,
-.fa-taxi:before {
-  content: "";
-}
-
-.fa-tree:before {
-  content: "";
-}
-
-.fa-spotify:before {
-  content: "";
-}
-
-.fa-deviantart:before {
-  content: "";
-}
-
-.fa-soundcloud:before {
-  content: "";
-}
-
-.fa-database:before {
-  content: "";
-}
-
-.fa-file-pdf-o:before {
-  content: "";
-}
-
-.fa-file-word-o:before {
-  content: "";
-}
-
-.fa-file-excel-o:before {
-  content: "";
-}
-
-.fa-file-powerpoint-o:before {
-  content: "";
-}
-
-.fa-file-photo-o:before,
-.fa-file-picture-o:before,
-.fa-file-image-o:before {
-  content: "";
-}
-
-.fa-file-zip-o:before,
-.fa-file-archive-o:before {
-  content: "";
-}
-
-.fa-file-sound-o:before,
-.fa-file-audio-o:before {
-  content: "";
-}
-
-.fa-file-movie-o:before,
-.fa-file-video-o:before {
-  content: "";
-}
-
-.fa-file-code-o:before {
-  content: "";
-}
-
-.fa-vine:before {
-  content: "";
-}
-
-.fa-codepen:before {
-  content: "";
-}
-
-.fa-jsfiddle:before {
-  content: "";
-}
-
-.fa-life-bouy:before,
-.fa-life-buoy:before,
-.fa-life-saver:before,
-.fa-support:before,
-.fa-life-ring:before {
-  content: "";
-}
-
-.fa-circle-o-notch:before {
-  content: "";
-}
-
-.fa-ra:before,
-.fa-resistance:before,
-.fa-rebel:before {
-  content: "";
-}
-
-.fa-ge:before,
-.fa-empire:before {
-  content: "";
-}
-
-.fa-git-square:before {
-  content: "";
-}
-
-.fa-git:before {
-  content: "";
-}
-
-.fa-y-combinator-square:before,
-.fa-yc-square:before,
-.fa-hacker-news:before {
-  content: "";
-}
-
-.fa-tencent-weibo:before {
-  content: "";
-}
-
-.fa-qq:before {
-  content: "";
-}
-
-.fa-wechat:before,
-.fa-weixin:before {
-  content: "";
-}
-
-.fa-send:before,
-.fa-paper-plane:before {
-  content: "";
-}
-
-.fa-send-o:before,
-.fa-paper-plane-o:before {
-  content: "";
-}
-
-.fa-history:before {
-  content: "";
-}
-
-.fa-circle-thin:before {
-  content: "";
-}
-
-.fa-header:before {
-  content: "";
-}
-
-.fa-paragraph:before {
-  content: "";
-}
-
-.fa-sliders:before {
-  content: "";
-}
-
-.fa-share-alt:before {
-  content: "";
-}
-
-.fa-share-alt-square:before {
-  content: "";
-}
-
-.fa-bomb:before {
-  content: "";
-}
-
-.fa-soccer-ball-o:before,
-.fa-futbol-o:before {
-  content: "";
-}
-
-.fa-tty:before {
-  content: "";
-}
-
-.fa-binoculars:before {
-  content: "";
-}
-
-.fa-plug:before {
-  content: "";
-}
-
-.fa-slideshare:before {
-  content: "";
-}
-
-.fa-twitch:before {
-  content: "";
-}
-
-.fa-yelp:before {
-  content: "";
-}
-
-.fa-newspaper-o:before {
-  content: "";
-}
-
-.fa-wifi:before {
-  content: "";
-}
-
-.fa-calculator:before {
-  content: "";
-}
-
-.fa-paypal:before {
-  content: "";
-}
-
-.fa-google-wallet:before {
-  content: "";
-}
-
-.fa-cc-visa:before {
-  content: "";
-}
-
-.fa-cc-mastercard:before {
-  content: "";
-}
-
-.fa-cc-discover:before {
-  content: "";
-}
-
-.fa-cc-amex:before {
-  content: "";
-}
-
-.fa-cc-paypal:before {
-  content: "";
-}
-
-.fa-cc-stripe:before {
-  content: "";
-}
-
-.fa-bell-slash:before {
-  content: "";
-}
-
-.fa-bell-slash-o:before {
-  content: "";
-}
-
-.fa-trash:before {
-  content: "";
-}
-
-.fa-copyright:before {
-  content: "";
-}
-
-.fa-at:before {
-  content: "";
-}
-
-.fa-eyedropper:before {
-  content: "";
-}
-
-.fa-paint-brush:before {
-  content: "";
-}
-
-.fa-birthday-cake:before {
-  content: "";
-}
-
-.fa-area-chart:before {
-  content: "";
-}
-
-.fa-pie-chart:before {
-  content: "";
-}
-
-.fa-line-chart:before {
-  content: "";
-}
-
-.fa-lastfm:before {
-  content: "";
-}
-
-.fa-lastfm-square:before {
-  content: "";
-}
-
-.fa-toggle-off:before {
-  content: "";
-}
-
-.fa-toggle-on:before {
-  content: "";
-}
-
-.fa-bicycle:before {
-  content: "";
-}
-
-.fa-bus:before {
-  content: "";
-}
-
-.fa-ioxhost:before {
-  content: "";
-}
-
-.fa-angellist:before {
-  content: "";
-}
-
-.fa-cc:before {
-  content: "";
-}
-
-.fa-shekel:before,
-.fa-sheqel:before,
-.fa-ils:before {
-  content: "";
-}
-
-.fa-meanpath:before {
-  content: "";
-}
-
-.fa-buysellads:before {
-  content: "";
-}
-
-.fa-connectdevelop:before {
-  content: "";
-}
-
-.fa-dashcube:before {
-  content: "";
-}
-
-.fa-forumbee:before {
-  content: "";
-}
-
-.fa-leanpub:before {
-  content: "";
-}
-
-.fa-sellsy:before {
-  content: "";
-}
-
-.fa-shirtsinbulk:before {
-  content: "";
-}
-
-.fa-simplybuilt:before {
-  content: "";
-}
-
-.fa-skyatlas:before {
-  content: "";
-}
-
-.fa-cart-plus:before {
-  content: "";
-}
-
-.fa-cart-arrow-down:before {
-  content: "";
-}
-
-.fa-diamond:before {
-  content: "";
-}
-
-.fa-ship:before {
-  content: "";
-}
-
-.fa-user-secret:before {
-  content: "";
-}
-
-.fa-motorcycle:before {
-  content: "";
-}
-
-.fa-street-view:before {
-  content: "";
-}
-
-.fa-heartbeat:before {
-  content: "";
-}
-
-.fa-venus:before {
-  content: "";
-}
-
-.fa-mars:before {
-  content: "";
-}
-
-.fa-mercury:before {
-  content: "";
-}
-
-.fa-intersex:before,
-.fa-transgender:before {
-  content: "";
-}
-
-.fa-transgender-alt:before {
-  content: "";
-}
-
-.fa-venus-double:before {
-  content: "";
-}
-
-.fa-mars-double:before {
-  content: "";
-}
-
-.fa-venus-mars:before {
-  content: "";
-}
-
-.fa-mars-stroke:before {
-  content: "";
-}
-
-.fa-mars-stroke-v:before {
-  content: "";
-}
-
-.fa-mars-stroke-h:before {
-  content: "";
-}
-
-.fa-neuter:before {
-  content: "";
-}
-
-.fa-genderless:before {
-  content: "";
-}
-
-.fa-facebook-official:before {
-  content: "";
-}
-
-.fa-pinterest-p:before {
-  content: "";
-}
-
-.fa-whatsapp:before {
-  content: "";
-}
-
-.fa-server:before {
-  content: "";
-}
-
-.fa-user-plus:before {
-  content: "";
-}
-
-.fa-user-times:before {
-  content: "";
-}
-
-.fa-hotel:before,
-.fa-bed:before {
-  content: "";
-}
-
-.fa-viacoin:before {
-  content: "";
-}
-
-.fa-train:before {
-  content: "";
-}
-
-.fa-subway:before {
-  content: "";
-}
-
-.fa-medium:before {
-  content: "";
-}
-
-.fa-yc:before,
-.fa-y-combinator:before {
-  content: "";
-}
-
-.fa-optin-monster:before {
-  content: "";
-}
-
-.fa-opencart:before {
-  content: "";
-}
-
-.fa-expeditedssl:before {
-  content: "";
-}
-
-.fa-battery-4:before,
-.fa-battery:before,
-.fa-battery-full:before {
-  content: "";
-}
-
-.fa-battery-3:before,
-.fa-battery-three-quarters:before {
-  content: "";
-}
-
-.fa-battery-2:before,
-.fa-battery-half:before {
-  content: "";
-}
-
-.fa-battery-1:before,
-.fa-battery-quarter:before {
-  content: "";
-}
-
-.fa-battery-0:before,
-.fa-battery-empty:before {
-  content: "";
-}
-
-.fa-mouse-pointer:before {
-  content: "";
-}
-
-.fa-i-cursor:before {
-  content: "";
-}
-
-.fa-object-group:before {
-  content: "";
-}
-
-.fa-object-ungroup:before {
-  content: "";
-}
-
-.fa-sticky-note:before {
-  content: "";
-}
-
-.fa-sticky-note-o:before {
-  content: "";
-}
-
-.fa-cc-jcb:before {
-  content: "";
-}
-
-.fa-cc-diners-club:before {
-  content: "";
-}
-
-.fa-clone:before {
-  content: "";
-}
-
-.fa-balance-scale:before {
-  content: "";
-}
-
-.fa-hourglass-o:before {
-  content: "";
-}
-
-.fa-hourglass-1:before,
-.fa-hourglass-start:before {
-  content: "";
-}
-
-.fa-hourglass-2:before,
-.fa-hourglass-half:before {
-  content: "";
-}
-
-.fa-hourglass-3:before,
-.fa-hourglass-end:before {
-  content: "";
-}
-
-.fa-hourglass:before {
-  content: "";
-}
-
-.fa-hand-grab-o:before,
-.fa-hand-rock-o:before {
-  content: "";
-}
-
-.fa-hand-stop-o:before,
-.fa-hand-paper-o:before {
-  content: "";
-}
-
-.fa-hand-scissors-o:before {
-  content: "";
-}
-
-.fa-hand-lizard-o:before {
-  content: "";
-}
-
-.fa-hand-spock-o:before {
-  content: "";
-}
-
-.fa-hand-pointer-o:before {
-  content: "";
-}
-
-.fa-hand-peace-o:before {
-  content: "";
-}
-
-.fa-trademark:before {
-  content: "";
-}
-
-.fa-registered:before {
-  content: "";
-}
-
-.fa-creative-commons:before {
-  content: "";
-}
-
-.fa-gg:before {
-  content: "";
-}
-
-.fa-gg-circle:before {
-  content: "";
-}
-
-.fa-tripadvisor:before {
-  content: "";
-}
-
-.fa-odnoklassniki:before {
-  content: "";
-}
-
-.fa-odnoklassniki-square:before {
-  content: "";
-}
-
-.fa-get-pocket:before {
-  content: "";
-}
-
-.fa-wikipedia-w:before {
-  content: "";
-}
-
-.fa-safari:before {
-  content: "";
-}
-
-.fa-chrome:before {
-  content: "";
-}
-
-.fa-firefox:before {
-  content: "";
-}
-
-.fa-opera:before {
-  content: "";
-}
-
-.fa-internet-explorer:before {
-  content: "";
-}
-
-.fa-tv:before,
-.fa-television:before {
-  content: "";
-}
-
-.fa-contao:before {
-  content: "";
-}
-
-.fa-500px:before {
-  content: "";
-}
-
-.fa-amazon:before {
-  content: "";
-}
-
-.fa-calendar-plus-o:before {
-  content: "";
-}
-
-.fa-calendar-minus-o:before {
-  content: "";
-}
-
-.fa-calendar-times-o:before {
-  content: "";
-}
-
-.fa-calendar-check-o:before {
-  content: "";
-}
-
-.fa-industry:before {
-  content: "";
-}
-
-.fa-map-pin:before {
-  content: "";
-}
-
-.fa-map-signs:before {
-  content: "";
-}
-
-.fa-map-o:before {
-  content: "";
-}
-
-.fa-map:before {
-  content: "";
-}
-
-.fa-commenting:before {
-  content: "";
-}
-
-.fa-commenting-o:before {
-  content: "";
-}
-
-.fa-houzz:before {
-  content: "";
-}
-
-.fa-vimeo:before {
-  content: "";
-}
-
-.fa-black-tie:before {
-  content: "";
-}
-
-.fa-fonticons:before {
-  content: "";
-}
-
-.fa-reddit-alien:before {
-  content: "";
-}
-
-.fa-edge:before {
-  content: "";
-}
-
-.fa-credit-card-alt:before {
-  content: "";
-}
-
-.fa-codiepie:before {
-  content: "";
-}
-
-.fa-modx:before {
-  content: "";
-}
-
-.fa-fort-awesome:before {
-  content: "";
-}
-
-.fa-usb:before {
-  content: "";
-}
-
-.fa-product-hunt:before {
-  content: "";
-}
-
-.fa-mixcloud:before {
-  content: "";
-}
-
-.fa-scribd:before {
-  content: "";
-}
-
-.fa-pause-circle:before {
-  content: "";
-}
-
-.fa-pause-circle-o:before {
-  content: "";
-}
-
-.fa-stop-circle:before {
-  content: "";
-}
-
-.fa-stop-circle-o:before {
-  content: "";
-}
-
-.fa-shopping-bag:before {
-  content: "";
-}
-
-.fa-shopping-basket:before {
-  content: "";
-}
-
-.fa-hashtag:before {
-  content: "";
-}
-
-.fa-bluetooth:before {
-  content: "";
-}
-
-.fa-bluetooth-b:before {
-  content: "";
-}
-
-.fa-percent:before {
-  content: "";
-}
-
-.fa-gitlab:before {
-  content: "";
-}
-
-.fa-wpbeginner:before {
-  content: "";
-}
-
-.fa-wpforms:before {
-  content: "";
-}
-
-.fa-envira:before {
-  content: "";
-}
-
-.fa-universal-access:before {
-  content: "";
-}
-
-.fa-wheelchair-alt:before {
-  content: "";
-}
-
-.fa-question-circle-o:before {
-  content: "";
-}
-
-.fa-blind:before {
-  content: "";
-}
-
-.fa-audio-description:before {
-  content: "";
-}
-
-.fa-volume-control-phone:before {
-  content: "";
-}
-
-.fa-braille:before {
-  content: "";
-}
-
-.fa-assistive-listening-systems:before {
-  content: "";
-}
-
-.fa-asl-interpreting:before,
-.fa-american-sign-language-interpreting:before {
-  content: "";
-}
-
-.fa-deafness:before,
-.fa-hard-of-hearing:before,
-.fa-deaf:before {
-  content: "";
-}
-
-.fa-glide:before {
-  content: "";
-}
-
-.fa-glide-g:before {
-  content: "";
-}
-
-.fa-signing:before,
-.fa-sign-language:before {
-  content: "";
-}
-
-.fa-low-vision:before {
-  content: "";
-}
-
-.fa-viadeo:before {
-  content: "";
-}
-
-.fa-viadeo-square:before {
-  content: "";
-}
-
-.fa-snapchat:before {
-  content: "";
-}
-
-.fa-snapchat-ghost:before {
-  content: "";
-}
-
-.fa-snapchat-square:before {
-  content: "";
-}
-
-.fa-pied-piper:before {
-  content: "";
-}
-
-.fa-first-order:before {
-  content: "";
-}
-
-.fa-yoast:before {
-  content: "";
-}
-
-.fa-themeisle:before {
-  content: "";
-}
-
-.fa-google-plus-circle:before,
-.fa-google-plus-official:before {
-  content: "";
-}
-
-.fa-fa:before,
-.fa-font-awesome:before {
-  content: "";
-}
-
-.fa-handshake-o:before {
-  content: "";
-}
-
-.fa-envelope-open:before {
-  content: "";
-}
-
-.fa-envelope-open-o:before {
-  content: "";
-}
-
-.fa-linode:before {
-  content: "";
-}
-
-.fa-address-book:before {
-  content: "";
-}
-
-.fa-address-book-o:before {
-  content: "";
-}
-
-.fa-vcard:before,
-.fa-address-card:before {
-  content: "";
-}
-
-.fa-vcard-o:before,
-.fa-address-card-o:before {
-  content: "";
-}
-
-.fa-user-circle:before {
-  content: "";
-}
-
-.fa-user-circle-o:before {
-  content: "";
-}
-
-.fa-user-o:before {
-  content: "";
-}
-
-.fa-id-badge:before {
-  content: "";
-}
-
-.fa-drivers-license:before,
-.fa-id-card:before {
-  content: "";
-}
-
-.fa-drivers-license-o:before,
-.fa-id-card-o:before {
-  content: "";
-}
-
-.fa-quora:before {
-  content: "";
-}
-
-.fa-free-code-camp:before {
-  content: "";
-}
-
-.fa-telegram:before {
-  content: "";
-}
-
-.fa-thermometer-4:before,
-.fa-thermometer:before,
-.fa-thermometer-full:before {
-  content: "";
-}
-
-.fa-thermometer-3:before,
-.fa-thermometer-three-quarters:before {
-  content: "";
-}
-
-.fa-thermometer-2:before,
-.fa-thermometer-half:before {
-  content: "";
-}
-
-.fa-thermometer-1:before,
-.fa-thermometer-quarter:before {
-  content: "";
-}
-
-.fa-thermometer-0:before,
-.fa-thermometer-empty:before {
-  content: "";
-}
-
-.fa-shower:before {
-  content: "";
-}
-
-.fa-bathtub:before,
-.fa-s15:before,
-.fa-bath:before {
-  content: "";
-}
-
-.fa-podcast:before {
-  content: "";
-}
-
-.fa-window-maximize:before {
-  content: "";
-}
-
-.fa-window-minimize:before {
-  content: "";
-}
-
-.fa-window-restore:before {
-  content: "";
-}
-
-.fa-times-rectangle:before,
-.fa-window-close:before {
-  content: "";
-}
-
-.fa-times-rectangle-o:before,
-.fa-window-close-o:before {
-  content: "";
-}
-
-.fa-bandcamp:before {
-  content: "";
-}
-
-.fa-grav:before {
-  content: "";
-}
-
-.fa-etsy:before {
-  content: "";
-}
-
-.fa-imdb:before {
-  content: "";
-}
-
-.fa-ravelry:before {
-  content: "";
-}
-
-.fa-eercast:before {
-  content: "";
-}
-
-.fa-microchip:before {
-  content: "";
-}
-
-.fa-snowflake-o:before {
-  content: "";
-}
-
-.fa-superpowers:before {
-  content: "";
-}
-
-.fa-wpexplorer:before {
-  content: "";
-}
-
-.fa-meetup:before {
-  content: "";
-}
-
-.sr-only {
-  position: absolute;
-  width: 1px;
-  height: 1px;
-  padding: 0;
-  margin: -1px;
-  overflow: hidden;
-  clip: rect(0, 0, 0, 0);
-  border: 0;
-}
-
-.sr-only-focusable:active, .sr-only-focusable:focus {
-  position: static;
-  width: auto;
-  height: auto;
-  margin: 0;
-  overflow: visible;
-  clip: auto;
-}
-
-/** Mixin to create distinct classes for fab positions, e.g. ".mat-fab-position-bottom-right". */
-/* stylelint-disable function-url-quotes, no-duplicate-selectors */
-/*
-*
-*  Responsive attributes
-*
-*  References:
-*  1) https://scotch.io/tutorials/a-visual-guide-to-css3-flexbox-properties#flex
-*  2) https://css-tricks.com/almanac/properties/f/flex/
-*  3) https://css-tricks.com/snippets/css/a-guide-to-flexbox/
-*  4) https://github.com/philipwalton/flexbugs#3-min-height-on-a-flex-container-wont-apply-to-its-flex-items
-*  5) http://godban.com.ua/projects/flexgrid
-*
-*/
-@-moz-document url-prefix() {
-  [layout-fill] {
-    margin: 0;
-    width: 100%;
-    min-height: 100%;
-    height: 100%;
-  }
-}
-/** Mixin to create distinct classes for fab positions, e.g. ".mat-fab-position-bottom-right". */
-/* stylelint-disable function-url-quotes, no-duplicate-selectors */
-/*
-*
-*  Responsive attributes
-*
-*  References:
-*  1) https://scotch.io/tutorials/a-visual-guide-to-css3-flexbox-properties#flex
-*  2) https://css-tricks.com/almanac/properties/f/flex/
-*  3) https://css-tricks.com/snippets/css/a-guide-to-flexbox/
-*  4) https://github.com/philipwalton/flexbugs#3-min-height-on-a-flex-container-wont-apply-to-its-flex-items
-*  5) http://godban.com.ua/projects/flexgrid
-*
-*/
-@-moz-document url-prefix() {
-  [layout-fill] {
-    margin: 0;
-    width: 100%;
-    min-height: 100%;
-    height: 100%;
-  }
-}
-[mat-fab].mat-fab-position-bottom-right,
-.mat-fab.mat-fab-position-bottom-right,
-[mat-fab].mat-fab-bottom-right,
-.mat-fab.mat-fab-bottom-right {
-  top: auto;
-  right: 20px;
-  left: auto;
-  bottom: 20px;
-  position: absolute;
-}
-html[dir=rtl] [mat-fab].mat-fab-position-bottom-right,
-html[dir=rtl] .mat-fab.mat-fab-position-bottom-right,
-html[dir=rtl] [mat-fab].mat-fab-bottom-right,
-html[dir=rtl] .mat-fab.mat-fab-bottom-right {
-  right: auto;
-  unicode-bidi: embed;
-}
-body[dir=rtl] [mat-fab].mat-fab-position-bottom-right,
-body[dir=rtl] .mat-fab.mat-fab-position-bottom-right,
-body[dir=rtl] [mat-fab].mat-fab-bottom-right,
-body[dir=rtl] .mat-fab.mat-fab-bottom-right {
-  right: auto;
-  unicode-bidi: embed;
-}
-[dir=rtl] [mat-fab].mat-fab-position-bottom-right,
-[dir=rtl] .mat-fab.mat-fab-position-bottom-right,
-[dir=rtl] [mat-fab].mat-fab-bottom-right,
-[dir=rtl] .mat-fab.mat-fab-bottom-right {
-  right: auto;
-  unicode-bidi: embed;
-}
-[mat-fab].mat-fab-position-bottom-right bdo[dir=rtl],
-.mat-fab.mat-fab-position-bottom-right bdo[dir=rtl],
-[mat-fab].mat-fab-bottom-right bdo[dir=rtl],
-.mat-fab.mat-fab-bottom-right bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-bottom-right bdo[dir=ltr],
-.mat-fab.mat-fab-position-bottom-right bdo[dir=ltr],
-[mat-fab].mat-fab-bottom-right bdo[dir=ltr],
-.mat-fab.mat-fab-bottom-right bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-html[dir=rtl] [mat-fab].mat-fab-position-bottom-right,
-html[dir=rtl] .mat-fab.mat-fab-position-bottom-right,
-html[dir=rtl] [mat-fab].mat-fab-bottom-right,
-html[dir=rtl] .mat-fab.mat-fab-bottom-right {
-  left: 20px;
-  unicode-bidi: embed;
-}
-body[dir=rtl] [mat-fab].mat-fab-position-bottom-right,
-body[dir=rtl] .mat-fab.mat-fab-position-bottom-right,
-body[dir=rtl] [mat-fab].mat-fab-bottom-right,
-body[dir=rtl] .mat-fab.mat-fab-bottom-right {
-  left: 20px;
-  unicode-bidi: embed;
-}
-[dir=rtl] [mat-fab].mat-fab-position-bottom-right,
-[dir=rtl] .mat-fab.mat-fab-position-bottom-right,
-[dir=rtl] [mat-fab].mat-fab-bottom-right,
-[dir=rtl] .mat-fab.mat-fab-bottom-right {
-  left: 20px;
-  unicode-bidi: embed;
-}
-[mat-fab].mat-fab-position-bottom-right bdo[dir=rtl],
-.mat-fab.mat-fab-position-bottom-right bdo[dir=rtl],
-[mat-fab].mat-fab-bottom-right bdo[dir=rtl],
-.mat-fab.mat-fab-bottom-right bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-bottom-right bdo[dir=ltr],
-.mat-fab.mat-fab-position-bottom-right bdo[dir=ltr],
-[mat-fab].mat-fab-bottom-right bdo[dir=ltr],
-.mat-fab.mat-fab-bottom-right bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-bottom-right.fixed,
-.mat-fab.mat-fab-position-bottom-right.fixed,
-[mat-fab].mat-fab-bottom-right.fixed,
-.mat-fab.mat-fab-bottom-right.fixed {
-  position: fixed;
-}
-
-[mat-fab].mat-fab-position-bottom-left,
-.mat-fab.mat-fab-position-bottom-left,
-[mat-fab].mat-fab-bottom-left,
-.mat-fab.mat-fab-bottom-left {
-  top: auto;
-  right: auto;
-  left: 20px;
-  bottom: 20px;
-  position: absolute;
-}
-html[dir=rtl] [mat-fab].mat-fab-position-bottom-left,
-html[dir=rtl] .mat-fab.mat-fab-position-bottom-left,
-html[dir=rtl] [mat-fab].mat-fab-bottom-left,
-html[dir=rtl] .mat-fab.mat-fab-bottom-left {
-  right: 20px;
-  unicode-bidi: embed;
-}
-body[dir=rtl] [mat-fab].mat-fab-position-bottom-left,
-body[dir=rtl] .mat-fab.mat-fab-position-bottom-left,
-body[dir=rtl] [mat-fab].mat-fab-bottom-left,
-body[dir=rtl] .mat-fab.mat-fab-bottom-left {
-  right: 20px;
-  unicode-bidi: embed;
-}
-[dir=rtl] [mat-fab].mat-fab-position-bottom-left,
-[dir=rtl] .mat-fab.mat-fab-position-bottom-left,
-[dir=rtl] [mat-fab].mat-fab-bottom-left,
-[dir=rtl] .mat-fab.mat-fab-bottom-left {
-  right: 20px;
-  unicode-bidi: embed;
-}
-[mat-fab].mat-fab-position-bottom-left bdo[dir=rtl],
-.mat-fab.mat-fab-position-bottom-left bdo[dir=rtl],
-[mat-fab].mat-fab-bottom-left bdo[dir=rtl],
-.mat-fab.mat-fab-bottom-left bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-bottom-left bdo[dir=ltr],
-.mat-fab.mat-fab-position-bottom-left bdo[dir=ltr],
-[mat-fab].mat-fab-bottom-left bdo[dir=ltr],
-.mat-fab.mat-fab-bottom-left bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-html[dir=rtl] [mat-fab].mat-fab-position-bottom-left,
-html[dir=rtl] .mat-fab.mat-fab-position-bottom-left,
-html[dir=rtl] [mat-fab].mat-fab-bottom-left,
-html[dir=rtl] .mat-fab.mat-fab-bottom-left {
-  left: auto;
-  unicode-bidi: embed;
-}
-body[dir=rtl] [mat-fab].mat-fab-position-bottom-left,
-body[dir=rtl] .mat-fab.mat-fab-position-bottom-left,
-body[dir=rtl] [mat-fab].mat-fab-bottom-left,
-body[dir=rtl] .mat-fab.mat-fab-bottom-left {
-  left: auto;
-  unicode-bidi: embed;
-}
-[dir=rtl] [mat-fab].mat-fab-position-bottom-left,
-[dir=rtl] .mat-fab.mat-fab-position-bottom-left,
-[dir=rtl] [mat-fab].mat-fab-bottom-left,
-[dir=rtl] .mat-fab.mat-fab-bottom-left {
-  left: auto;
-  unicode-bidi: embed;
-}
-[mat-fab].mat-fab-position-bottom-left bdo[dir=rtl],
-.mat-fab.mat-fab-position-bottom-left bdo[dir=rtl],
-[mat-fab].mat-fab-bottom-left bdo[dir=rtl],
-.mat-fab.mat-fab-bottom-left bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-bottom-left bdo[dir=ltr],
-.mat-fab.mat-fab-position-bottom-left bdo[dir=ltr],
-[mat-fab].mat-fab-bottom-left bdo[dir=ltr],
-.mat-fab.mat-fab-bottom-left bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-bottom-left.fixed,
-.mat-fab.mat-fab-position-bottom-left.fixed,
-[mat-fab].mat-fab-bottom-left.fixed,
-.mat-fab.mat-fab-bottom-left.fixed {
-  position: fixed;
-}
-
-[mat-fab].mat-fab-position-top-right,
-.mat-fab.mat-fab-position-top-right,
-[mat-fab].mat-fab-top-right,
-.mat-fab.mat-fab-top-right {
-  top: 20px;
-  right: 20px;
-  left: auto;
-  bottom: auto;
-  position: absolute;
-}
-html[dir=rtl] [mat-fab].mat-fab-position-top-right,
-html[dir=rtl] .mat-fab.mat-fab-position-top-right,
-html[dir=rtl] [mat-fab].mat-fab-top-right,
-html[dir=rtl] .mat-fab.mat-fab-top-right {
-  right: auto;
-  unicode-bidi: embed;
-}
-body[dir=rtl] [mat-fab].mat-fab-position-top-right,
-body[dir=rtl] .mat-fab.mat-fab-position-top-right,
-body[dir=rtl] [mat-fab].mat-fab-top-right,
-body[dir=rtl] .mat-fab.mat-fab-top-right {
-  right: auto;
-  unicode-bidi: embed;
-}
-[dir=rtl] [mat-fab].mat-fab-position-top-right,
-[dir=rtl] .mat-fab.mat-fab-position-top-right,
-[dir=rtl] [mat-fab].mat-fab-top-right,
-[dir=rtl] .mat-fab.mat-fab-top-right {
-  right: auto;
-  unicode-bidi: embed;
-}
-[mat-fab].mat-fab-position-top-right bdo[dir=rtl],
-.mat-fab.mat-fab-position-top-right bdo[dir=rtl],
-[mat-fab].mat-fab-top-right bdo[dir=rtl],
-.mat-fab.mat-fab-top-right bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-top-right bdo[dir=ltr],
-.mat-fab.mat-fab-position-top-right bdo[dir=ltr],
-[mat-fab].mat-fab-top-right bdo[dir=ltr],
-.mat-fab.mat-fab-top-right bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-html[dir=rtl] [mat-fab].mat-fab-position-top-right,
-html[dir=rtl] .mat-fab.mat-fab-position-top-right,
-html[dir=rtl] [mat-fab].mat-fab-top-right,
-html[dir=rtl] .mat-fab.mat-fab-top-right {
-  left: 20px;
-  unicode-bidi: embed;
-}
-body[dir=rtl] [mat-fab].mat-fab-position-top-right,
-body[dir=rtl] .mat-fab.mat-fab-position-top-right,
-body[dir=rtl] [mat-fab].mat-fab-top-right,
-body[dir=rtl] .mat-fab.mat-fab-top-right {
-  left: 20px;
-  unicode-bidi: embed;
-}
-[dir=rtl] [mat-fab].mat-fab-position-top-right,
-[dir=rtl] .mat-fab.mat-fab-position-top-right,
-[dir=rtl] [mat-fab].mat-fab-top-right,
-[dir=rtl] .mat-fab.mat-fab-top-right {
-  left: 20px;
-  unicode-bidi: embed;
-}
-[mat-fab].mat-fab-position-top-right bdo[dir=rtl],
-.mat-fab.mat-fab-position-top-right bdo[dir=rtl],
-[mat-fab].mat-fab-top-right bdo[dir=rtl],
-.mat-fab.mat-fab-top-right bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-top-right bdo[dir=ltr],
-.mat-fab.mat-fab-position-top-right bdo[dir=ltr],
-[mat-fab].mat-fab-top-right bdo[dir=ltr],
-.mat-fab.mat-fab-top-right bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-top-right.fixed,
-.mat-fab.mat-fab-position-top-right.fixed,
-[mat-fab].mat-fab-top-right.fixed,
-.mat-fab.mat-fab-top-right.fixed {
-  position: fixed;
-}
-
-[mat-fab].mat-fab-position-top-left,
-.mat-fab.mat-fab-position-top-left,
-[mat-fab].mat-fab-top-left,
-.mat-fab.mat-fab-top-left {
-  top: 20px;
-  right: auto;
-  left: 20px;
-  bottom: auto;
-  position: absolute;
-}
-html[dir=rtl] [mat-fab].mat-fab-position-top-left,
-html[dir=rtl] .mat-fab.mat-fab-position-top-left,
-html[dir=rtl] [mat-fab].mat-fab-top-left,
-html[dir=rtl] .mat-fab.mat-fab-top-left {
-  right: 20px;
-  unicode-bidi: embed;
-}
-body[dir=rtl] [mat-fab].mat-fab-position-top-left,
-body[dir=rtl] .mat-fab.mat-fab-position-top-left,
-body[dir=rtl] [mat-fab].mat-fab-top-left,
-body[dir=rtl] .mat-fab.mat-fab-top-left {
-  right: 20px;
-  unicode-bidi: embed;
-}
-[dir=rtl] [mat-fab].mat-fab-position-top-left,
-[dir=rtl] .mat-fab.mat-fab-position-top-left,
-[dir=rtl] [mat-fab].mat-fab-top-left,
-[dir=rtl] .mat-fab.mat-fab-top-left {
-  right: 20px;
-  unicode-bidi: embed;
-}
-[mat-fab].mat-fab-position-top-left bdo[dir=rtl],
-.mat-fab.mat-fab-position-top-left bdo[dir=rtl],
-[mat-fab].mat-fab-top-left bdo[dir=rtl],
-.mat-fab.mat-fab-top-left bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-top-left bdo[dir=ltr],
-.mat-fab.mat-fab-position-top-left bdo[dir=ltr],
-[mat-fab].mat-fab-top-left bdo[dir=ltr],
-.mat-fab.mat-fab-top-left bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-html[dir=rtl] [mat-fab].mat-fab-position-top-left,
-html[dir=rtl] .mat-fab.mat-fab-position-top-left,
-html[dir=rtl] [mat-fab].mat-fab-top-left,
-html[dir=rtl] .mat-fab.mat-fab-top-left {
-  left: auto;
-  unicode-bidi: embed;
-}
-body[dir=rtl] [mat-fab].mat-fab-position-top-left,
-body[dir=rtl] .mat-fab.mat-fab-position-top-left,
-body[dir=rtl] [mat-fab].mat-fab-top-left,
-body[dir=rtl] .mat-fab.mat-fab-top-left {
-  left: auto;
-  unicode-bidi: embed;
-}
-[dir=rtl] [mat-fab].mat-fab-position-top-left,
-[dir=rtl] .mat-fab.mat-fab-position-top-left,
-[dir=rtl] [mat-fab].mat-fab-top-left,
-[dir=rtl] .mat-fab.mat-fab-top-left {
-  left: auto;
-  unicode-bidi: embed;
-}
-[mat-fab].mat-fab-position-top-left bdo[dir=rtl],
-.mat-fab.mat-fab-position-top-left bdo[dir=rtl],
-[mat-fab].mat-fab-top-left bdo[dir=rtl],
-.mat-fab.mat-fab-top-left bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-top-left bdo[dir=ltr],
-.mat-fab.mat-fab-position-top-left bdo[dir=ltr],
-[mat-fab].mat-fab-top-left bdo[dir=ltr],
-.mat-fab.mat-fab-top-left bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-[mat-fab].mat-fab-position-top-left.fixed,
-.mat-fab.mat-fab-position-top-left.fixed,
-[mat-fab].mat-fab-top-left.fixed,
-.mat-fab.mat-fab-top-left.fixed {
-  position: fixed;
-}
-
-button[mat-icon-button].mat-icon-button-mini {
-  height: 24px;
-  line-height: 24px;
-  width: 24px;
-}
-
-html .mat-card {
-  padding: 0;
-  margin: 8px;
-}
-html .mat-card mat-card-header {
-  height: auto;
-}
-html .mat-card [matCardAvatar] {
-  font-size: 40px;
-  line-height: 40px;
-  height: 40px;
-  width: 40px;
-  margin: 16px 0 0 15px;
-  border-radius: 50%;
-}
-html .mat-card .mat-card-image {
-  width: 100%;
-}
-html .mat-card .mat-card-image,
-html .mat-card .mat-card-lg-image,
-html .mat-card .mat-card-md-image,
-html .mat-card .mat-card-sm-image,
-html .mat-card .mat-card-title-group {
-  margin: 0;
-}
-html .mat-card mat-card-title {
-  padding-top: 16px;
-  padding-left: 16px;
-  padding-right: 16px;
-}
-html .mat-card mat-card-subtitle {
-  padding-left: 16px;
-  padding-right: 16px;
-}
-html .mat-card mat-card-content {
-  padding: 16px;
-}
-html .mat-card .mat-card-actions, html .mat-card .mat-card .mat-card-actions {
-  padding: 8px;
-  margin: 0;
-}
-html .mat-card .mat-card-actions:last-child {
-  margin-bottom: 0;
-  padding-bottom: 8px;
-}
-html .mat-card .mat-divider.relative {
-  position: relative;
-}
-html[dir=rtl] .mat-card-title-group .mat-card-image:last-child,
-html[dir=rtl] .mat-card-title-group .mat-card-lg-image:last-child,
-html[dir=rtl] .mat-card-title-group .mat-card-md-image:last-child,
-html[dir=rtl] .mat-card-title-group .mat-card-sm-image:last-child {
-  border-top-left-radius: 2px;
-  border-bottom-left-radius: 2px;
-}
-html[dir=rtl] .mat-card .mat-card-image:first-child {
-  border-top-left-radius: 2px;
-  border-top-right-radius: 2px;
-}
-html[dir=rtl] .mat-card .mat-card-lg-image:first-child,
-html[dir=rtl] .mat-card .mat-card-md-image:first-child,
-html[dir=rtl] .mat-card .mat-card-sm-image:first-child {
-  border-top-right-radius: 2px;
-}
-html:not([dir=rtl]) .mat-card-title-group .mat-card-image:last-child,
-html:not([dir=rtl]) .mat-card-title-group .mat-card-lg-image:last-child,
-html:not([dir=rtl]) .mat-card-title-group .mat-card-md-image:last-child,
-html:not([dir=rtl]) .mat-card-title-group .mat-card-sm-image:last-child {
-  border-top-right-radius: 2px;
-  border-bottom-right-radius: 2px;
-}
-html:not([dir=rtl]) .mat-card .mat-card-image:first-child {
-  border-top-left-radius: 2px;
-  border-top-right-radius: 2px;
-}
-html:not([dir=rtl]) .mat-card .mat-card-lg-image:first-child,
-html:not([dir=rtl]) .mat-card .mat-card-md-image:first-child,
-html:not([dir=rtl]) .mat-card .mat-card-sm-image:first-child {
-  border-top-left-radius: 2px;
-}
-
-.mat-card-colored[href]:hover, .mat-card-colored[ng-reflect-href]:hover {
-  cursor: pointer;
-  box-shadow: 0 2px 4px -1px rgba(0, 0, 0, 0.2), 0 4px 5px 0 rgba(0, 0, 0, 0.14), 0 1px 10px 0 rgba(0, 0, 0, 0.12);
-}
-.mat-card-colored[href]:active, .mat-card-colored[ng-reflect-href]:active {
-  box-shadow: 0 6px 6px -3px rgba(0, 0, 0, 0.2), 0 10px 14px 1px rgba(0, 0, 0, 0.14), 0 4px 18px 3px rgba(0, 0, 0, 0.12);
-}
-.mat-card-colored[href]:active mat-toolbar, .mat-card-colored[ng-reflect-href]:active mat-toolbar {
-  background-color: rgba(255, 255, 255, 0.2);
-  background-position: -100% 100%;
-}
-.mat-card-colored[href] mat-toolbar, .mat-card-colored[ng-reflect-href] mat-toolbar {
-  background-size: 200% 100%;
-  background-image: linear-gradient(to right, transparent 50%, rgba(255, 255, 255, 0.2) 50%);
-  transition: background-position 0.3s cubic-bezier(0.19, 1, 0.22, 1) 0.1s, color 0.5s ease 0s, background-color 0.5s ease;
-}
-.mat-card-colored mat-toolbar {
-  height: 148px;
-  border-radius: 2px 2px 0 0;
-  overflow: hidden;
-}
-.mat-card-colored mat-toolbar mat-icon,
-.mat-card-colored mat-toolbar .mat-icon {
-  opacity: 0.65;
-  color: white;
-  font-size: 8rem;
-  text-shadow: 0 0 rgba(0, 0, 0, 0.01), 1px 1px rgba(0, 0, 0, 0.01), 2px 2px rgba(0, 0, 0, 0.01), 3px 3px rgba(0, 0, 0, 0.01), 4px 4px rgba(0, 0, 0, 0.01), 5px 5px rgba(0, 0, 0, 0.01), 6px 6px rgba(0, 0, 0, 0.01), 7px 7px rgba(0, 0, 0, 0.01), 8px 8px rgba(0, 0, 0, 0.01), 9px 9px rgba(0, 0, 0, 0.01), 10px 10px rgba(0, 0, 0, 0.01), 11px 11px rgba(0, 0, 0, 0.01), 12px 12px rgba(0, 0, 0, 0.01), 13px 13px rgba(0, 0, 0, 0.01), 14px 14px rgba(0, 0, 0, 0.01), 15px 15px rgba(0, 0, 0, 0.01), 16px  [...]
-}
-
-md-content,
-[md-content],
-.md-content,
-mat-content,
-[mat-content],
-.mat-content {
-  display: block;
-  position: relative;
-  overflow: auto;
-  -webkit-overflow-scrolling: touch;
-}
-md-content[md-scroll-y], md-content.mat-scroll-y,
-[md-content][md-scroll-y],
-[md-content].mat-scroll-y,
-.md-content[md-scroll-y],
-.md-content.mat-scroll-y,
-mat-content[md-scroll-y],
-mat-content.mat-scroll-y,
-[mat-content][md-scroll-y],
-[mat-content].mat-scroll-y,
-.mat-content[md-scroll-y],
-.mat-content.mat-scroll-y {
-  overflow-y: auto;
-  overflow-x: hidden;
-}
-md-content[md-scroll-x], md-content.mat-scroll-x,
-[md-content][md-scroll-x],
-[md-content].mat-scroll-x,
-.md-content[md-scroll-x],
-.md-content.mat-scroll-x,
-mat-content[md-scroll-x],
-mat-content.mat-scroll-x,
-[mat-content][md-scroll-x],
-[mat-content].mat-scroll-x,
-.mat-content[md-scroll-x],
-.mat-content.mat-scroll-x {
-  overflow-x: auto;
-  overflow-y: hidden;
-}
-md-content.autoScroll,
-[md-content].autoScroll,
-.md-content.autoScroll,
-mat-content.autoScroll,
-[mat-content].autoScroll,
-.mat-content.autoScroll {
-  -webkit-overflow-scrolling: auto;
-}
-
-mat-sidenav-container > md-content, mat-sidenav-container > [md-content], mat-sidenav-container > .md-content, mat-sidenav-container > mat-content, mat-sidenav-container > [mat-content], mat-sidenav-container > .mat-content {
-  height: 100%;
-  overflow: hidden;
-}
-
-mat-divider[matInset] {
-  margin-left: 72px;
-  margin-right: 0;
-}
-html[dir=rtl] mat-divider[matInset] {
-  margin-left: 0;
-  unicode-bidi: embed;
-}
-body[dir=rtl] mat-divider[matInset] {
-  margin-left: 0;
-  unicode-bidi: embed;
-}
-[dir=rtl] mat-divider[matInset] {
-  margin-left: 0;
-  unicode-bidi: embed;
-}
-mat-divider[matInset] bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-mat-divider[matInset] bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-html[dir=rtl] mat-divider[matInset] {
-  margin-right: 72px;
-  unicode-bidi: embed;
-}
-body[dir=rtl] mat-divider[matInset] {
-  margin-right: 72px;
-  unicode-bidi: embed;
-}
-[dir=rtl] mat-divider[matInset] {
-  margin-right: 72px;
-  unicode-bidi: embed;
-}
-mat-divider[matInset] bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-mat-divider[matInset] bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-mat-divider[mat-inset] {
-  margin-left: 72px;
-  margin-right: 0;
-}
-html[dir=rtl] mat-divider[mat-inset] {
-  margin-left: 0;
-  unicode-bidi: embed;
-}
-body[dir=rtl] mat-divider[mat-inset] {
-  margin-left: 0;
-  unicode-bidi: embed;
-}
-[dir=rtl] mat-divider[mat-inset] {
-  margin-left: 0;
-  unicode-bidi: embed;
-}
-mat-divider[mat-inset] bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-mat-divider[mat-inset] bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-html[dir=rtl] mat-divider[mat-inset] {
-  margin-right: 72px;
-  unicode-bidi: embed;
-}
-body[dir=rtl] mat-divider[mat-inset] {
-  margin-right: 72px;
-  unicode-bidi: embed;
-}
-[dir=rtl] mat-divider[mat-inset] {
-  margin-right: 72px;
-  unicode-bidi: embed;
-}
-mat-divider[mat-inset] bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-mat-divider[mat-inset] bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-
-mat-list-item mat-icon[matListAvatar],
-.mat-list-item-content mat-icon[matListAvatar] {
-  align-items: center;
-  align-content: center;
-  justify-content: center;
-  display: flex;
-}
-
-.mat-icon.mat-icon-logo {
-  height: 24px;
-  width: 100px;
-}
-
-.mat-icon {
-  flex-shrink: 0;
-}
-
-mat-list mat-list-item [matListAvatar],
-mat-list a[mat-list-item] [matListAvatar],
-mat-nav-list mat-list-item [matListAvatar],
-mat-nav-list a[mat-list-item] [matListAvatar] {
-  min-width: 40px;
-}
-
-mat-sidenav {
-  width: 320px;
-}
-mat-sidenav .mat-list-item-content mat-icon {
-  margin-left: 0;
-  margin-right: 16px;
-}
-html[dir=rtl] mat-sidenav .mat-list-item-content mat-icon {
-  margin-left: 16px;
-  unicode-bidi: embed;
-}
-body[dir=rtl] mat-sidenav .mat-list-item-content mat-icon {
-  margin-left: 16px;
-  unicode-bidi: embed;
-}
-[dir=rtl] mat-sidenav .mat-list-item-content mat-icon {
-  margin-left: 16px;
-  unicode-bidi: embed;
-}
-mat-sidenav .mat-list-item-content mat-icon bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-mat-sidenav .mat-list-item-content mat-icon bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-html[dir=rtl] mat-sidenav .mat-list-item-content mat-icon {
-  margin-right: 0;
-  unicode-bidi: embed;
-}
-body[dir=rtl] mat-sidenav .mat-list-item-content mat-icon {
-  margin-right: 0;
-  unicode-bidi: embed;
-}
-[dir=rtl] mat-sidenav .mat-list-item-content mat-icon {
-  margin-right: 0;
-  unicode-bidi: embed;
-}
-mat-sidenav .mat-list-item-content mat-icon bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-mat-sidenav .mat-list-item-content mat-icon bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-mat-sidenav [mat-list-item], mat-sidenav [mat-list-item]:active, mat-sidenav [mat-list-item]:focus {
-  outline: none;
-}
-
-html,
-body {
-  height: 100%;
-  color: rgba(0, 0, 0, 0.87);
-  background: white;
-  position: relative;
-}
-
-body {
-  margin: 0;
-  padding: 0;
-}
-
-[tabindex="-1"]:focus {
-  outline: none;
-}
-
-.inset {
-  padding: 10px;
-}
-
-button.md-no-style {
-  font-weight: normal;
-  background-color: inherit;
-  text-align: left;
-  border: none;
-  padding: 0;
-  margin: 0;
-}
-html[dir=rtl] button.md-no-style {
-  text-align: right;
-  unicode-bidi: embed;
-}
-body[dir=rtl] button.md-no-style {
-  text-align: right;
-  unicode-bidi: embed;
-}
-[dir=rtl] button.md-no-style {
-  text-align: right;
-  unicode-bidi: embed;
-}
-button.md-no-style bdo[dir=rtl] {
-  direction: rtl;
-  unicode-bidi: bidi-override;
-}
-button.md-no-style bdo[dir=ltr] {
-  direction: ltr;
-  unicode-bidi: bidi-override;
-}
-
-select,
-button,
-textarea,
-input {
-  vertical-align: baseline;
-}
-
-input[type=reset],
-input[type=submit],
-html input[type=button],
-button {
-  cursor: pointer;
-  -webkit-appearance: button;
-}
-input[type=reset][disabled],
-input[type=submit][disabled],
-html input[type=button][disabled],
-button[disabled] {
-  cursor: default;
-}
-
-textarea {
-  vertical-align: top;
-  overflow: auto;
-}
-
-input[type=search] {
-  -webkit-appearance: textfield;
-  box-sizing: content-box;
-  -webkit-box-sizing: content-box;
-}
-input[type=search]::-webkit-search-decoration, input[type=search]::-webkit-search-cancel-button {
-  -webkit-appearance: none;
-}
-
-.md-visually-hidden,
-.mat-visually-hidden {
-  border: 0;
-  clip: rect(0 0 0 0);
-  height: 1px;
-  margin: -1px;
-  overflow: hidden;
-  padding: 0;
-  position: absolute;
-  text-transform: none;
-  width: 1px;
-}
-
-.md-shadow,
-.mat-shadow {
-  position: absolute;
-  top: 0;
-  left: 0;
-  bottom: 0;
-  right: 0;
-  border-radius: inherit;
-  pointer-events: none;
-}
-
-.md-shadow-bottom-z-1,
-.mat-shadow-bottom-z-1 {
-  box-shadow: 0 2px 5px 0 rgba(0, 0, 0, 0.26);
-}
-
-.md-shadow-bottom-z-2,
-.mat-shadow-bottom-z-2 {
-  box-shadow: 0 4px 8px 0 rgba(0, 0, 0, 0.4);
-}
-
-.md-shadow-animated.md-shadow,
-.mat-shadow-animated.mat-shadow {
-  transition: box-shadow 0.28s cubic-bezier(0.4, 0, 0.2, 1);
-}
-
-.md-padding,
-.mat-padding {
-  padding: 8px;
-}
-
-.md-margin,
-.mat-margin {
-  margin: 8px;
-}
-
-@media (min-width: 960px) {
-  .md-padding,
-.mat-padding {
-    padding: 16px;
-  }
-}
-body[dense] mat-toolbar.mat-toolbar-multiple-rows .mat-toolbar-row,
-body[dense] mat-toolbar.mat-toolbar-multiple-rows .mat-toolbar-single-row,
-body[dense] mat-toolbar-row.mat-toolbar-multiple-rows .mat-toolbar-row,
-body[dense] mat-toolbar-row.mat-toolbar-multiple-rows .mat-toolbar-single-row,
-mat-toolbar[dense].mat-toolbar-multiple-rows .mat-toolbar-row,
-mat-toolbar[dense].mat-toolbar-multiple-rows .mat-toolbar-single-row,
-mat-toolbar-row[dense].mat-toolbar-multiple-rows .mat-toolbar-row,
-mat-toolbar-row[dense].mat-toolbar-multiple-rows .mat-toolbar-single-row {
-  height: 48px;
-}
-body[dense] mat-toolbar.mat-toolbar-single-row, body[dense] mat-toolbar.mat-toolbar-row,
-body[dense] mat-toolbar-row.mat-toolbar-single-row,
-body[dense] mat-toolbar-row.mat-toolbar-row,
-mat-toolbar[dense].mat-toolbar-single-row,
-mat-toolbar[dense].mat-toolbar-row,
-mat-toolbar-row[dense].mat-toolbar-single-row,
-mat-toolbar-row[dense].mat-toolbar-row {
-  height: 48px;
-}
-
-mat-toolbar [mat-button]:first-of-type:not(:last-child) {
-  margin-left: -6px;
-}
-[dir=rtl] mat-toolbar [mat-button]:first-of-type:not(:last-child) {
-  margin-right: -6px;
-  margin-left: 0;
-}
-mat-toolbar [mat-button]:last-of-type:not(:first-child) {
-  margin-right: -6px;
-}
-[dir=rtl] mat-toolbar [mat-button]:last-of-type:not(:first-child) {
-  margin-left: -6px;
-  margin-right: 0;
-}
-mat-toolbar .mat-icon-logo {
-  margin-right: 10px;
-}
-[dir=rtl] mat-toolbar .mat-icon-logo {
-  margin-left: 10px;
-  margin-right: 0;
-}
-mat-toolbar [mat-icon-button] {
-  margin: 0 6px;
-}
-
-.md-whiteframe-1dp,
-.md-whiteframe-z1,
-.mat-whiteframe-1dp,
-.mat-whiteframe-z1 {
-  box-shadow: 0 1px 3px 0 rgba(0, 0, 0, 0.2), 0 1px 1px 0 rgba(0, 0, 0, 0.14), 0 2px 1px -1px rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-2dp,
-.mat-whiteframe-2dp {
-  box-shadow: 0 1px 5px 0 rgba(0, 0, 0, 0.2), 0 2px 2px 0 rgba(0, 0, 0, 0.14), 0 3px 1px -2px rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-3dp,
-.mat-whiteframe-3dp {
-  box-shadow: 0 1px 8px 0 rgba(0, 0, 0, 0.2), 0 3px 4px 0 rgba(0, 0, 0, 0.14), 0 3px 3px -2px rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-4dp,
-.md-whiteframe-z2,
-.mat-whiteframe-4dp,
-.mat-whiteframe-z2 {
-  box-shadow: 0 2px 4px -1px rgba(0, 0, 0, 0.2), 0 4px 5px 0 rgba(0, 0, 0, 0.14), 0 1px 10 0 rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-5dp,
-.mat-whiteframe-5dp {
-  box-shadow: 0 3px 5px -1px rgba(0, 0, 0, 0.2), 0 5px 8px 0 rgba(0, 0, 0, 0.14), 0 1px 14px 0 rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-6dp,
-.mat-whiteframe-6dp {
-  box-shadow: 0 3px 5px -1px rgba(0, 0, 0, 0.2), 0 6px 10 0 rgba(0, 0, 0, 0.14), 0 1px 18px 0 rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-7dp,
-.md-whiteframe-z3,
-.mat-whiteframe-7dp,
-.mat-whiteframe-z3 {
-  box-shadow: 0 4px 5px -2px rgba(0, 0, 0, 0.2), 0 7px 10 1px rgba(0, 0, 0, 0.14), 0 2px 16px 1px rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-8dp,
-.mat-whiteframe-8dp {
-  box-shadow: 0 5px 5px -3px rgba(0, 0, 0, 0.2), 0 8px 10 1px rgba(0, 0, 0, 0.14), 0 3px 14px 2px rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-9dp,
-.mat-whiteframe-9dp {
-  box-shadow: 0 5px 6px -3px rgba(0, 0, 0, 0.2), 0 9px 12px 1px rgba(0, 0, 0, 0.14), 0 3px 16px 2px rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-10dp,
-.md-whiteframe-z4,
-.mat-whiteframe-10dp,
-.mat-whiteframe-z4 {
-  box-shadow: 0 6px 6px -3px rgba(0, 0, 0, 0.2), 0 10 14px 1px rgba(0, 0, 0, 0.14), 0 4px 18px 3px rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-11dp,
-.mat-whiteframe-11dp {
-  box-shadow: 0 6px 7px -4px rgba(0, 0, 0, 0.2), 0 11px 15px 1px rgba(0, 0, 0, 0.14), 0 4px 20 3px rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-12dp,
-.mat-whiteframe-12dp {
-  box-shadow: 0 7px 8px -4px rgba(0, 0, 0, 0.2), 0 12px 17px 2px rgba(0, 0, 0, 0.14), 0 5px 22px 4px rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-13dp,
-.md-whiteframe-z5,
-.mat-whiteframe-13dp,
-.mat-whiteframe-z5 {
-  box-shadow: 0 7px 8px -4px rgba(0, 0, 0, 0.2), 0 13px 19px 2px rgba(0, 0, 0, 0.14), 0 5px 24px 4px rgba(0, 0, 0, 0.12);
-}
-
-.md-whiteframe-14dp,
-.mat-whiteframe-14dp {
-  box-shadow: 0 7px 9px -4px rgba(0, 0, 0, 0.2), 0 14px 21px 2px rgba(0, 0, 0, 0.14), 0 5px 26px 4px rgba(0, 0, 0, 0.12);
-}
-
-@font-face {
-  font-family: "Material Icons";
-  font-style: normal;
-  font-weight: 400;
-  src: url("node_modules/@covalent/core/common/styles/font/MaterialIcons-Regular-v48.woff2") format("woff2");
-}
-.material-icons {
-  /* stylelint-disable-next-line font-family-no-missing-generic-family-keyword */
-  font-family: "Material Icons";
-  font-weight: normal;
-  font-style: normal;
-  font-size: 24px;
-  /* Preferred icon size */
-  display: inline-block;
-  width: 1em;
-  height: 1em;
-  line-height: 1;
-  text-transform: none;
-  letter-spacing: normal;
-  word-wrap: normal;
-  white-space: nowrap;
-  direction: ltr;
-  /* Support for all WebKit browsers. */
-  -webkit-font-smoothing: antialiased;
-  /* Support for Safari and Chrome. */
-  text-rendering: optimizeLegibility;
-  /* Support for Firefox. */
-  -moz-osx-font-smoothing: grayscale;
-  /* Support for IE. */
-  font-feature-settings: "liga";
-}
-
-mat-icon.material-icons, mat-icon.material-icons.mat-icon {
-  width: 1em;
-  height: 1em;
-}
-
-.material-icons.md-18,
-.material-icons.mat-18 {
-  font-size: 18px;
-  height: 18px;
-  width: 18px;
-}
-
-.material-icons.md-24,
-.material-icons.mat-24 {
-  font-size: 24px;
-  height: 24px;
-  width: 24px;
-}
-
-.material-icons.md-36,
-.material-icons.mat-36 {
-  font-size: 36px;
-  height: 36px;
-  width: 36px;
-}
-
-.material-icons.md-48,
-.material-icons.mat-48 {
-  font-size: 48px;
-  height: 48px;
-  width: 48px;
-}
-
-.material-icons.md-dark,
-.material-icons.mat-dark {
-  color: rgba(0, 0, 0, 0.54);
-}
-
-.material-icons.md-dark.md-inactive,
-.material-icons.mat-dark.mat-inactive {
-  color: rgba(0, 0, 0, 0.26);
-}
-
-.material-icons.md-light,
-.material-icons.mat-light {
-  color: white;
-}
-
-.material-icons.md-light.md-inactive,
-.material-icons.mat-light.mat-inactive {
-  color: rgba(255, 255, 255, 0.3);
-}
-
-body [tabindex]:focus {
-  outline: none;
-}
-body .radius-none {
-  border-radius: 0;
-}
-body .overflow-hidden {
-  overflow: hidden;
-}
-body .overflow-auto {
-  overflow: auto;
-}
-body .overflow-visible {
-  overflow: visible;
-}
-body .block {
-  display: block;
-}
-body .inline-block {
-  display: inline-block;
-}
-body .relative {
-  position: relative;
-}
-body .fixed {
-  position: fixed;
-}
-body .height-auto {
-  min-height: 0;
-}
-body .z-3 {
-  z-index: 3;
-}
-body .z-2 {
-  z-index: 2;
-}
-body .z-1 {
-  z-index: 1;
-}
-body .focus-weight:focus {
-  outline: 0;
-  font-weight: 700;
-}
-body .cursor-pointer:hover {
-  cursor: pointer;
-}
-
-body .pad {
-  padding: 16px;
-}
-body .pad-xxl {
-  padding: 56px;
-}
-body .pad-xl {
-  padding: 48px;
-}
-body .pad-lg {
-  padding: 32px;
-}
-body .pad-md {
-  padding: 24px;
-}
-body .pad-sm {
-  padding: 8px;
-}
-body .pad-xs {
-  padding: 4px;
-}
-body .pad-none {
-  padding: 0;
-}
-body .pad-bottom {
-  padding-bottom: 16px;
-}
-body .pad-bottom-xxl {
-  padding-bottom: 56px;
-}
-body .pad-bottom-xl {
-  padding-bottom: 48px;
-}
-body .pad-bottom-lg {
-  padding-bottom: 32px;
-}
-body .pad-bottom-md {
-  padding-bottom: 24px;
-}
-body .pad-bottom-sm {
-  padding-bottom: 8px;
-}
-body .pad-bottom-xs {
-  padding-bottom: 4px;
-}
-body .pad-bottom-none {
-  padding-bottom: 0;
-}
-body .pad-top {
-  padding-top: 16px;
-}
-body .pad-top-xxl {
-  padding-top: 56px;
-}
-body .pad-top-xl {
-  padding-top: 48px;
-}
-body .pad-top-lg {
-  padding-top: 32px;
-}
-body .pad-top-md {
-  padding-top: 24px;
-}
-body .pad-top-sm {
-  padding-top: 8px;
-}
-body .pad-top-xs {
-  padding-top: 4px;
-}
-body .pad-top-none {
-  padding-top: 0;
-}
-body .pad-left {
-  padding-left: 16px;
-}
-body .pad-left-xxl {
-  padding-left: 56px;
-}
-body .pad-left-xl {
-  padding-left: 48px;
-}
-body .pad-left-lg {
-  padding-left: 32px;
-}
-body .pad-left-md {
-  padding-left: 24px;
-}
-body .pad-left-sm {
-  padding-left: 8px;
-}
-body .pad-left-xs {
-  padding-left: 4px;
-}
-body .pad-left-none {
-  padding-left: 0;
-}
-body .pad-right {
-  padding-right: 16px;
-}
-body .pad-right-xxl {
-  padding-right: 56px;
-}
-body .pad-right-xl {
-  padding-right: 48px;
-}
-body .pad-right-lg {
-  padding-right: 32px;
-}
-body .pad-right-md {
-  padding-right: 24px;
-}
-body .pad-right-sm {
-  padding-right: 8px;
-}
-body .pad-right-xs {
-  padding-right: 4px;
-}
-body .pad-right-none {
-  padding-right: 0;
-}
-
-body .pull-xxl {
-  margin: -56px;
-}
-body .pull-xl {
-  margin: -48px;
-}
-body .pull-lg {
-  margin: -32px;
-}
-body .pull-md {
-  margin: -24px;
-}
-body .pull {
-  margin: -16px;
-}
-body .pull-sm {
-  margin: -8px;
-}
-body .pull-xs {
-  margin: -4px;
-}
-body .pull-none {
-  margin: 0;
-}
-body .pull-bottom-xxl {
-  margin-bottom: -56px;
-}
-body .pull-bottom-xl {
-  margin-bottom: -48px;
-}
-body .pull-bottom-lg {
-  margin-bottom: -32px;
-}
-body .pull-bottom-md {
-  margin-bottom: -24px;
-}
-body .pull-bottom {
-  margin-bottom: -16px;
-}
-body .pull-bottom-sm {
-  margin-bottom: -8px;
-}
-body .pull-bottom-xs {
-  margin-bottom: -4px;
-}
-body .pull-bottom-none {
-  margin-bottom: 0;
-}
-body .pull-top-xxl {
-  margin-top: -56px;
-}
-body .pull-top-xl {
-  margin-top: -48px;
-}
-body .pull-top-lg {
-  margin-top: -32px;
-}
-body .pull-top-md {
-  margin-top: -24px;
-}
-body .pull-top {
-  margin-top: -16px;
-}
-body .pull-top-sm {
-  margin-top: -8px;
-}
-body .pull-top-xs {
-  margin-top: -4px;
-}
-body .pull-top-none {
-  margin-top: 0;
-}
-body .pull-left-xxl {
-  margin-left: -56px;
-}
-body .pull-left-xl {
-  margin-left: -48px;
-}
-body .pull-left-lg {
-  margin-left: -32px;
-}
-body .pull-left-md {
-  margin-left: -24px;
-}
-body .pull-left {
-  margin-left: -16px;
-}
-body .pull-left-sm {
-  margin-left: -8px;
-}
-body .pull-left-xs {
-  margin-left: -4px;
-}
-body .pull-left-none {
-  margin-left: 0;
-}
-body .pull-right-xxl {
-  margin-right: -56px;
-}
-body .pull-right-xl {
-  margin-right: -48px;
-}
-body .pull-right-lg {
-  margin-right: -32px;
-}
-body .pull-right-md {
-  margin-right: -24px;
-}
-body .pull-right {
-  margin-right: -16px;
-}
-body .pull-right-sm {
-  margin-right: -8px;
-}
-body .pull-right-xs {
-  margin-right: -4px;
-}
-body .pull-right-none {
-  margin-right: 0;
-}
-
-body .push {
-  margin: 16px;
-}
-body .push-xxl {
-  margin: 56px;
-}
-body .push-xl {
-  margin: 48px;
-}
-body .push-lg {
-  margin: 32px;
-}
-body .push-md {
-  margin: 24px;
-}
-body .push-sm {
-  margin: 8px;
-}
-body .push-xs {
-  margin: 4px;
-}
-body .push-none {
-  margin: 0;
-}
-body .push-bottom {
-  margin-bottom: 16px;
-}
-body .push-bottom-xxl {
-  margin-bottom: 56px;
-}
-body .push-bottom-xl {
-  margin-bottom: 48px;
-}
-body .push-bottom-lg {
-  margin-bottom: 32px;
-}
-body .push-bottom-md {
-  margin-bottom: 24px;
-}
-body .push-bottom-sm {
-  margin-bottom: 8px;
-}
-body .push-bottom-xs {
-  margin-bottom: 4px;
-}
-body .push-bottom-none {
-  margin-bottom: 0;
-}
-body .push-top {
-  margin-top: 16px;
-}
-body .push-top-xxl {
-  margin-top: 56px;
-}
-body .push-top-xl {
-  margin-top: 48px;
-}
-body .push-top-lg {
-  margin-top: 32px;
-}
-body .push-top-md {
-  margin-top: 24px;
-}
-body .push-top-sm {
-  margin-top: 8px;
-}
-body .push-top-xs {
-  margin-top: 4px;
-}
-body .push-top-none {
-  margin-top: 0;
-}
-body .push-left {
-  margin-left: 16px;
-}
-body .push-left-xxl {
-  margin-left: 56px;
-}
-body .push-left-xl {
-  margin-left: 48px;
-}
-body .push-left-lg {
-  margin-left: 32px;
-}
-body .push-left-md {
-  margin-left: 24px;
-}
-body .push-left-sm {
-  margin-left: 8px;
-}
-body .push-left-xs {
-  margin-left: 4px;
-}
-body .push-left-none {
-  margin-left: 0;
-}
-body .push-right {
-  margin-right: 16px;
-}
-body .push-right-xxl {
-  margin-right: 56px;
-}
-body .push-right-xl {
-  margin-right: 48px;
-}
-body .push-right-lg {
-  margin-right: 32px;
-}
-body .push-right-md {
-  margin-right: 24px;
-}
-body .push-right-sm {
-  margin-right: 8px;
-}
-body .push-right-xs {
-  margin-right: 4px;
-}
-body .push-right-none {
-  margin-right: 0;
-}
-
-.size-12 {
-  height: 12px;
-  width: 12px;
-}
-
-.size-16 {
-  height: 16px;
-  width: 16px;
-}
-
-.size-24 {
-  height: 24px;
-  width: 24px;
-}
-
-.size-32 {
-  height: 32px;
-  width: 32px;
-}
-
-.size-50 {
-  height: 50px;
-  width: 50px;
-}
-
-.size-64 {
-  height: 64px;
-  width: 64px;
-}
-
-.size-72 {
-  height: 72px;
-  width: 72px;
-}
-
-.size-100 {
-  height: 100px;
-  width: 100px;
-}
-
-.size-128 {
-  height: 128px;
-  width: 128px;
-}
-
-.size-256 {
-  height: 256px;
-  width: 256px;
-}
-
-.size-height-12 {
-  height: 12px;
-  width: auto;
-}
-
-.size-height-16 {
-  height: 16px;
-  width: auto;
-}
-
-.size-height-24 {
-  height: 24px;
-  width: auto;
-}
-
-.size-height-32 {
-  height: 32px;
-  width: auto;
-}
-
-.size-height-50 {
-  height: 50px;
-  width: auto;
-}
-
-.size-height-64 {
-  height: 64px;
-  width: auto;
-}
-
-.size-height-72 {
-  height: 72px;
-  width: auto;
-}
-
-.size-height-100 {
-  height: 100px;
-  width: auto;
-}
-
-.size-height-128 {
-  height: 128px;
-  width: auto;
-}
-
-.size-height-256 {
-  height: 256px;
-  width: auto;
-}
-
-.size-width-12 {
-  width: 12px;
-  height: auto;
-}
-
-.size-width-16 {
-  width: 16px;
-  height: auto;
-}
-
-.size-width-24 {
-  width: 24px;
-  height: auto;
-}
-
-.size-width-32 {
-  width: 32px;
-  height: auto;
-}
-
-.size-width-50 {
-  width: 50px;
-  height: auto;
-}
-
-.size-width-64 {
-  width: 64px;
-  height: auto;
-}
-
-.size-width-72 {
-  width: 72px;
-  height: auto;
-}
-
-.size-width-100 {
-  width: 100px;
-  height: auto;
-}
-
-.size-width-128 {
-  width: 128px;
-  height: auto;
-}
-
-.size-width-256 {
-  width: 256px;
-  height: auto;
-}
-
-body h1 > small,
-body h2 > small,
-body h3 > small,
-body h4 > small,
-body h5 > small,
-body h6 > small {
-  font-size: 60%;
-}
-body .text-normal {
-  font-style: normal;
-}
-body .text-center {
-  text-align: center;
-}
-body .text-left {
-  text-align: left;
-}
-body .text-right {
-  text-align: right;
-}
-body .text-xs,
-body .text-sm,
-body .text-md,
-body .text-lg {
-  text-rendering: optimizeLegibility;
-}
-body .text-micro {
-  font-size: 10px;
-  font-weight: normal;
-  letter-spacing: 1px;
-}
-body .text-xs {
-  font-size: 50%;
-}
-body .text-sm {
-  font-size: 70%;
-}
-body .text-md {
-  font-size: 80%;
-}
-body .text-lg {
-  font-size: 110%;
-}
-body .text-xl {
-  font-size: 120%;
-}
-body .text-xxl {
-  font-size: 130%;
-}
-body .text-30 {
-  font-size: 30px;
-}
-body .text-super {
-  font-size: 60px;
-}
-body .text-wrap {
-  white-space: normal;
-}
-body .text-break {
-  word-break: break-word;
-}
-body .text-upper {
-  text-transform: uppercase;
-}
-body .text-lower {
-  text-transform: lowercase;
-}
-body .text-caps {
-  text-transform: capitalize;
-}
-body .text-truncate {
-  white-space: nowrap;
-  overflow: hidden;
-  text-overflow: ellipsis;
-}
-body .text-nodecoration {
-  text-decoration: none;
-}
-
-/*
-*  Apply Mixins to create Layout/Flexbox styles
-*
-*/
-[flex-order] {
-  order: 0;
-}
-
-[flex-order="-20"] {
-  order: -20;
-}
-
-[flex-order="-19"] {
-  order: -19;
-}
-
-[flex-order="-18"] {
-  order: -18;
-}
-
-[flex-order="-17"] {
-  order: -17;
-}
-
-[flex-order="-16"] {
-  order: -16;
-}
-
-[flex-order="-15"] {
-  order: -15;
-}
-
-[flex-order="-14"] {
-  order: -14;
-}
-
-[flex-order="-13"] {
-  order: -13;
-}
-
-[flex-order="-12"] {
-  order: -12;
-}
-
-[flex-order="-11"] {
-  order: -11;
-}
-
-[flex-order="-10"] {
-  order: -10;
-}
-
-[flex-order="-9"] {
-  order: -9;
-}
-
-[flex-order="-8"] {
-  order: -8;
-}
-
-[flex-order="-7"] {
-  order: -7;
-}
-
-[flex-order="-6"] {
-  order: -6;
-}
-
-[flex-order="-5"] {
-  order: -5;
-}
-
-[flex-order="-4"] {
-  order: -4;
-}
-
-[flex-order="-3"] {
-  order: -3;
-}
-
-[flex-order="-2"] {
-  order: -2;
-}
-
-[flex-order="-1"] {
-  order: -1;
-}
-
-[flex-order="0"] {
-  order: 0;
-}
-
-[flex-order="1"] {
-  order: 1;
-}
-
-[flex-order="2"] {
-  order: 2;
-}
-
-[flex-order="3"] {
-  order: 3;
-}
-
-[flex-order="4"] {
-  order: 4;
-}
-
-[flex-order="5"] {
-  order: 5;
-}
-
-[flex-order="6"] {
-  order: 6;
-}
-
-[flex-order="7"] {
-  order: 7;
-}
-
-[flex-order="8"] {
-  order: 8;
-}
-
-[flex-order="9"] {
-  order: 9;
-}
-
-[flex-order="10"] {
-  order: 10;
-}
-
-[flex-order="11"] {
-  order: 11;
-}
-
-[flex-order="12"] {
-  order: 12;
-}
-
-[flex-order="13"] {
-  order: 13;
-}
-
-[flex-order="14"] {
-  order: 14;
-}
-
-[flex-order="15"] {
-  order: 15;
-}
-
-[flex-order="16"] {
-  order: 16;
-}
-
-[flex-order="17"] {
-  order: 17;
-}
-
-[flex-order="18"] {
-  order: 18;
-}
-
-[flex-order="19"] {
-  order: 19;
-}
-
-[flex-order="20"] {
-  order: 20;
-}
-
-[flex-offset="0"] {
-  margin-left: 0%;
-}
-
-[flex-offset="5"] {
-  margin-left: 5%;
-}
-
-[flex-offset="10"] {
-  margin-left: 10%;
-}
-
-[flex-offset="15"] {
-  margin-left: 15%;
-}
-
-[flex-offset="20"] {
-  margin-left: 20%;
-}
-
-[flex-offset="25"] {
-  margin-left: 25%;
-}
-
-[flex-offset="30"] {
-  margin-left: 30%;
-}
-
-[flex-offset="35"] {
-  margin-left: 35%;
-}
-
-[flex-offset="40"] {
-  margin-left: 40%;
-}
-
-[flex-offset="45"] {
-  margin-left: 45%;
-}
-
-[flex-offset="50"] {
-  margin-left: 50%;
-}
-
-[flex-offset="55"] {
-  margin-left: 55%;
-}
-
-[flex-offset="60"] {
-  margin-left: 60%;
-}
-
-[flex-offset="65"] {
-  margin-left: 65%;
-}
-
-[flex-offset="70"] {
-  margin-left: 70%;
-}
-
-[flex-offset="75"] {
-  margin-left: 75%;
-}
-
-[flex-offset="80"] {
-  margin-left: 80%;
-}
-
-[flex-offset="85"] {
-  margin-left: 85%;
-}
-
-[flex-offset="90"] {
-  margin-left: 90%;
-}
-
-[flex-offset="95"] {
-  margin-left: 95%;
-}
-
-[flex-offset="33"] {
-  margin-left: calc(100% / 3);
-}
-
-[flex-offset="66"] {
-  margin-left: calc(200% / 3);
-}
-
-[layout-align],
-[layout-align="start stretch"] {
-  justify-content: flex-start;
-  align-content: stretch;
-  align-items: stretch;
-}
-
-[layout-align=start],
-[layout-align="start start"],
-[layout-align="start center"],
-[layout-align="start end"],
-[layout-align="start stretch"] {
-  justify-content: flex-start;
-}
-
-[layout-align=center],
-[layout-align="center start"],
-[layout-align="center center"],
-[layout-align="center end"],
-[layout-align="center stretch"] {
-  justify-content: center;
-}
-
-[layout-align=end],
-[layout-align="end center"],
-[layout-align="end start"],
-[layout-align="end end"],
-[layout-align="end stretch"] {
-  justify-content: flex-end;
-}
-
-[layout-align=space-around],
-[layout-align="space-around center"],
-[layout-align="space-around start"],
-[layout-align="space-around end"],
-[layout-align="space-around stretch"] {
-  justify-content: space-around;
-}
-
-[layout-align=space-between],
-[layout-align="space-between center"],
-[layout-align="space-between start"],
-[layout-align="space-between end"],
-[layout-align="space-between stretch"] {
-  justify-content: space-between;
-}
-
-[layout-align="start start"],
-[layout-align="center start"],
-[layout-align="end start"],
-[layout-align="space-between start"],
-[layout-align="space-around start"] {
-  align-items: flex-start;
-  align-content: flex-start;
-}
-
-[layout-align="start center"],
-[layout-align="center center"],
-[layout-align="end center"],
-[layout-align="space-between center"],
-[layout-align="space-around center"] {
-  align-items: center;
-  align-content: center;
-  max-width: 100%;
-}
-[layout-align="start center"] > *,
-[layout-align="center center"] > *,
-[layout-align="end center"] > *,
-[layout-align="space-between center"] > *,
-[layout-align="space-around center"] > * {
-  max-width: 100%;
-  box-sizing: border-box;
-}
-
-[layout-align="start center"] > *,
-[layout-align="center center"] > *,
-[layout-align="end center"] > *,
-[layout-align="space-between center"] > *,
-[layout-align="space-around center"] > * {
-  max-width: 100%;
-  box-sizing: border-box;
-}
-
-[layout-align="start end"],
-[layout-align="center end"],
-[layout-align="end end"],
-[layout-align="space-between end"],
-[layout-align="space-around end"] {
-  align-items: flex-end;
-  align-content: flex-end;
-}
-
-[layout-align="start stretch"],
-[layout-align="center stretch"],
-[layout-align="end stretch"],
-[layout-align="space-between stretch"],
-[layout-align="space-around stretch"] {
-  align-items: stretch;
-  align-content: stretch;
-}
-
-[flex] {
-  flex: 1;
-  box-sizing: border-box;
-}
-
-@media screen\0  {
-  [flex] {
-    flex: 1 1 0%;
-  }
-}
-[flex=grow],
-[flex-grow] {
-  flex: 1 1 100%;
-  box-sizing: border-box;
-}
-
-[flex=initial],
-[flex-initial] {
-  flex: 0 1 auto;
-  box-sizing: border-box;
-}
-
-[flex=auto],
-[flex-auto] {
-  flex: 1 1 auto;
-  box-sizing: border-box;
-}
-
-[flex=none],
-[flex-none] {
-  flex: 0 0 auto;
-  box-sizing: border-box;
-}
-
-[flex=noshrink],
-[flex-noshrink] {
-  flex: 1 0 auto;
-  box-sizing: border-box;
-}
-
-[flex=nogrow],
-[flex-nogrow] {
-  flex: 0 1 auto;
-  box-sizing: border-box;
-}
-
-[flex="0"] {
-  flex: 1 1 0%;
-  max-width: 0%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="0"],
-[layout=row] > [flex="0"] {
-  flex: 1 1 0%;
-  max-width: 0%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="0"],
-[layout=column] > [flex="0"] {
-  flex: 1 1 0%;
-  max-width: 100%;
-  max-height: 0%;
-  box-sizing: border-box;
-}
-
-[flex="5"] {
-  flex: 1 1 5%;
-  max-width: 5%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="5"],
-[layout=row] > [flex="5"] {
-  flex: 1 1 5%;
-  max-width: 5%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="5"],
-[layout=column] > [flex="5"] {
-  flex: 1 1 5%;
-  max-width: 100%;
-  max-height: 5%;
-  box-sizing: border-box;
-}
-
-[flex="10"] {
-  flex: 1 1 10%;
-  max-width: 10%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="10"],
-[layout=row] > [flex="10"] {
-  flex: 1 1 10%;
-  max-width: 10%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="10"],
-[layout=column] > [flex="10"] {
-  flex: 1 1 10%;
-  max-width: 100%;
-  max-height: 10%;
-  box-sizing: border-box;
-}
-
-[flex="15"] {
-  flex: 1 1 15%;
-  max-width: 15%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="15"],
-[layout=row] > [flex="15"] {
-  flex: 1 1 15%;
-  max-width: 15%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="15"],
-[layout=column] > [flex="15"] {
-  flex: 1 1 15%;
-  max-width: 100%;
-  max-height: 15%;
-  box-sizing: border-box;
-}
-
-[flex="20"] {
-  flex: 1 1 20%;
-  max-width: 20%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="20"],
-[layout=row] > [flex="20"] {
-  flex: 1 1 20%;
-  max-width: 20%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="20"],
-[layout=column] > [flex="20"] {
-  flex: 1 1 20%;
-  max-width: 100%;
-  max-height: 20%;
-  box-sizing: border-box;
-}
-
-[flex="25"] {
-  flex: 1 1 25%;
-  max-width: 25%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="25"],
-[layout=row] > [flex="25"] {
-  flex: 1 1 25%;
-  max-width: 25%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="25"],
-[layout=column] > [flex="25"] {
-  flex: 1 1 25%;
-  max-width: 100%;
-  max-height: 25%;
-  box-sizing: border-box;
-}
-
-[flex="30"] {
-  flex: 1 1 30%;
-  max-width: 30%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="30"],
-[layout=row] > [flex="30"] {
-  flex: 1 1 30%;
-  max-width: 30%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="30"],
-[layout=column] > [flex="30"] {
-  flex: 1 1 30%;
-  max-width: 100%;
-  max-height: 30%;
-  box-sizing: border-box;
-}
-
-[flex="35"] {
-  flex: 1 1 35%;
-  max-width: 35%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="35"],
-[layout=row] > [flex="35"] {
-  flex: 1 1 35%;
-  max-width: 35%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="35"],
-[layout=column] > [flex="35"] {
-  flex: 1 1 35%;
-  max-width: 100%;
-  max-height: 35%;
-  box-sizing: border-box;
-}
-
-[flex="40"] {
-  flex: 1 1 40%;
-  max-width: 40%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="40"],
-[layout=row] > [flex="40"] {
-  flex: 1 1 40%;
-  max-width: 40%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="40"],
-[layout=column] > [flex="40"] {
-  flex: 1 1 40%;
-  max-width: 100%;
-  max-height: 40%;
-  box-sizing: border-box;
-}
-
-[flex="45"] {
-  flex: 1 1 45%;
-  max-width: 45%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="45"],
-[layout=row] > [flex="45"] {
-  flex: 1 1 45%;
-  max-width: 45%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="45"],
-[layout=column] > [flex="45"] {
-  flex: 1 1 45%;
-  max-width: 100%;
-  max-height: 45%;
-  box-sizing: border-box;
-}
-
-[flex="50"] {
-  flex: 1 1 50%;
-  max-width: 50%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="50"],
-[layout=row] > [flex="50"] {
-  flex: 1 1 50%;
-  max-width: 50%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="50"],
-[layout=column] > [flex="50"] {
-  flex: 1 1 50%;
-  max-width: 100%;
-  max-height: 50%;
-  box-sizing: border-box;
-}
-
-[flex="55"] {
-  flex: 1 1 55%;
-  max-width: 55%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="55"],
-[layout=row] > [flex="55"] {
-  flex: 1 1 55%;
-  max-width: 55%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="55"],
-[layout=column] > [flex="55"] {
-  flex: 1 1 55%;
-  max-width: 100%;
-  max-height: 55%;
-  box-sizing: border-box;
-}
-
-[flex="60"] {
-  flex: 1 1 60%;
-  max-width: 60%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="60"],
-[layout=row] > [flex="60"] {
-  flex: 1 1 60%;
-  max-width: 60%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="60"],
-[layout=column] > [flex="60"] {
-  flex: 1 1 60%;
-  max-width: 100%;
-  max-height: 60%;
-  box-sizing: border-box;
-}
-
-[flex="65"] {
-  flex: 1 1 65%;
-  max-width: 65%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="65"],
-[layout=row] > [flex="65"] {
-  flex: 1 1 65%;
-  max-width: 65%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="65"],
-[layout=column] > [flex="65"] {
-  flex: 1 1 65%;
-  max-width: 100%;
-  max-height: 65%;
-  box-sizing: border-box;
-}
-
-[flex="70"] {
-  flex: 1 1 70%;
-  max-width: 70%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="70"],
-[layout=row] > [flex="70"] {
-  flex: 1 1 70%;
-  max-width: 70%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="70"],
-[layout=column] > [flex="70"] {
-  flex: 1 1 70%;
-  max-width: 100%;
-  max-height: 70%;
-  box-sizing: border-box;
-}
-
-[flex="75"] {
-  flex: 1 1 75%;
-  max-width: 75%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="75"],
-[layout=row] > [flex="75"] {
-  flex: 1 1 75%;
-  max-width: 75%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="75"],
-[layout=column] > [flex="75"] {
-  flex: 1 1 75%;
-  max-width: 100%;
-  max-height: 75%;
-  box-sizing: border-box;
-}
-
-[flex="80"] {
-  flex: 1 1 80%;
-  max-width: 80%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="80"],
-[layout=row] > [flex="80"] {
-  flex: 1 1 80%;
-  max-width: 80%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="80"],
-[layout=column] > [flex="80"] {
-  flex: 1 1 80%;
-  max-width: 100%;
-  max-height: 80%;
-  box-sizing: border-box;
-}
-
-[flex="85"] {
-  flex: 1 1 85%;
-  max-width: 85%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="85"],
-[layout=row] > [flex="85"] {
-  flex: 1 1 85%;
-  max-width: 85%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="85"],
-[layout=column] > [flex="85"] {
-  flex: 1 1 85%;
-  max-width: 100%;
-  max-height: 85%;
-  box-sizing: border-box;
-}
-
-[flex="90"] {
-  flex: 1 1 90%;
-  max-width: 90%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="90"],
-[layout=row] > [flex="90"] {
-  flex: 1 1 90%;
-  max-width: 90%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="90"],
-[layout=column] > [flex="90"] {
-  flex: 1 1 90%;
-  max-width: 100%;
-  max-height: 90%;
-  box-sizing: border-box;
-}
-
-[flex="95"] {
-  flex: 1 1 95%;
-  max-width: 95%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="95"],
-[layout=row] > [flex="95"] {
-  flex: 1 1 95%;
-  max-width: 95%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="95"],
-[layout=column] > [flex="95"] {
-  flex: 1 1 95%;
-  max-width: 100%;
-  max-height: 95%;
-  box-sizing: border-box;
-}
-
-[flex="100"] {
-  flex: 1 1 100%;
-  max-width: 100%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="100"],
-[layout=row] > [flex="100"] {
-  flex: 1 1 100%;
-  max-width: 100%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="100"],
-[layout=column] > [flex="100"] {
-  flex: 1 1 100%;
-  max-width: 100%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=row] > [flex="33"],
-[layout=row] > [flex="33"],
-[layout=row] > [flex="33"],
-[layout=row] > [flex="33"] {
-  flex: 1 1 33%;
-  max-width: calc(100% / 3);
-  max-height: 100%;
-  box-sizing: border-box;
-}
-[layout=row] > [flex="34"],
-[layout=row] > [flex="34"],
-[layout=row] > [flex="34"],
-[layout=row] > [flex="34"] {
-  flex: 1 1 34%;
-  max-width: 34%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-[layout=row] > [flex="66"],
-[layout=row] > [flex="66"],
-[layout=row] > [flex="66"],
-[layout=row] > [flex="66"] {
-  flex: 1 1 66%;
-  max-width: calc(200% / 3);
-  max-height: 100%;
-  box-sizing: border-box;
-}
-[layout=row] > [flex="67"],
-[layout=row] > [flex="67"],
-[layout=row] > [flex="67"],
-[layout=row] > [flex="67"] {
-  flex: 1 1 67%;
-  max-width: 67%;
-  max-height: 100%;
-  box-sizing: border-box;
-}
-
-[layout=column] > [flex="33"],
-[layout=column] > [flex="33"],
-[layout=column] > [flex="33"],
-[layout=column] > [flex="33"] {
-  flex: 1 1 33%;
-  max-width: 100%;
-  max-height: calc(100% / 3);
-  box-sizing: border-box;
-}
-[layout=column] > [flex="34"],
-[layout=column] > [flex="34"],
-[layout=column] > [flex="34"],
-[layout=column] > [flex="34"] {
-  flex: 1 1 34%;
-  max-width: 100%;
-  max-height: 34%;
-  box-sizing: border-box;
-}
-[layout=column] > [flex="66"],
-[layout=column] > [flex="66"],
-[layout=column] > [flex="66"],
-[layout=column] > [flex="66"] {
-  flex: 1 1 66%;
-  max-width: 100%;
-  max-height: calc(200% / 3);
-  box-sizing: border-box;
-}
-[layout=column] > [flex="67"],
-[layout=column] > [flex="67"],
-[layout=column] > [flex="67"],
-[layout=column] > [flex="67"] {
-  flex: 1 1 67%;
-  max-width: 100%;
-  max-height: 67%;
-  box-sizing: border-box;
-}
-
-[layout],
-[layout=column],
-[layout=row] {
-  box-sizing: border-box;
-  display: -webkit-box;
-  display: -webkit-flex;
-  display: -moz-box;
-  display: -ms-flexbox;
-  display: flex;
-}
-
-[layout=column] {
-  flex-direction: column;
-}
-
-[layout=row] {
-  flex-direction: row;
-}
-
-[layout-padding] > [flex-sm],
-[layout-padding] > [flex-lt-md] {
-  padding: 4px;
-}
-
-[layout-padding],
-[layout-padding] > [flex],
-[layout-padding] > [flex-gt-sm],
-[layout-padding] > [flex-md],
-[layout-padding] > [flex-lt-lg] {
-  padding: 8px;
-}
-
-[layout-padding] > [flex-gt-md],
-[layout-padding] > [flex-lg] {
-  padding: 16px;
-}
-
-[layout-margin] > [flex-sm],
-[layout-margin] > [flex-lt-md] {
-  margin: 4px;
-}
-
-[layout-margin],
-[layout-margin] > [flex],
-[layout-margin] > [flex-gt-sm],
-[layout-margin] > [flex-md],
-[layout-margin] > [flex-lt-lg] {
-  margin: 8px;
-}
-
-[layout-margin] > [flex-gt-md],
-[layout-margin] > [flex-lg] {
-  margin: 16px;
-}
-
-[layout-wrap] {
-  flex-wrap: wrap;
-}
-
-[layout-nowrap] {
-  flex-wrap: nowrap;
-}
-
-[layout-fill] {
-  margin: 0;
-  width: 100%;
-  min-height: 100%;
-  height: 100%;
-}
-
-/**
-* `hide-gt-sm show-gt-lg` should hide from 600px to 1200px
-* `show-md hide-gt-sm` should show from 0px to 960px and hide at >960px
-* `hide-gt-md show-gt-sm` should show everywhere (show overrides hide)`
-*
-*  hide means hide everywhere
-*  Sizes:
-*         $layout-breakpoint-xs:     600px !default;
-*         $layout-breakpoint-sm:     960px !default;
-*         $layout-breakpoint-md:     1280px !default;
-*         $layout-breakpoint-lg:     1920px !default;
-*/
-@media (max-width: 599px) {
-  [hide-xs]:not([show-xs]):not([show]),
-[hide]:not([show-xs]):not([show]) {
-    display: none;
-  }
-
-  [flex-order-xs="-20"] {
-    order: -20;
-  }
-
-  [flex-order-xs="-19"] {
-    order: -19;
-  }
-
-  [flex-order-xs="-18"] {
-    order: -18;
-  }
-
-  [flex-order-xs="-17"] {
-    order: -17;
-  }
-
-  [flex-order-xs="-16"] {
-    order: -16;
-  }
-
-  [flex-order-xs="-15"] {
-    order: -15;
-  }
-
-  [flex-order-xs="-14"] {
-    order: -14;
-  }
-
-  [flex-order-xs="-13"] {
-    order: -13;
-  }
-
-  [flex-order-xs="-12"] {
-    order: -12;
-  }
-
-  [flex-order-xs="-11"] {
-    order: -11;
-  }
-
-  [flex-order-xs="-10"] {
-    order: -10;
-  }
-
-  [flex-order-xs="-9"] {
-    order: -9;
-  }
-
-  [flex-order-xs="-8"] {
-    order: -8;
-  }
-
-  [flex-order-xs="-7"] {
-    order: -7;
-  }
-
-  [flex-order-xs="-6"] {
-    order: -6;
-  }
-
-  [flex-order-xs="-5"] {
-    order: -5;
-  }
-
-  [flex-order-xs="-4"] {
-    order: -4;
-  }
-
-  [flex-order-xs="-3"] {
-    order: -3;
-  }
-
-  [flex-order-xs="-2"] {
-    order: -2;
-  }
-
-  [flex-order-xs="-1"] {
-    order: -1;
-  }
-
-  [flex-order-xs="0"] {
-    order: 0;
-  }
-
-  [flex-order-xs="1"] {
-    order: 1;
-  }
-
-  [flex-order-xs="2"] {
-    order: 2;
-  }
-
-  [flex-order-xs="3"] {
-    order: 3;
-  }
-
-  [flex-order-xs="4"] {
... 213002 lines suppressed ...