You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@griffin.apache.org by gu...@apache.org on 2018/09/12 08:58:24 UTC

[35/51] [partial] incubator-griffin-site git commit: remove legacy code

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/custom.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/custom.jst b/node_modules/ajv/lib/dot/custom.jst
deleted file mode 100644
index ed5d80a..0000000
--- a/node_modules/ajv/lib/dot/custom.jst
+++ /dev/null
@@ -1,188 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-{{# def.$data }}
-
-{{
-  var $rule = this
-    , $definition = 'definition' + $lvl
-    , $rDef = $rule.definition
-    , $validate = $rDef.validate
-    , $compile
-    , $inline
-    , $macro
-    , $ruleValidate
-    , $validateCode;
-}}
-
-{{? $isData && $rDef.$data }}
-  {{
-    $validateCode = 'keywordValidate' + $lvl;
-    var $validateSchema = $rDef.validateSchema;
-  }}
-  var {{=$definition}} = RULES.custom['{{=$keyword}}'].definition;
-  var {{=$validateCode}} = {{=$definition}}.validate;
-{{??}}
-  {{
-    $ruleValidate = it.useCustomRule($rule, $schema, it.schema, it);
-    $schemaValue = 'validate.schema' + $schemaPath;
-    $validateCode = $ruleValidate.code;
-    $compile = $rDef.compile;
-    $inline = $rDef.inline;
-    $macro = $rDef.macro;
-  }}
-{{?}}
-
-{{
-  var $ruleErrs = $validateCode + '.errors'
-    , $i = 'i' + $lvl
-    , $ruleErr = 'ruleErr' + $lvl
-    , $asyncKeyword = $rDef.async;
-
-  if ($asyncKeyword && !it.async)
-    throw new Error('async keyword in sync schema');
-}}
-
-
-{{? !($inline || $macro) }}{{=$ruleErrs}} = null;{{?}}
-var {{=$errs}} = errors;
-var {{=$valid}};
-
-{{## def.callRuleValidate:
-  {{=$validateCode}}.call(
-    {{? it.opts.passContext }}this{{??}}self{{?}}
-    {{? $compile || $rDef.schema === false }}
-      , {{=$data}}
-    {{??}}
-      , {{=$schemaValue}}
-      , {{=$data}}
-      , validate.schema{{=it.schemaPath}}
-    {{?}}
-    , {{# def.dataPath }}
-    {{# def.passParentData }}
-    , rootData
-  )
-#}}
-
-{{## def.extendErrors:_inline:
-  for (var {{=$i}}={{=$errs}}; {{=$i}}<errors; {{=$i}}++) {
-    var {{=$ruleErr}} = vErrors[{{=$i}}];
-    if ({{=$ruleErr}}.dataPath === undefined)
-      {{=$ruleErr}}.dataPath = (dataPath || '') + {{= it.errorPath }};
-    {{# _inline ? 'if (\{\{=$ruleErr\}\}.schemaPath === undefined) {' : '' }}
-      {{=$ruleErr}}.schemaPath = "{{=$errSchemaPath}}";
-    {{# _inline ? '}' : '' }}
-    {{? it.opts.verbose }}
-      {{=$ruleErr}}.schema = {{=$schemaValue}};
-      {{=$ruleErr}}.data = {{=$data}};
-    {{?}}
-  }
-#}}
-
-
-{{? $validateSchema }}
-  {{=$valid}} = {{=$definition}}.validateSchema({{=$schemaValue}});
-  if ({{=$valid}}) {
-{{?}}
-
-{{? $inline }}
-  {{? $rDef.statements }}
-    {{= $ruleValidate.validate }}
-  {{??}}
-    {{=$valid}} = {{= $ruleValidate.validate }};
-  {{?}}
-{{?? $macro }}
-  {{# def.setupNextLevel }}
-  {{
-    $it.schema = $ruleValidate.validate;
-    $it.schemaPath = '';
-  }}
-  {{# def.setCompositeRule }}
-  {{ var $code = it.validate($it).replace(/validate\.schema/g, $validateCode); }}
-  {{# def.resetCompositeRule }}
-  {{= $code }}
-{{??}}
-  {{# def.beginDefOut}}
-    {{# def.callRuleValidate }}
-  {{# def.storeDefOut:def_callRuleValidate }}
-
-  {{? $rDef.errors === false }}
-    {{=$valid}} = {{? $asyncKeyword }}{{=it.yieldAwait}}{{?}}{{= def_callRuleValidate }};
-  {{??}}
-    {{? $asyncKeyword }}
-      {{ $ruleErrs = 'customErrors' + $lvl; }}
-      var {{=$ruleErrs}} = null;
-      try {
-        {{=$valid}} = {{=it.yieldAwait}}{{= def_callRuleValidate }};
-      } catch (e) {
-        {{=$valid}} = false;
-        if (e instanceof ValidationError) {{=$ruleErrs}} = e.errors;
-        else throw e;
-      }
-    {{??}}
-      {{=$ruleErrs}} = null;
-      {{=$valid}} = {{= def_callRuleValidate }};
-    {{?}}
-  {{?}}
-{{?}}
-
-{{? $rDef.modifying }}
-  {{=$data}} = {{=$parentData}}[{{=$parentDataProperty}}];
-{{?}}
-
-{{? $validateSchema }}
-  }
-{{?}}
-
-{{## def.notValidationResult:
-  {{? $rDef.valid === undefined }}
-    !{{? $macro }}{{=$nextValid}}{{??}}{{=$valid}}{{?}}
-  {{??}}
-    {{= !$rDef.valid }}
-  {{?}}
-#}}
-
-{{? $rDef.valid }}
-  {{? $breakOnError }} if (true) { {{?}}
-{{??}}
-  if ({{# def.notValidationResult }}) {
-    {{ $errorKeyword = $rule.keyword; }}
-    {{# def.beginDefOut}}
-      {{# def.error:'custom' }}
-    {{# def.storeDefOut:def_customError }}
-
-    {{? $inline }}
-      {{? $rDef.errors }}
-        {{? $rDef.errors != 'full' }}
-          {{# def.extendErrors:true }}
-        {{?}}
-      {{??}}
-        {{? $rDef.errors === false}}
-          {{= def_customError }}
-        {{??}}
-          if ({{=$errs}} == errors) {
-            {{= def_customError }}
-          } else {
-            {{# def.extendErrors:true }}
-          }
-        {{?}}
-      {{?}}
-    {{?? $macro }}
-      {{# def.extraError:'custom' }}
-    {{??}}
-      {{? $rDef.errors === false}}
-        {{= def_customError }}
-      {{??}}
-        if (Array.isArray({{=$ruleErrs}})) {
-          if (vErrors === null) vErrors = {{=$ruleErrs}};
-          else vErrors = vErrors.concat({{=$ruleErrs}});
-          errors = vErrors.length;
-          {{# def.extendErrors:false }}
-        } else {
-          {{= def_customError }}
-        }
-      {{?}}
-    {{?}}
-
-  } {{? $breakOnError }} else { {{?}}
-{{?}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/defaults.def
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/defaults.def b/node_modules/ajv/lib/dot/defaults.def
deleted file mode 100644
index 5ad8d1d..0000000
--- a/node_modules/ajv/lib/dot/defaults.def
+++ /dev/null
@@ -1,32 +0,0 @@
-{{## def.assignDefault:
-  if ({{=$passData}} === undefined)
-    {{=$passData}} = {{? it.opts.useDefaults == 'shared' }}
-                       {{= it.useDefault($sch.default) }}
-                     {{??}}
-                       {{= JSON.stringify($sch.default) }}
-                     {{?}};
-#}}
-
-
-{{## def.defaultProperties:
-  {{
-    var $schema = it.schema.properties
-      , $schemaKeys = Object.keys($schema); }}
-  {{~ $schemaKeys:$propertyKey }}
-    {{ var $sch = $schema[$propertyKey]; }}
-    {{? $sch.default !== undefined }}
-      {{ var $passData = $data + it.util.getProperty($propertyKey); }}
-      {{# def.assignDefault }}
-    {{?}}
-  {{~}}
-#}}
-
-
-{{## def.defaultItems:
-  {{~ it.schema.items:$sch:$i }}
-    {{? $sch.default !== undefined }}
-      {{ var $passData = $data + '[' + $i + ']'; }}
-      {{# def.assignDefault }}
-    {{?}}
-  {{~}}
-#}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/definitions.def
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/definitions.def b/node_modules/ajv/lib/dot/definitions.def
deleted file mode 100644
index a442346..0000000
--- a/node_modules/ajv/lib/dot/definitions.def
+++ /dev/null
@@ -1,182 +0,0 @@
-{{## def.setupKeyword:
-  {{
-    var $lvl = it.level;
-    var $dataLvl = it.dataLevel;
-    var $schema = it.schema[$keyword];
-    var $schemaPath = it.schemaPath + it.util.getProperty($keyword);
-    var $errSchemaPath = it.errSchemaPath + '/' + $keyword;
-    var $breakOnError = !it.opts.allErrors;
-    var $errorKeyword;
-
-    var $data = 'data' + ($dataLvl || '');
-    var $valid = 'valid' + $lvl;
-    var $errs = 'errs__' + $lvl;
-  }}
-#}}
-
-
-{{## def.setCompositeRule:
-  {{
-    var $wasComposite = it.compositeRule;
-    it.compositeRule = $it.compositeRule = true;
-  }}
-#}}
-
-
-{{## def.resetCompositeRule:
-  {{ it.compositeRule = $it.compositeRule = $wasComposite; }}
-#}}
-
-
-{{## def.setupNextLevel:
-  {{
-    var $it = it.util.copy(it);
-    var $closingBraces = '';
-    $it.level++;
-    var $nextValid = 'valid' + $it.level;
-  }}
-#}}
-
-
-{{## def.ifValid:
-  {{? $breakOnError }}
-    if ({{=$valid}}) {
-    {{ $closingBraces += '}'; }}
-  {{?}}
-#}}
-
-
-{{## def.ifResultValid:
-  {{? $breakOnError }}
-    if ({{=$nextValid}}) {
-    {{ $closingBraces += '}'; }}
-  {{?}}
-#}}
-
-
-{{## def.elseIfValid:
-  {{? $breakOnError }}
-    {{ $closingBraces += '}'; }}
-    else {
-  {{?}}
-#}}
-
-
-{{## def.nonEmptySchema:_schema:
-  it.util.schemaHasRules(_schema, it.RULES.all)
-#}}
-
-
-{{## def.strLength:
-  {{? it.opts.unicode === false }}
-    {{=$data}}.length
-  {{??}}
-    ucs2length({{=$data}})
-  {{?}}
-#}}
-
-
-{{## def.willOptimize:
-  it.util.varOccurences($code, $nextData) < 2
-#}}
-
-
-{{## def.generateSubschemaCode:
-  {{
-    var $code = it.validate($it);
-    $it.baseId = $currentBaseId;
-  }}
-#}}
-
-
-{{## def.insertSubschemaCode:
-  {{= it.validate($it) }}
-  {{ $it.baseId = $currentBaseId; }}
-#}}
-
-
-{{## def._optimizeValidate:
-  it.util.varReplace($code, $nextData, $passData)
-#}}
-
-
-{{## def.optimizeValidate:
-  {{? {{# def.willOptimize}} }}
-    {{= {{# def._optimizeValidate }} }}
-  {{??}}
-    var {{=$nextData}} = {{=$passData}};
-    {{= $code }}
-  {{?}}
-#}}
-
-
-{{## def.cleanUp: {{ out = it.util.cleanUpCode(out); }} #}}
-
-
-{{## def.cleanUpVarErrors: {{ out = it.util.cleanUpVarErrors(out, $async); }} #}}
-
-
-{{## def.$data:
-  {{
-    var $isData = it.opts.v5 && $schema && $schema.$data
-      , $schemaValue;
-  }}
-  {{? $isData }}
-    var schema{{=$lvl}} = {{= it.util.getData($schema.$data, $dataLvl, it.dataPathArr) }};
-    {{ $schemaValue = 'schema' + $lvl; }}
-  {{??}}
-    {{ $schemaValue = $schema; }}
-  {{?}}
-#}}
-
-
-{{## def.$dataNotType:_type:
-  {{?$isData}} ({{=$schemaValue}} !== undefined && typeof {{=$schemaValue}} != _type) || {{?}}
-#}}
-
-
-{{## def.check$dataIsArray:
-  if (schema{{=$lvl}} === undefined) {{=$valid}} = true;
-  else if (!Array.isArray(schema{{=$lvl}})) {{=$valid}} = false;
-  else {
-#}}
-
-
-{{## def.beginDefOut:
-  {{
-    var $$outStack = $$outStack || [];
-    $$outStack.push(out);
-    out = '';
-  }}
-#}}
-
-
-{{## def.storeDefOut:_variable:
-  {{
-    var _variable = out;
-    out = $$outStack.pop();
-  }}
-#}}
-
-
-{{## def.dataPath:(dataPath || ''){{? it.errorPath != '""'}} + {{= it.errorPath }}{{?}}#}}
-
-{{## def.setParentData:
-  {{
-    var $parentData = $dataLvl ? 'data' + (($dataLvl-1)||'') : 'parentData'
-      , $parentDataProperty = $dataLvl ? it.dataPathArr[$dataLvl] : 'parentDataProperty';
-  }}
-#}}
-
-{{## def.passParentData:
-  {{# def.setParentData }}
-  , {{= $parentData }}
-  , {{= $parentDataProperty }}
-#}}
-
-
-{{## def.checkOwnProperty:
-  {{? $ownProperties }}
-    if (!Object.prototype.hasOwnProperty.call({{=$data}}, {{=$key}})) continue;
-  {{?}}
-#}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/dependencies.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/dependencies.jst b/node_modules/ajv/lib/dot/dependencies.jst
deleted file mode 100644
index 1198a45..0000000
--- a/node_modules/ajv/lib/dot/dependencies.jst
+++ /dev/null
@@ -1,69 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.missing }}
-{{# def.setupKeyword }}
-{{# def.setupNextLevel }}
-
-
-{{
-  var $schemaDeps = {}
-    , $propertyDeps = {};
-
-  for ($property in $schema) {
-    var $sch = $schema[$property];
-    var $deps = Array.isArray($sch) ? $propertyDeps : $schemaDeps;
-    $deps[$property] = $sch;
-  }
-}}
-
-var {{=$errs}} = errors;
-
-{{ var $currentErrorPath = it.errorPath; }}
-
-var missing{{=$lvl}};
-{{ for (var $property in $propertyDeps) { }}
-  {{ $deps = $propertyDeps[$property]; }}
-  if ({{=$data}}{{= it.util.getProperty($property) }} !== undefined
-    {{? $breakOnError }}
-        && ({{# def.checkMissingProperty:$deps }})) {
-        {{# def.errorMissingProperty:'dependencies' }}
-    {{??}}
-      ) {
-        {{~ $deps:$reqProperty }}
-          {{# def.allErrorsMissingProperty:'dependencies' }}
-        {{~}}
-    {{?}}
-  } {{# def.elseIfValid }}
-{{ } }}
-
-{{
-  it.errorPath = $currentErrorPath;
-  var $currentBaseId = $it.baseId;
-}}
-
-
-{{ for (var $property in $schemaDeps) { }}
-  {{ var $sch = $schemaDeps[$property]; }}
-  {{? {{# def.nonEmptySchema:$sch }} }}
-    {{=$nextValid}} = true;
-
-    if ({{=$data}}{{= it.util.getProperty($property) }} !== undefined) {
-      {{ 
-        $it.schema = $sch;
-        $it.schemaPath = $schemaPath + it.util.getProperty($property);
-        $it.errSchemaPath = $errSchemaPath + '/' + it.util.escapeFragment($property);
-      }}
-
-      {{# def.insertSubschemaCode }}
-    }
-
-    {{# def.ifResultValid }}
-  {{?}}
-{{ } }}
-
-{{? $breakOnError }} 
-  {{= $closingBraces }}
-  if ({{=$errs}} == errors) {
-{{?}}
-
-{{# def.cleanUp }}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/enum.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/enum.jst b/node_modules/ajv/lib/dot/enum.jst
deleted file mode 100644
index 357c2e8..0000000
--- a/node_modules/ajv/lib/dot/enum.jst
+++ /dev/null
@@ -1,30 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-{{# def.$data }}
-
-{{
-  var $i = 'i' + $lvl
-    , $vSchema = 'schema' + $lvl;
-}}
-
-{{? !$isData }}
-  var {{=$vSchema}} = validate.schema{{=$schemaPath}};
-{{?}}
-var {{=$valid}};
-
-{{?$isData}}{{# def.check$dataIsArray }}{{?}}
-
-{{=$valid}} = false;
-
-for (var {{=$i}}=0; {{=$i}}<{{=$vSchema}}.length; {{=$i}}++)
-  if (equal({{=$data}}, {{=$vSchema}}[{{=$i}}])) {
-    {{=$valid}} = true;
-    break;
-  }
-
-{{? $isData }}  }  {{?}}
-
-{{# def.checkError:'enum' }}
-
-{{? $breakOnError }} else { {{?}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/errors.def
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/errors.def b/node_modules/ajv/lib/dot/errors.def
deleted file mode 100644
index 3e04721..0000000
--- a/node_modules/ajv/lib/dot/errors.def
+++ /dev/null
@@ -1,185 +0,0 @@
-{{# def.definitions }}
-
-{{## def._error:_rule:
-  {{ 'istanbul ignore else'; }}
-  {{? it.createErrors !== false }}
-    {
-      keyword: '{{= $errorKeyword || _rule }}'
-      , dataPath: (dataPath || '') + {{= it.errorPath }}
-      , schemaPath: {{=it.util.toQuotedString($errSchemaPath)}}
-      , params: {{# def._errorParams[_rule] }}
-      {{? it.opts.messages !== false }}
-        , message: {{# def._errorMessages[_rule] }}
-      {{?}}
-      {{? it.opts.verbose }}
-        , schema: {{# def._errorSchemas[_rule] }}
-        , parentSchema: validate.schema{{=it.schemaPath}}
-        , data: {{=$data}}
-      {{?}}
-    }
-  {{??}}
-    {}
-  {{?}}
-#}}
-
-
-{{## def._addError:_rule:
-  if (vErrors === null) vErrors = [err];
-  else vErrors.push(err);
-  errors++;
-#}}
-
-
-{{## def.addError:_rule:
-  var err = {{# def._error:_rule }};
-  {{# def._addError:_rule }}
-#}}
-
-
-{{## def.error:_rule:
-  {{# def.beginDefOut}}
-    {{# def._error:_rule }}
-  {{# def.storeDefOut:__err }}
-
-  {{? !it.compositeRule && $breakOnError }}
-    {{ 'istanbul ignore if'; }}
-    {{? it.async }}
-      throw new ValidationError([{{=__err}}]);
-    {{??}}
-      validate.errors = [{{=__err}}];
-      return false;
-    {{?}}
-  {{??}}
-    var err = {{=__err}};
-    {{# def._addError:_rule }}
-  {{?}}
-#}}
-
-
-{{## def.extraError:_rule:
-  {{# def.addError:_rule}}
-  {{? !it.compositeRule && $breakOnError }}
-    {{ 'istanbul ignore if'; }}
-    {{? it.async }}
-      throw new ValidationError(vErrors);
-    {{??}}
-      validate.errors = vErrors;
-      return false;
-    {{?}}
-  {{?}}
-#}}
-
-
-{{## def.checkError:_rule:
-  if (!{{=$valid}}) {
-    {{# def.error:_rule }}
-  }
-#}}
-
-
-{{## def.resetErrors:
-  errors = {{=$errs}};
-  if (vErrors !== null) {
-    if ({{=$errs}}) vErrors.length = {{=$errs}};
-    else vErrors = null;
-  }
-#}}
-
-
-{{## def.concatSchema:{{?$isData}}' + {{=$schemaValue}} + '{{??}}{{=$schema}}{{?}}#}}
-{{## def.appendSchema:{{?$isData}}' + {{=$schemaValue}}{{??}}{{=$schema}}'{{?}}#}}
-{{## def.concatSchemaEQ:{{?$isData}}' + {{=$schemaValue}} + '{{??}}{{=it.util.escapeQuotes($schema)}}{{?}}#}}
-
-{{## def._errorMessages = {
-  $ref:            "'can\\\'t resolve reference {{=it.util.escapeQuotes($schema)}}'",
-  additionalItems: "'should NOT have more than {{=$schema.length}} items'",
-  additionalProperties: "'should NOT have additional properties'",
-  anyOf:           "'should match some schema in anyOf'",
-  dependencies:    "'should have {{? $deps.length == 1 }}property {{= it.util.escapeQuotes($deps[0]) }}{{??}}properties {{= it.util.escapeQuotes($deps.join(\", \")) }}{{?}} when property {{= it.util.escapeQuotes($property) }} is present'",
-  'enum':          "'should be equal to one of the allowed values'",
-  format:          "'should match format \"{{#def.concatSchemaEQ}}\"'",
-  _limit:          "'should be {{=$opStr}} {{#def.appendSchema}}",
-  _exclusiveLimit: "'{{=$exclusiveKeyword}} should be boolean'",
-  _limitItems:     "'should NOT have {{?$keyword=='maxItems'}}more{{??}}less{{?}} than {{#def.concatSchema}} items'",
-  _limitLength:    "'should NOT be {{?$keyword=='maxLength'}}longer{{??}}shorter{{?}} than {{#def.concatSchema}} characters'",
-  _limitProperties:"'should NOT have {{?$keyword=='maxProperties'}}more{{??}}less{{?}} than {{#def.concatSchema}} properties'",
-  multipleOf:      "'should be multiple of {{#def.appendSchema}}",
-  not:             "'should NOT be valid'",
-  oneOf:           "'should match exactly one schema in oneOf'",
-  pattern:         "'should match pattern \"{{#def.concatSchemaEQ}}\"'",
-  required:        "'{{? it.opts._errorDataPathProperty }}is a required property{{??}}should have required property \\'{{=$missingProperty}}\\'{{?}}'",
-  type:            "'should be {{? $typeIsArray }}{{= $typeSchema.join(\",\") }}{{??}}{{=$typeSchema}}{{?}}'",
-  uniqueItems:     "'should NOT have duplicate items (items ## ' + j + ' and ' + i + ' are identical)'",
-  custom:          "'should pass \"{{=$rule.keyword}}\" keyword validation'",
-  patternGroups:   "'should NOT have {{=$moreOrLess}} than {{=$limit}} properties matching pattern \"{{=it.util.escapeQuotes($pgProperty)}}\"'",
-  patternRequired: "'should have property matching pattern \\'{{=$missingPattern}}\\''",
-  switch:          "'should pass \"switch\" keyword validation'",
-  constant:        "'should be equal to constant'",
-  _formatLimit:    "'should be {{=$opStr}} \"{{#def.concatSchemaEQ}}\"'",
-  _formatExclusiveLimit: "'{{=$exclusiveKeyword}} should be boolean'"
-} #}}
-
-
-{{## def.schemaRefOrVal: {{?$isData}}validate.schema{{=$schemaPath}}{{??}}{{=$schema}}{{?}} #}}
-{{## def.schemaRefOrQS: {{?$isData}}validate.schema{{=$schemaPath}}{{??}}{{=it.util.toQuotedString($schema)}}{{?}} #}}
-
-{{## def._errorSchemas = {
-  $ref:            "{{=it.util.toQuotedString($schema)}}",
-  additionalItems: "false",
-  additionalProperties: "false",
-  anyOf:           "validate.schema{{=$schemaPath}}",
-  dependencies:    "validate.schema{{=$schemaPath}}",
-  'enum':          "validate.schema{{=$schemaPath}}",
-  format:          "{{#def.schemaRefOrQS}}",
-  _limit:          "{{#def.schemaRefOrVal}}",
-  _exclusiveLimit: "validate.schema{{=$schemaPath}}",
-  _limitItems:     "{{#def.schemaRefOrVal}}",
-  _limitLength:    "{{#def.schemaRefOrVal}}",
-  _limitProperties:"{{#def.schemaRefOrVal}}",
-  multipleOf:      "{{#def.schemaRefOrVal}}",
-  not:             "validate.schema{{=$schemaPath}}",
-  oneOf:           "validate.schema{{=$schemaPath}}",
-  pattern:         "{{#def.schemaRefOrQS}}",
-  required:        "validate.schema{{=$schemaPath}}",
-  type:            "validate.schema{{=$schemaPath}}",
-  uniqueItems:     "{{#def.schemaRefOrVal}}",
-  custom:          "validate.schema{{=$schemaPath}}",
-  patternGroups:   "validate.schema{{=$schemaPath}}",
-  patternRequired: "validate.schema{{=$schemaPath}}",
-  switch:          "validate.schema{{=$schemaPath}}",
-  constant:        "validate.schema{{=$schemaPath}}",
-  _formatLimit:    "{{#def.schemaRefOrQS}}",
-  _formatExclusiveLimit: "validate.schema{{=$schemaPath}}"
-} #}}
-
-
-{{## def.schemaValueQS: {{?$isData}}{{=$schemaValue}}{{??}}{{=it.util.toQuotedString($schema)}}{{?}} #}}
-
-{{## def._errorParams = {
-  $ref:            "{ ref: '{{=it.util.escapeQuotes($schema)}}' }",
-  additionalItems: "{ limit: {{=$schema.length}} }",
-  additionalProperties: "{ additionalProperty: '{{=$additionalProperty}}' }",
-  anyOf:           "{}",
-  dependencies:    "{ property: '{{= it.util.escapeQuotes($property) }}', missingProperty: '{{=$missingProperty}}', depsCount: {{=$deps.length}}, deps: '{{= it.util.escapeQuotes($deps.length==1 ? $deps[0] : $deps.join(\", \")) }}' }",
-  'enum':          "{ allowedValues: schema{{=$lvl}} }",
-  format:          "{ format: {{#def.schemaValueQS}} }",
-  _limit:          "{ comparison: {{=$opExpr}}, limit: {{=$schemaValue}}, exclusive: {{=$exclusive}} }",
-  _exclusiveLimit: "{}",
-  _limitItems:     "{ limit: {{=$schemaValue}} }",
-  _limitLength:    "{ limit: {{=$schemaValue}} }",
-  _limitProperties:"{ limit: {{=$schemaValue}} }",
-  multipleOf:      "{ multipleOf: {{=$schemaValue}} }",
-  not:             "{}",
-  oneOf:           "{}",
-  pattern:         "{ pattern: {{#def.schemaValueQS}} }",
-  required:        "{ missingProperty: '{{=$missingProperty}}' }",
-  type:            "{ type: '{{? $typeIsArray }}{{= $typeSchema.join(\",\") }}{{??}}{{=$typeSchema}}{{?}}' }",
-  uniqueItems:     "{ i: i, j: j }",
-  custom:          "{ keyword: '{{=$rule.keyword}}' }",
-  patternGroups:   "{ reason: '{{=$reason}}', limit: {{=$limit}}, pattern: '{{=it.util.escapeQuotes($pgProperty)}}' }",
-  patternRequired: "{ missingPattern: '{{=$missingPattern}}' }",
-  switch:          "{ caseIndex: {{=$caseIndex}} }",
-  constant:        "{}",
-  _formatLimit:    "{ comparison: {{=$opExpr}}, limit: {{#def.schemaValueQS}}, exclusive: {{=$exclusive}} }",
-  _formatExclusiveLimit: "{}"
-} #}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/format.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/format.jst b/node_modules/ajv/lib/dot/format.jst
deleted file mode 100644
index 961fe4f..0000000
--- a/node_modules/ajv/lib/dot/format.jst
+++ /dev/null
@@ -1,100 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-
-{{## def.skipFormat:
-  {{? $breakOnError }} if (true) { {{?}}
-  {{ return out; }}
-#}}
-
-{{? it.opts.format === false }}{{# def.skipFormat }}{{?}}
-
-
-{{# def.$data }}
-
-
-{{## def.$dataCheckFormat:
-  {{# def.$dataNotType:'string' }}
-  ({{? $unknownFormats === true || $allowUnknown }}
-     ({{=$schemaValue}} && !{{=$format}}
-      {{? $allowUnknown }}
-        && self._opts.unknownFormats.indexOf({{=$schemaValue}}) == -1
-      {{?}}) ||
-   {{?}}
-   ({{=$format}} && !(typeof {{=$format}} == 'function'
-                     ? {{? it.async}}
-                        (async{{=$lvl}} ? {{=it.yieldAwait}} {{=$format}}({{=$data}}) : {{=$format}}({{=$data}}))
-                       {{??}}
-                        {{=$format}}({{=$data}})
-                       {{?}}
-                     : {{=$format}}.test({{=$data}}))))
-#}}
-
-{{## def.checkFormat:
-  {{
-    var $formatRef = 'formats' + it.util.getProperty($schema);
-    if ($isObject) $formatRef += '.validate';
-  }}
-  {{? typeof $format == 'function' }}
-    {{=$formatRef}}({{=$data}})
-  {{??}}
-    {{=$formatRef}}.test({{=$data}})
-  {{?}}
-#}}
-
-
-{{
-  var $unknownFormats = it.opts.unknownFormats
-    , $allowUnknown = Array.isArray($unknownFormats);
-}}
-
-{{? $isData }}
-  {{ var $format = 'format' + $lvl; }}
-  var {{=$format}} = formats[{{=$schemaValue}}];
-  var isObject{{=$lvl}} = typeof {{=$format}} == 'object'
-                          && !({{=$format}} instanceof RegExp)
-                          && {{=$format}}.validate;
-  if (isObject{{=$lvl}}) {
-    {{? it.async}}
-      var async{{=$lvl}} = {{=$format}}.async;
-    {{?}}
-    {{=$format}} = {{=$format}}.validate;
-  }
-  if ({{# def.$dataCheckFormat }}) {
-{{??}}
-  {{ var $format = it.formats[$schema]; }}
-  {{? !$format }}
-    {{? $unknownFormats === true || ($allowUnknown && $unknownFormats.indexOf($schema) == -1) }}
-      {{ throw new Error('unknown format "' + $schema + '" is used in schema at path "' + it.errSchemaPath + '"'); }}
-    {{??}}
-      {{
-        if (!$allowUnknown) {
-          console.warn('unknown format "' + $schema + '" ignored in schema at path "' + it.errSchemaPath + '"');
-          if ($unknownFormats !== 'ignore')
-            console.warn('In the next major version it will throw exception. See option unknownFormats for more information');
-        }
-      }}
-      {{# def.skipFormat }}
-    {{?}}
-  {{?}}
-  {{
-    var $isObject = typeof $format == 'object'
-                    && !($format instanceof RegExp)
-                    && $format.validate;
-    if ($isObject) {
-      var $async = $format.async === true;
-      $format = $format.validate;
-    }
-  }}
-  {{? $async }}
-    {{
-      if (!it.async) throw new Error('async format in sync schema');
-      var $formatRef = 'formats' + it.util.getProperty($schema) + '.validate';
-    }}
-    if (!({{=it.yieldAwait}} {{=$formatRef}}({{=$data}}))) {
-  {{??}}
-    if (!{{# def.checkFormat }}) {
-  {{?}}
-{{?}}
-    {{# def.error:'format' }}
-  } {{? $breakOnError }} else { {{?}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/items.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/items.jst b/node_modules/ajv/lib/dot/items.jst
deleted file mode 100644
index a8b8aa7..0000000
--- a/node_modules/ajv/lib/dot/items.jst
+++ /dev/null
@@ -1,101 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-{{# def.setupNextLevel }}
-
-
-{{## def.validateItems:startFrom:
-  for (var {{=$idx}} = {{=startFrom}}; {{=$idx}} < {{=$data}}.length; {{=$idx}}++) {
-    {{
-      $it.errorPath = it.util.getPathExpr(it.errorPath, $idx, it.opts.jsonPointers, true);
-      var $passData = $data + '[' + $idx + ']';
-      $it.dataPathArr[$dataNxt] = $idx;
-    }}
-
-    {{# def.generateSubschemaCode }}
-    {{# def.optimizeValidate }}
-
-    {{? $breakOnError }}
-      if (!{{=$nextValid}}) break;
-    {{?}}
-  }
-#}}
-
-{{
-  var $idx = 'i' + $lvl
-    , $dataNxt = $it.dataLevel = it.dataLevel + 1
-    , $nextData = 'data' + $dataNxt
-    , $currentBaseId = it.baseId;
-}}
-
-var {{=$errs}} = errors;
-var {{=$valid}};
-
-{{? Array.isArray($schema) }}
-  {{ /* 'items' is an array of schemas */}}
-  {{ var $additionalItems = it.schema.additionalItems; }}
-  {{? $additionalItems === false }}
-    {{=$valid}} = {{=$data}}.length <= {{= $schema.length }};
-    {{
-      var $currErrSchemaPath = $errSchemaPath;
-      $errSchemaPath = it.errSchemaPath + '/additionalItems';      
-    }}
-    {{# def.checkError:'additionalItems' }}
-    {{ $errSchemaPath = $currErrSchemaPath; }}
-    {{# def.elseIfValid}}
-  {{?}}
-
-  {{~ $schema:$sch:$i }}
-    {{? {{# def.nonEmptySchema:$sch }} }}
-      {{=$nextValid}} = true;
-
-      if ({{=$data}}.length > {{=$i}}) {
-        {{
-          var $passData = $data + '[' + $i + ']';
-          $it.schema = $sch;
-          $it.schemaPath = $schemaPath + '[' + $i + ']';
-          $it.errSchemaPath = $errSchemaPath + '/' + $i;
-          $it.errorPath = it.util.getPathExpr(it.errorPath, $i, it.opts.jsonPointers, true);
-          $it.dataPathArr[$dataNxt] = $i;
-        }}
-
-        {{# def.generateSubschemaCode }}
-        {{# def.optimizeValidate }}
-      }
-
-      {{# def.ifResultValid }}
-    {{?}}
-  {{~}}
-
-  {{? typeof $additionalItems == 'object' && {{# def.nonEmptySchema:$additionalItems }} }}
-    {{
-      $it.schema = $additionalItems;
-      $it.schemaPath = it.schemaPath + '.additionalItems';
-      $it.errSchemaPath = it.errSchemaPath + '/additionalItems';
-    }}
-    {{=$nextValid}} = true;
-
-    if ({{=$data}}.length > {{= $schema.length }}) {
-      {{# def.validateItems: $schema.length }}
-    }
-
-    {{# def.ifResultValid }}
-  {{?}}
-
-{{?? {{# def.nonEmptySchema:$schema }} }}
-  {{ /* 'items' is a single schema */}}
-  {{
-    $it.schema = $schema;
-    $it.schemaPath = $schemaPath;
-    $it.errSchemaPath = $errSchemaPath;
-  }}
-  {{# def.validateItems: 0 }}
-  {{# def.ifResultValid }}
-{{?}}
-
-{{? $breakOnError }}
-  {{= $closingBraces }}
-  if ({{=$errs}} == errors) {
-{{?}}
-
-{{# def.cleanUp }}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/missing.def
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/missing.def b/node_modules/ajv/lib/dot/missing.def
deleted file mode 100644
index 23ad04c..0000000
--- a/node_modules/ajv/lib/dot/missing.def
+++ /dev/null
@@ -1,34 +0,0 @@
-{{## def.checkMissingProperty:_properties:
-  {{~ _properties:_$property:$i }}
-    {{?$i}} || {{?}}
-    {{ var $prop = it.util.getProperty(_$property); }}
-    ( {{=$data}}{{=$prop}} === undefined && (missing{{=$lvl}} = {{= it.util.toQuotedString(it.opts.jsonPointers ? _$property : $prop) }}) )
-  {{~}}
-#}}
-
-
-{{## def.errorMissingProperty:_error:
-  {{
-    var $propertyPath = 'missing' + $lvl
-      , $missingProperty = '\' + ' + $propertyPath + ' + \'';
-    if (it.opts._errorDataPathProperty) {
-      it.errorPath = it.opts.jsonPointers
-                      ? it.util.getPathExpr($currentErrorPath,  $propertyPath, true)
-                      : $currentErrorPath + ' + ' + $propertyPath;
-    }
-  }}
-  {{# def.error:_error }}
-#}}
-
-{{## def.allErrorsMissingProperty:_error:
-  {{
-    var $prop = it.util.getProperty($reqProperty)
-      , $missingProperty = it.util.escapeQuotes($reqProperty);
-    if (it.opts._errorDataPathProperty) {
-      it.errorPath = it.util.getPath($currentErrorPath, $reqProperty, it.opts.jsonPointers);
-    }
-  }}
-  if ({{=$data}}{{=$prop}} === undefined) {
-    {{# def.addError:_error }}
-  }
-#}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/multipleOf.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/multipleOf.jst b/node_modules/ajv/lib/dot/multipleOf.jst
deleted file mode 100644
index 5f8dd33..0000000
--- a/node_modules/ajv/lib/dot/multipleOf.jst
+++ /dev/null
@@ -1,20 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-{{# def.$data }}
-
-var division{{=$lvl}};
-if ({{?$isData}}
-      {{=$schemaValue}} !== undefined && (
-      typeof {{=$schemaValue}} != 'number' ||
-    {{?}}
-      (division{{=$lvl}} = {{=$data}} / {{=$schemaValue}},
-      {{? it.opts.multipleOfPrecision }}
-        Math.abs(Math.round(division{{=$lvl}}) - division{{=$lvl}}) > 1e-{{=it.opts.multipleOfPrecision}}
-      {{??}}
-        division{{=$lvl}} !== parseInt(division{{=$lvl}})
-      {{?}}
-      )
-    {{?$isData}}  )  {{?}} ) {
-  {{# def.error:'multipleOf' }}
-} {{? $breakOnError }} else { {{?}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/not.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/not.jst b/node_modules/ajv/lib/dot/not.jst
deleted file mode 100644
index e03185a..0000000
--- a/node_modules/ajv/lib/dot/not.jst
+++ /dev/null
@@ -1,43 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-{{# def.setupNextLevel }}
-
-{{? {{# def.nonEmptySchema:$schema }} }}
-  {{
-    $it.schema = $schema;
-    $it.schemaPath = $schemaPath;
-    $it.errSchemaPath = $errSchemaPath;
-  }}
-
-  var {{=$errs}} = errors;
-
-  {{# def.setCompositeRule }}
-
-  {{
-    $it.createErrors = false;
-    var $allErrorsOption;
-    if ($it.opts.allErrors) {
-      $allErrorsOption = $it.opts.allErrors;
-      $it.opts.allErrors = false;
-    }
-  }}
-  {{= it.validate($it) }}
-  {{
-    $it.createErrors = true;
-    if ($allErrorsOption) $it.opts.allErrors = $allErrorsOption;
-  }}
-
-  {{# def.resetCompositeRule }}
-
-  if ({{=$nextValid}}) {
-    {{# def.error:'not' }}
-  } else {
-    {{# def.resetErrors }}
-  {{? it.opts.allErrors }} } {{?}}
-{{??}}
-  {{# def.addError:'not' }}
-  {{? $breakOnError}}
-    if (false) {
-  {{?}}
-{{?}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/oneOf.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/oneOf.jst b/node_modules/ajv/lib/dot/oneOf.jst
deleted file mode 100644
index b7f7bff..0000000
--- a/node_modules/ajv/lib/dot/oneOf.jst
+++ /dev/null
@@ -1,44 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-{{# def.setupNextLevel }}
-
-var {{=$errs}} = errors;
-var prevValid{{=$lvl}} = false;
-var {{=$valid}} = false;
-
-{{ var $currentBaseId = $it.baseId; }}
-{{# def.setCompositeRule }}
-
-{{~ $schema:$sch:$i }}
-  {{? {{# def.nonEmptySchema:$sch }} }}
-    {{
-      $it.schema = $sch;
-      $it.schemaPath = $schemaPath + '[' + $i + ']';
-      $it.errSchemaPath = $errSchemaPath + '/' + $i;
-    }}
-
-    {{# def.insertSubschemaCode }}
-  {{??}}
-    var {{=$nextValid}} = true;
-  {{?}}
-
-  {{? $i }}
-    if ({{=$nextValid}} && prevValid{{=$lvl}})
-      {{=$valid}} = false;
-    else {
-    {{ $closingBraces += '}'; }}
-  {{?}}
-
-    if ({{=$nextValid}}) {{=$valid}} = prevValid{{=$lvl}} = true;
-{{~}}
-
-{{# def.resetCompositeRule }}
-
-{{= $closingBraces }}
-
-if (!{{=$valid}}) {
-  {{# def.error:'oneOf' }}
-} else {
-  {{# def.resetErrors }}
-{{? it.opts.allErrors }} } {{?}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/pattern.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/pattern.jst b/node_modules/ajv/lib/dot/pattern.jst
deleted file mode 100644
index 3a37ef6..0000000
--- a/node_modules/ajv/lib/dot/pattern.jst
+++ /dev/null
@@ -1,14 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-{{# def.$data }}
-
-{{
-  var $regexp = $isData
-                ? '(new RegExp(' + $schemaValue + '))'
-                : it.usePattern($schema);
-}}
-
-if ({{# def.$dataNotType:'string' }} !{{=$regexp}}.test({{=$data}}) ) {
-  {{# def.error:'pattern' }}
-} {{? $breakOnError }} else { {{?}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/properties.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/properties.jst b/node_modules/ajv/lib/dot/properties.jst
deleted file mode 100644
index 3a4b966..0000000
--- a/node_modules/ajv/lib/dot/properties.jst
+++ /dev/null
@@ -1,319 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-{{# def.setupNextLevel }}
-
-
-{{## def.validateAdditional:
-  {{ /* additionalProperties is schema */
-    $it.schema = $aProperties;
-    $it.schemaPath = it.schemaPath + '.additionalProperties';
-    $it.errSchemaPath = it.errSchemaPath + '/additionalProperties';
-    $it.errorPath = it.opts._errorDataPathProperty
-                    ? it.errorPath
-                    : it.util.getPathExpr(it.errorPath, $key, it.opts.jsonPointers);
-    var $passData = $data + '[' + $key + ']';
-    $it.dataPathArr[$dataNxt] = $key;
-  }}
-
-  {{# def.generateSubschemaCode }}
-  {{# def.optimizeValidate }}
-#}}
-
-
-{{
-  var $key = 'key' + $lvl
-    , $dataNxt = $it.dataLevel = it.dataLevel + 1
-    , $nextData = 'data' + $dataNxt;
-
-  var $schemaKeys = Object.keys($schema || {})
-    , $pProperties = it.schema.patternProperties || {}
-    , $pPropertyKeys = Object.keys($pProperties)
-    , $aProperties = it.schema.additionalProperties
-    , $someProperties = $schemaKeys.length || $pPropertyKeys.length
-    , $noAdditional = $aProperties === false
-    , $additionalIsSchema = typeof $aProperties == 'object'
-                              && Object.keys($aProperties).length
-    , $removeAdditional = it.opts.removeAdditional
-    , $checkAdditional = $noAdditional || $additionalIsSchema || $removeAdditional
-    , $ownProperties = it.opts.ownProperties
-    , $currentBaseId = it.baseId;
-
-  var $required = it.schema.required;
-  if ($required && !(it.opts.v5 && $required.$data) && $required.length < it.opts.loopRequired)
-    var $requiredHash = it.util.toHash($required);
-
-  if (it.opts.v5) {
-    var $pgProperties = it.schema.patternGroups || {}
-      , $pgPropertyKeys = Object.keys($pgProperties);
-  }
-}}
-
-
-var {{=$errs}} = errors;
-var {{=$nextValid}} = true;
-
-{{? $checkAdditional }}
-  for (var {{=$key}} in {{=$data}}) {
-    {{# def.checkOwnProperty }}
-    {{? $someProperties }}
-      var isAdditional{{=$lvl}} = !(false
-        {{? $schemaKeys.length }}
-          {{? $schemaKeys.length > 5 }}
-            || validate.schema{{=$schemaPath}}[{{=$key}}]
-          {{??}}
-            {{~ $schemaKeys:$propertyKey }}
-              || {{=$key}} == {{= it.util.toQuotedString($propertyKey) }}
-            {{~}}
-          {{?}}
-        {{?}}
-        {{? $pPropertyKeys.length }}
-          {{~ $pPropertyKeys:$pProperty:$i }}
-            || {{= it.usePattern($pProperty) }}.test({{=$key}})
-          {{~}}
-        {{?}}
-        {{? it.opts.v5 && $pgPropertyKeys && $pgPropertyKeys.length }}
-          {{~ $pgPropertyKeys:$pgProperty:$i }}
-            || {{= it.usePattern($pgProperty) }}.test({{=$key}})
-          {{~}}
-        {{?}}
-      );
-
-      if (isAdditional{{=$lvl}}) {
-    {{?}}
-    {{? $removeAdditional == 'all' }}
-      delete {{=$data}}[{{=$key}}];
-    {{??}}
-      {{
-        var $currentErrorPath = it.errorPath;
-        var $additionalProperty = '\' + ' + $key + ' + \'';
-        if (it.opts._errorDataPathProperty) {
-          it.errorPath = it.util.getPathExpr(it.errorPath, $key, it.opts.jsonPointers);
-        }
-      }}
-      {{? $noAdditional }}
-        {{? $removeAdditional }}
-          delete {{=$data}}[{{=$key}}];
-        {{??}}
-          {{=$nextValid}} = false;
-          {{
-            var $currErrSchemaPath = $errSchemaPath;
-            $errSchemaPath = it.errSchemaPath + '/additionalProperties';
-          }}
-          {{# def.error:'additionalProperties' }}
-          {{ $errSchemaPath = $currErrSchemaPath; }}
-          {{? $breakOnError }} break; {{?}}
-        {{?}}
-      {{?? $additionalIsSchema }}
-        {{? $removeAdditional == 'failing' }}
-          var {{=$errs}} = errors;
-          {{# def.setCompositeRule }}
-
-          {{# def.validateAdditional }}
-
-          if (!{{=$nextValid}}) {
-            errors = {{=$errs}};
-            if (validate.errors !== null) {
-              if (errors) validate.errors.length = errors;
-              else validate.errors = null;
-            }
-            delete {{=$data}}[{{=$key}}];
-          }
-
-          {{# def.resetCompositeRule }}
-        {{??}}
-          {{# def.validateAdditional }}
-          {{? $breakOnError }} if (!{{=$nextValid}}) break; {{?}}
-        {{?}}
-      {{?}}
-      {{ it.errorPath = $currentErrorPath; }}
-    {{?}}
-    {{? $someProperties }}
-      }
-    {{?}}
-  }
-
-  {{# def.ifResultValid }}
-{{?}}
-
-{{ var $useDefaults = it.opts.useDefaults && !it.compositeRule; }}
-
-{{? $schemaKeys.length }}
-  {{~ $schemaKeys:$propertyKey }}
-    {{ var $sch = $schema[$propertyKey]; }}
-
-    {{? {{# def.nonEmptySchema:$sch}} }}
-      {{
-        var $prop = it.util.getProperty($propertyKey)
-          , $passData = $data + $prop
-          , $hasDefault = $useDefaults && $sch.default !== undefined;
-        $it.schema = $sch;
-        $it.schemaPath = $schemaPath + $prop;
-        $it.errSchemaPath = $errSchemaPath + '/' + it.util.escapeFragment($propertyKey);
-        $it.errorPath = it.util.getPath(it.errorPath, $propertyKey, it.opts.jsonPointers);
-        $it.dataPathArr[$dataNxt] = it.util.toQuotedString($propertyKey);
-      }}
-
-      {{# def.generateSubschemaCode }}
-
-      {{? {{# def.willOptimize }} }}
-        {{
-          $code = {{# def._optimizeValidate }};
-          var $useData = $passData;
-        }}
-      {{??}}
-        {{ var $useData = $nextData; }}
-        var {{=$nextData}} = {{=$passData}};
-      {{?}}
-
-      {{? $hasDefault }}
-        {{= $code }}
-      {{??}}
-        {{? $requiredHash && $requiredHash[$propertyKey] }}
-          if ({{=$useData}} === undefined) {
-            {{=$nextValid}} = false;
-            {{
-              var $currentErrorPath = it.errorPath
-                , $currErrSchemaPath = $errSchemaPath
-                , $missingProperty = it.util.escapeQuotes($propertyKey);
-              if (it.opts._errorDataPathProperty) {
-                it.errorPath = it.util.getPath($currentErrorPath, $propertyKey, it.opts.jsonPointers);
-              }
-              $errSchemaPath = it.errSchemaPath + '/required';
-            }}
-            {{# def.error:'required' }}
-            {{ $errSchemaPath = $currErrSchemaPath; }}
-            {{ it.errorPath = $currentErrorPath; }}
-          } else {
-        {{??}}
-          {{? $breakOnError }}
-            if ({{=$useData}} === undefined) {
-              {{=$nextValid}} = true;
-            } else {
-          {{??}}
-            if ({{=$useData}} !== undefined) {
-          {{?}}
-        {{?}}
-
-          {{= $code }}
-        }
-      {{?}}  {{ /* $hasDefault */ }}
-    {{?}} {{ /* def.nonEmptySchema */ }}
-
-    {{# def.ifResultValid }}
-  {{~}}
-{{?}}
-
-{{~ $pPropertyKeys:$pProperty }}
-  {{ var $sch = $pProperties[$pProperty]; }}
-
-  {{? {{# def.nonEmptySchema:$sch}} }}
-    {{
-      $it.schema = $sch;
-      $it.schemaPath = it.schemaPath + '.patternProperties' + it.util.getProperty($pProperty);
-      $it.errSchemaPath = it.errSchemaPath + '/patternProperties/'
-                                           + it.util.escapeFragment($pProperty);
-    }}
-
-    for (var {{=$key}} in {{=$data}}) {
-      {{# def.checkOwnProperty }}
-      if ({{= it.usePattern($pProperty) }}.test({{=$key}})) {
-        {{
-          $it.errorPath = it.util.getPathExpr(it.errorPath, $key, it.opts.jsonPointers);
-          var $passData = $data + '[' + $key + ']';
-          $it.dataPathArr[$dataNxt] = $key;
-        }}
-
-        {{# def.generateSubschemaCode }}
-        {{# def.optimizeValidate }}
-
-        {{? $breakOnError }} if (!{{=$nextValid}}) break; {{?}}
-      }
-      {{? $breakOnError }} else {{=$nextValid}} = true; {{?}}
-    }
-
-    {{# def.ifResultValid }}
-  {{?}} {{ /* def.nonEmptySchema */ }}
-{{~}}
-
-
-{{? it.opts.v5 }}
-  {{~ $pgPropertyKeys:$pgProperty }}
-    {{
-      var $pgSchema = $pgProperties[$pgProperty]
-        , $sch = $pgSchema.schema;
-    }}
-
-    {{? {{# def.nonEmptySchema:$sch}} }}
-      {{
-        $it.schema = $sch;
-        $it.schemaPath = it.schemaPath + '.patternGroups' + it.util.getProperty($pgProperty) + '.schema';
-        $it.errSchemaPath = it.errSchemaPath + '/patternGroups/'
-                                             + it.util.escapeFragment($pgProperty)
-                                             + '/schema';
-      }}
-
-      var pgPropCount{{=$lvl}} = 0;
-
-      for (var {{=$key}} in {{=$data}}) {
-        {{# def.checkOwnProperty }}
-        if ({{= it.usePattern($pgProperty) }}.test({{=$key}})) {
-          pgPropCount{{=$lvl}}++;
-
-          {{
-            $it.errorPath = it.util.getPathExpr(it.errorPath, $key, it.opts.jsonPointers);
-            var $passData = $data + '[' + $key + ']';
-            $it.dataPathArr[$dataNxt] = $key;
-          }}
-
-          {{# def.generateSubschemaCode }}
-          {{# def.optimizeValidate }}
-
-          {{? $breakOnError }} if (!{{=$nextValid}}) break; {{?}}
-        }
-        {{? $breakOnError }} else {{=$nextValid}} = true; {{?}}
-      }
-
-      {{# def.ifResultValid }}
-
-      {{
-        var $pgMin = $pgSchema.minimum
-          , $pgMax = $pgSchema.maximum;
-      }}
-      {{? $pgMin !== undefined || $pgMax !== undefined }}
-        var {{=$valid}} = true;
-
-        {{ var $currErrSchemaPath = $errSchemaPath; }}
-
-        {{? $pgMin !== undefined }}
-          {{ var $limit = $pgMin, $reason = 'minimum', $moreOrLess = 'less'; }}
-          {{=$valid}} = pgPropCount{{=$lvl}} >= {{=$pgMin}};
-          {{ $errSchemaPath = it.errSchemaPath + '/patternGroups/minimum'; }}
-          {{# def.checkError:'patternGroups' }}
-          {{? $pgMax !== undefined }}
-            else
-          {{?}}
-        {{?}}
-
-        {{? $pgMax !== undefined }}
-          {{ var $limit = $pgMax, $reason = 'maximum', $moreOrLess = 'more'; }}
-          {{=$valid}} = pgPropCount{{=$lvl}} <= {{=$pgMax}};
-          {{ $errSchemaPath = it.errSchemaPath + '/patternGroups/maximum'; }}
-          {{# def.checkError:'patternGroups' }}
-        {{?}}
-
-        {{ $errSchemaPath = $currErrSchemaPath; }}
-
-        {{# def.ifValid }}
-      {{?}}
-    {{?}} {{ /* def.nonEmptySchema */ }}
-  {{~}}
-{{?}}
-
-
-{{? $breakOnError }}
-  {{= $closingBraces }}
-  if ({{=$errs}} == errors) {
-{{?}}
-
-{{# def.cleanUp }}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/ref.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/ref.jst b/node_modules/ajv/lib/dot/ref.jst
deleted file mode 100644
index e8cdc44..0000000
--- a/node_modules/ajv/lib/dot/ref.jst
+++ /dev/null
@@ -1,86 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-
-{{## def._validateRef:_v:
-  {{? it.opts.passContext }}
-    {{=_v}}.call(this,
-  {{??}}
-    {{=_v}}(
-  {{?}}
-    {{=$data}}, {{# def.dataPath }}{{# def.passParentData }}, rootData)
-#}}
-
-{{ var $async, $refCode; }}
-{{? $schema == '#' || $schema == '#/' }}
-  {{
-    if (it.isRoot) {
-      $async = it.async;
-      $refCode = 'validate';
-    } else {
-      $async = it.root.schema.$async === true;
-      $refCode = 'root.refVal[0]';
-    }
-  }}
-{{??}}
-  {{ var $refVal = it.resolveRef(it.baseId, $schema, it.isRoot); }}
-  {{? $refVal === undefined }}
-    {{ var $message = 'can\'t resolve reference ' + $schema + ' from id ' + it.baseId; }}
-    {{? it.opts.missingRefs == 'fail' }}
-      {{ console.log($message); }}
-      {{# def.error:'$ref' }}
-      {{? $breakOnError }} if (false) { {{?}}
-    {{?? it.opts.missingRefs == 'ignore' }}
-      {{ console.log($message); }}
-      {{? $breakOnError }} if (true) { {{?}}
-    {{??}}
-      {{
-        var $error = new Error($message);
-        $error.missingRef = it.resolve.url(it.baseId, $schema);
-        $error.missingSchema = it.resolve.normalizeId(it.resolve.fullPath($error.missingRef));
-        throw $error;
-      }}
-    {{?}}
-  {{?? $refVal.inline }}
-    {{# def.setupNextLevel }}
-    {{
-      $it.schema = $refVal.schema;
-      $it.schemaPath = '';
-      $it.errSchemaPath = $schema;
-    }}
-    {{ var $code = it.validate($it).replace(/validate\.schema/g, $refVal.code); }}
-    {{= $code }}
-    {{? $breakOnError}}
-      if ({{=$nextValid}}) {
-    {{?}}
-  {{??}}
-    {{
-      $async = $refVal.$async === true;
-      $refCode = $refVal.code;
-    }}
-  {{?}}
-{{?}}
-
-{{? $refCode }}
-  {{# def.beginDefOut}}
-    {{# def._validateRef:$refCode }}
-  {{# def.storeDefOut:__callValidate }}
-
-  {{? $async }}
-    {{ if (!it.async) throw new Error('async schema referenced by sync schema'); }}
-    try { {{? $breakOnError }}var {{=$valid}} ={{?}} {{=it.yieldAwait}} {{=__callValidate}}; }
-    catch (e) {
-      if (!(e instanceof ValidationError)) throw e;
-      if (vErrors === null) vErrors = e.errors;
-      else vErrors = vErrors.concat(e.errors);
-      errors = vErrors.length;
-    }
-    {{? $breakOnError }} if ({{=$valid}}) { {{?}}
-  {{??}}
-    if (!{{=__callValidate}}) {
-      if (vErrors === null) vErrors = {{=$refCode}}.errors;
-      else vErrors = vErrors.concat({{=$refCode}}.errors);
-      errors = vErrors.length;
-    } {{? $breakOnError }} else { {{?}}
-  {{?}}
-{{?}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/required.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/required.jst b/node_modules/ajv/lib/dot/required.jst
deleted file mode 100644
index e109568..0000000
--- a/node_modules/ajv/lib/dot/required.jst
+++ /dev/null
@@ -1,96 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.missing }}
-{{# def.setupKeyword }}
-{{# def.$data }}
-
-{{ var $vSchema = 'schema' + $lvl; }}
-
-{{## def.setupLoop:
-  {{? !$isData }}
-    var {{=$vSchema}} = validate.schema{{=$schemaPath}};
-  {{?}}
-
-  {{
-    var $i = 'i' + $lvl
-      , $propertyPath = 'schema' + $lvl + '[' + $i + ']'
-      , $missingProperty = '\' + ' + $propertyPath + ' + \'';
-    if (it.opts._errorDataPathProperty) {
-      it.errorPath = it.util.getPathExpr($currentErrorPath, $propertyPath, it.opts.jsonPointers);
-    }
-  }}
-#}}
-
-
-{{? !$isData }}
-  {{? $schema.length < it.opts.loopRequired &&
-      it.schema.properties && Object.keys(it.schema.properties).length }}
-    {{ var $required = []; }}
-    {{~ $schema:$property }}
-      {{ var $propertySch = it.schema.properties[$property]; }}
-      {{? !($propertySch && {{# def.nonEmptySchema:$propertySch}}) }}
-        {{ $required[$required.length] = $property; }}
-      {{?}}
-    {{~}}
-  {{??}}
-    {{ var $required = $schema; }}
-  {{?}}
-{{?}}
-
-
-{{? $isData || $required.length }}
-  {{
-    var $currentErrorPath = it.errorPath
-      , $loopRequired = $isData || $required.length >= it.opts.loopRequired;
-  }}
-
-  {{? $breakOnError }}
-    var missing{{=$lvl}};
-    {{? $loopRequired }}
-      {{# def.setupLoop }}
-      var {{=$valid}} = true;
-
-      {{?$isData}}{{# def.check$dataIsArray }}{{?}}
-
-      for (var {{=$i}} = 0; {{=$i}} < {{=$vSchema}}.length; {{=$i}}++) {
-        {{=$valid}} = {{=$data}}[{{=$vSchema}}[{{=$i}}]] !== undefined;
-        if (!{{=$valid}}) break;
-      }
-
-      {{? $isData }}  }  {{?}}
-
-      {{# def.checkError:'required' }}
-      else {
-    {{??}}
-      if ({{# def.checkMissingProperty:$required }}) {
-        {{# def.errorMissingProperty:'required' }}
-      } else {
-    {{?}}
-  {{??}}
-    {{? $loopRequired }}
-      {{# def.setupLoop }}
-      {{? $isData }}
-        if ({{=$vSchema}} && !Array.isArray({{=$vSchema}})) {
-          {{# def.addError:'required' }}
-        } else if ({{=$vSchema}} !== undefined) {
-      {{?}}
-
-      for (var {{=$i}} = 0; {{=$i}} < {{=$vSchema}}.length; {{=$i}}++) {
-        if ({{=$data}}[{{=$vSchema}}[{{=$i}}]] === undefined) {
-          {{# def.addError:'required' }}
-        }
-      }
-
-      {{? $isData }}  }  {{?}}
-    {{??}}
-      {{~ $required:$reqProperty }}
-        {{# def.allErrorsMissingProperty:'required' }}
-      {{~}}
-    {{?}}
-  {{?}}
-
-  {{ it.errorPath = $currentErrorPath; }}
-
-{{?? $breakOnError }}
-  if (true) {
-{{?}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/uniqueItems.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/uniqueItems.jst b/node_modules/ajv/lib/dot/uniqueItems.jst
deleted file mode 100644
index dfc42b0..0000000
--- a/node_modules/ajv/lib/dot/uniqueItems.jst
+++ /dev/null
@@ -1,38 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-{{# def.$data }}
-
-
-{{? ($schema || $isData) && it.opts.uniqueItems !== false }}
-  {{? $isData }}
-    var {{=$valid}};
-    if ({{=$schemaValue}} === false || {{=$schemaValue}} === undefined)
-      {{=$valid}} = true;
-    else if (typeof {{=$schemaValue}} != 'boolean')
-      {{=$valid}} = false;
-    else {
-  {{?}}
-
-  var {{=$valid}} = true;
-  if ({{=$data}}.length > 1) {
-    var i = {{=$data}}.length, j;
-    outer:
-    for (;i--;) {
-      for (j = i; j--;) {
-        if (equal({{=$data}}[i], {{=$data}}[j])) {
-          {{=$valid}} = false;
-          break outer;
-        }
-      }
-    }
-  }
-
-  {{? $isData }}  }  {{?}}
-
-  if (!{{=$valid}}) {
-    {{# def.error:'uniqueItems' }}
-  } {{? $breakOnError }} else { {{?}}
-{{??}}
-  {{? $breakOnError }} if (true) { {{?}}
-{{?}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/v5/_formatLimit.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/v5/_formatLimit.jst b/node_modules/ajv/lib/dot/v5/_formatLimit.jst
deleted file mode 100644
index af16b88..0000000
--- a/node_modules/ajv/lib/dot/v5/_formatLimit.jst
+++ /dev/null
@@ -1,116 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-
-var {{=$valid}} = undefined;
-
-{{## def.skipFormatLimit:
-  {{=$valid}} = true;
-  {{ return out; }}
-#}}
-
-{{## def.compareFormat:
-  {{? $isData }}
-    if ({{=$schemaValue}} === undefined) {{=$valid}} = true;
-    else if (typeof {{=$schemaValue}} != 'string') {{=$valid}} = false;
-    else {
-    {{ $closingBraces += '}'; }}
-  {{?}}
-
-  {{? $isDataFormat }}
-    if (!{{=$compare}}) {{=$valid}} = true;
-    else {
-    {{ $closingBraces += '}'; }}
-  {{?}}
-
-  var {{=$result}} = {{=$compare}}({{=$data}}, {{# def.schemaValueQS }});
-
-  if ({{=$result}} === undefined) {{=$valid}} = false;
-#}}
-
-
-{{? it.opts.format === false }}{{# def.skipFormatLimit }}{{?}}
-
-{{
-  var $schemaFormat = it.schema.format
-    , $isDataFormat = it.opts.v5 && $schemaFormat.$data
-    , $closingBraces = '';
-}}
-
-{{? $isDataFormat }}
-  {{
-    var $schemaValueFormat = it.util.getData($schemaFormat.$data, $dataLvl, it.dataPathArr)
-      , $format = 'format' + $lvl
-      , $compare = 'compare' + $lvl;
-  }}
-
-  var {{=$format}} = formats[{{=$schemaValueFormat}}]
-    , {{=$compare}} = {{=$format}} && {{=$format}}.compare;
-{{??}}
-  {{ var $format = it.formats[$schemaFormat]; }}
-  {{? !($format && $format.compare) }}
-    {{# def.skipFormatLimit }}
-  {{?}}
-  {{ var $compare = 'formats' + it.util.getProperty($schemaFormat) + '.compare'; }}
-{{?}}
-
-{{
-  var $isMax = $keyword == 'formatMaximum'
-    , $exclusiveKeyword = 'formatExclusive' + ($isMax ? 'Maximum' : 'Minimum')
-    , $schemaExcl = it.schema[$exclusiveKeyword]
-    , $isDataExcl = it.opts.v5 && $schemaExcl && $schemaExcl.$data
-    , $op = $isMax ? '<' : '>'
-    , $result = 'result' + $lvl;
-}}
-
-{{# def.$data }}
-
-
-{{? $isDataExcl }}
-  {{
-    var $schemaValueExcl = it.util.getData($schemaExcl.$data, $dataLvl, it.dataPathArr)
-      , $exclusive = 'exclusive' + $lvl
-      , $opExpr = 'op' + $lvl
-      , $opStr = '\' + ' + $opExpr + ' + \'';
-  }}
-  var schemaExcl{{=$lvl}} = {{=$schemaValueExcl}};
-  {{ $schemaValueExcl = 'schemaExcl' + $lvl; }}
-
-  if (typeof {{=$schemaValueExcl}} != 'boolean' && {{=$schemaValueExcl}} !== undefined) {
-    {{=$valid}} = false;
-    {{ var $errorKeyword = $exclusiveKeyword; }}
-    {{# def.error:'_formatExclusiveLimit' }}
-  }
-
-  {{# def.elseIfValid }}
-
-  {{# def.compareFormat }}
-  var {{=$exclusive}} = {{=$schemaValueExcl}} === true;
-
-  if ({{=$valid}} === undefined) {
-    {{=$valid}} = {{=$exclusive}}
-                  ? {{=$result}} {{=$op}} 0
-                  : {{=$result}} {{=$op}}= 0;
-  }
-
-  if (!{{=$valid}}) var op{{=$lvl}} = {{=$exclusive}} ? '{{=$op}}' : '{{=$op}}=';
-{{??}}
-  {{
-    var $exclusive = $schemaExcl === true
-      , $opStr = $op;  /*used in error*/
-    if (!$exclusive) $opStr += '=';
-    var $opExpr = '\'' + $opStr + '\''; /*used in error*/
-  }}
-
-  {{# def.compareFormat }}
-
-  if ({{=$valid}} === undefined)
-    {{=$valid}} = {{=$result}} {{=$op}}{{?!$exclusive}}={{?}} 0;
-{{?}}
-
-{{= $closingBraces }}
-
-if (!{{=$valid}}) {
-  {{ var $errorKeyword = $keyword; }}
-  {{# def.error:'_formatLimit' }}
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/v5/constant.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/v5/constant.jst b/node_modules/ajv/lib/dot/v5/constant.jst
deleted file mode 100644
index 67969c1..0000000
--- a/node_modules/ajv/lib/dot/v5/constant.jst
+++ /dev/null
@@ -1,10 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-{{# def.$data }}
-
-{{? !$isData }}
-  var schema{{=$lvl}} = validate.schema{{=$schemaPath}};
-{{?}}
-var {{=$valid}} = equal({{=$data}}, schema{{=$lvl}});
-{{# def.checkError:'constant' }}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/v5/patternRequired.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/v5/patternRequired.jst b/node_modules/ajv/lib/dot/v5/patternRequired.jst
deleted file mode 100644
index 9af2cdc..0000000
--- a/node_modules/ajv/lib/dot/v5/patternRequired.jst
+++ /dev/null
@@ -1,28 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-
-{{
-  var $key = 'key' + $lvl
-    , $matched = 'patternMatched' + $lvl
-    , $closingBraces = ''
-    , $ownProperties = it.opts.ownProperties;
-}}
-
-var {{=$valid}} = true;
-{{~ $schema:$pProperty }}
-  var {{=$matched}} = false;
-  for (var {{=$key}} in {{=$data}}) {
-    {{# def.checkOwnProperty }}
-    {{=$matched}} = {{= it.usePattern($pProperty) }}.test({{=$key}});
-    if ({{=$matched}}) break;
-  }
-
-  {{ var $missingPattern = it.util.escapeQuotes($pProperty); }}
-  if (!{{=$matched}}) {
-    {{=$valid}} = false;
-    {{# def.addError:'patternRequired' }}
-  } {{# def.elseIfValid }}
-{{~}}
-
-{{= $closingBraces }}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/v5/switch.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/v5/switch.jst b/node_modules/ajv/lib/dot/v5/switch.jst
deleted file mode 100644
index 389678e..0000000
--- a/node_modules/ajv/lib/dot/v5/switch.jst
+++ /dev/null
@@ -1,73 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.setupKeyword }}
-{{# def.setupNextLevel }}
-
-
-{{## def.validateIf:
-  {{# def.setCompositeRule }}
-  {{ $it.createErrors = false; }}
-  {{# def._validateSwitchRule:if }}
-  {{ $it.createErrors = true; }}
-  {{# def.resetCompositeRule }}
-  {{=$ifPassed}} = {{=$nextValid}};
-#}}
-
-{{## def.validateThen:
-  {{? typeof $sch.then == 'boolean' }}
-    {{? $sch.then === false }}
-      {{# def.error:'switch' }}
-    {{?}}
-    var {{=$nextValid}} = {{= $sch.then }};
-  {{??}}
-    {{# def._validateSwitchRule:then }}
-  {{?}}
-#}}
-
-{{## def._validateSwitchRule:_clause:
-  {{
-    $it.schema = $sch._clause;
-    $it.schemaPath = $schemaPath + '[' + $caseIndex + ']._clause';
-    $it.errSchemaPath = $errSchemaPath + '/' + $caseIndex + '/_clause';
-  }}
-  {{# def.insertSubschemaCode }}
-#}}
-
-{{## def.switchCase:
-  {{? $sch.if && {{# def.nonEmptySchema:$sch.if }} }}
-    var {{=$errs}} = errors;
-    {{# def.validateIf }}
-    if ({{=$ifPassed}}) {
-      {{# def.validateThen }}  
-    } else {
-      {{# def.resetErrors }}
-    }
-  {{??}}
-    {{=$ifPassed}} = true;
-    {{# def.validateThen }}
-  {{?}}
-#}}
-
-
-{{
-  var $ifPassed = 'ifPassed' + it.level
-    , $currentBaseId = $it.baseId
-    , $shouldContinue;
-}}
-var {{=$ifPassed}};
-
-{{~ $schema:$sch:$caseIndex }}
-  {{? $caseIndex && !$shouldContinue }}
-    if (!{{=$ifPassed}}) {
-    {{ $closingBraces+= '}'; }}
-  {{?}}
-
-  {{# def.switchCase }}
-  {{ $shouldContinue = $sch.continue }}
-{{~}}
-
-{{= $closingBraces }}
-
-var {{=$valid}} = {{=$nextValid}};
-
-{{# def.cleanUp }}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dot/validate.jst
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dot/validate.jst b/node_modules/ajv/lib/dot/validate.jst
deleted file mode 100644
index 1b08758..0000000
--- a/node_modules/ajv/lib/dot/validate.jst
+++ /dev/null
@@ -1,210 +0,0 @@
-{{# def.definitions }}
-{{# def.errors }}
-{{# def.defaults }}
-{{# def.coerce }}
-
-{{ /**
-    * schema compilation (render) time:
-    * it = { schema, RULES, _validate, opts }
-    * it.validate - this template function,
-    *   it is used recursively to generate code for subschemas
-    *
-    * runtime:
-    * "validate" is a variable name to which this function will be assigned
-    * validateRef etc. are defined in the parent scope in index.js
-    */ }}
-
-{{ var $async = it.schema.$async === true; }}
-
-{{? it.isTop}}
-  {{
-    var $top = it.isTop
-      , $lvl = it.level = 0
-      , $dataLvl = it.dataLevel = 0
-      , $data = 'data';
-    it.rootId = it.resolve.fullPath(it.root.schema.id);
-    it.baseId = it.baseId || it.rootId;
-    if ($async) {
-      it.async = true;
-      var $es7 = it.opts.async == 'es7';
-      it.yieldAwait = $es7 ? 'await' : 'yield';
-    }
-    delete it.isTop;
-
-    it.dataPathArr = [undefined];
-  }}
-
-  var validate =
-  {{? $async }}
-    {{? $es7 }}
-      (async function
-    {{??}}
-      {{? it.opts.async == 'co*'}}co.wrap{{?}}(function*
-    {{?}}
-  {{??}}
-    (function
-  {{?}}
-    (data, dataPath, parentData, parentDataProperty, rootData) {
-    'use strict';
-    var vErrors = null; {{ /* don't edit, used in replace */ }}
-    var errors = 0;     {{ /* don't edit, used in replace */ }}
-    if (rootData === undefined) rootData = data;
-{{??}}
-  {{
-    var $lvl = it.level
-      , $dataLvl = it.dataLevel
-      , $data = 'data' + ($dataLvl || '');
-
-    if (it.schema.id) it.baseId = it.resolve.url(it.baseId, it.schema.id);
-
-    if ($async && !it.async) throw new Error('async schema in sync schema');
-  }}
-
-  var errs_{{=$lvl}} = errors;
-{{?}}
-
-{{
-  var $valid = 'valid' + $lvl
-    , $breakOnError = !it.opts.allErrors
-    , $closingBraces1 = ''
-    , $closingBraces2 = ''
-    , $errorKeyword;
-
-  var $typeSchema = it.schema.type
-    , $typeIsArray = Array.isArray($typeSchema);
-}}
-
-{{## def.checkType:
-  {{
-    var $schemaPath = it.schemaPath + '.type'
-      , $errSchemaPath = it.errSchemaPath + '/type'
-      , $method = $typeIsArray ? 'checkDataTypes' : 'checkDataType';
-  }}
-
-  if ({{= it.util[$method]($typeSchema, $data, true) }}) {
-#}}
-
-{{? $typeSchema && it.opts.coerceTypes }}
-  {{ var $coerceToTypes = it.util.coerceToTypes(it.opts.coerceTypes, $typeSchema); }}
-  {{? $coerceToTypes }}
-    {{# def.checkType }}
-      {{# def.coerceType }}
-    }
-  {{?}}
-{{?}}
-
-{{ var $refKeywords; }}
-{{? it.schema.$ref && ($refKeywords = it.util.schemaHasRulesExcept(it.schema, it.RULES.all, '$ref')) }}
-  {{? it.opts.extendRefs == 'fail' }}
-    {{ throw new Error('$ref: validation keywords used in schema at path "' + it.errSchemaPath + '"'); }}
-  {{?? it.opts.extendRefs == 'ignore' }}
-    {{
-      $refKeywords = false;
-      console.log('$ref: keywords ignored in schema at path "' + it.errSchemaPath + '"');
-    }}
-  {{?? it.opts.extendRefs !== true }}
-    {{ console.log('$ref: all keywords used in schema at path "' + it.errSchemaPath + '". It will change in the next major version, see issue #260. Use option { extendRefs: true } to keep current behaviour'); }}
-  {{?}}
-{{?}}
-
-{{? it.schema.$ref && !$refKeywords }}
-  {{= it.RULES.all.$ref.code(it, '$ref') }}
-  {{? $breakOnError }}
-    }
-    if (errors === {{?$top}}0{{??}}errs_{{=$lvl}}{{?}}) {
-    {{ $closingBraces2 += '}'; }}
-  {{?}}
-{{??}}
-  {{~ it.RULES:$rulesGroup }}
-    {{? $shouldUseGroup($rulesGroup) }}
-      {{? $rulesGroup.type }}
-        if ({{= it.util.checkDataType($rulesGroup.type, $data) }}) {
-      {{?}}
-        {{? it.opts.useDefaults && !it.compositeRule }}
-          {{? $rulesGroup.type == 'object' && it.schema.properties }}
-            {{# def.defaultProperties }}
-          {{?? $rulesGroup.type == 'array' && Array.isArray(it.schema.items) }}
-            {{# def.defaultItems }}
-          {{?}}
-        {{?}}
-        {{~ $rulesGroup.rules:$rule }}
-          {{? $shouldUseRule($rule) }}
-            {{= $rule.code(it, $rule.keyword) }}
-            {{? $breakOnError }}
-              {{ $closingBraces1 += '}'; }}
-            {{?}}
-          {{?}}
-        {{~}}
-        {{? $breakOnError }}
-          {{= $closingBraces1 }}
-          {{ $closingBraces1 = ''; }}
-        {{?}}
-      {{? $rulesGroup.type }}
-        }
-        {{? $typeSchema && $typeSchema === $rulesGroup.type }}
-          {{ var $typeChecked = true; }}
-          else {
-            {{
-              var $schemaPath = it.schemaPath + '.type'
-                , $errSchemaPath = it.errSchemaPath + '/type';
-            }}
-            {{# def.error:'type' }}
-          }
-        {{?}}
-      {{?}}
-
-      {{? $breakOnError }}
-        if (errors === {{?$top}}0{{??}}errs_{{=$lvl}}{{?}}) {
-        {{ $closingBraces2 += '}'; }}
-      {{?}}
-    {{?}}
-  {{~}}
-{{?}}
-
-{{? $typeSchema && !$typeChecked && !(it.opts.coerceTypes && $coerceToTypes) }}
-  {{# def.checkType }}
-    {{# def.error:'type' }}
-  }
-{{?}}
-
-{{? $breakOnError }} {{= $closingBraces2 }} {{?}}
-
-{{? $top }}
-    {{? $async }}
-      if (errors === 0) return true;           {{ /* don't edit, used in replace */ }}
-      else throw new ValidationError(vErrors); {{ /* don't edit, used in replace */ }}
-    {{??}}
-      validate.errors = vErrors; {{ /* don't edit, used in replace */ }}
-      return errors === 0;       {{ /* don't edit, used in replace */ }}
-    {{?}}
-  });
-
-  return validate;
-{{??}}
-  var {{=$valid}} = errors === errs_{{=$lvl}};
-{{?}}
-
-{{# def.cleanUp }}
-
-{{? $top && $breakOnError }}
-  {{# def.cleanUpVarErrors }}
-{{?}}
-
-{{
-  function $shouldUseGroup($rulesGroup) {
-    for (var i=0; i < $rulesGroup.rules.length; i++)
-      if ($shouldUseRule($rulesGroup.rules[i]))
-        return true;
-  }
-
-  function $shouldUseRule($rule) {
-    return it.schema[$rule.keyword] !== undefined ||
-           ( $rule.keyword == 'properties' &&
-             ( it.schema.additionalProperties === false ||
-               typeof it.schema.additionalProperties == 'object'
-               || ( it.schema.patternProperties &&
-                    Object.keys(it.schema.patternProperties).length )
-               || ( it.opts.v5 && it.schema.patternGroups &&
-                    Object.keys(it.schema.patternGroups).length )));
-  }
-}}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dotjs/README.md
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dotjs/README.md b/node_modules/ajv/lib/dotjs/README.md
deleted file mode 100644
index 4d99484..0000000
--- a/node_modules/ajv/lib/dotjs/README.md
+++ /dev/null
@@ -1,3 +0,0 @@
-These files are compiled dot templates from dot folder.
-
-Do NOT edit them directly, edit the templates and run `npm run build` from main ajv folder.

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dotjs/_formatLimit.js
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dotjs/_formatLimit.js b/node_modules/ajv/lib/dotjs/_formatLimit.js
deleted file mode 100644
index 996e1f2..0000000
--- a/node_modules/ajv/lib/dotjs/_formatLimit.js
+++ /dev/null
@@ -1,176 +0,0 @@
-'use strict';
-module.exports = function generate__formatLimit(it, $keyword) {
-  var out = ' ';
-  var $lvl = it.level;
-  var $dataLvl = it.dataLevel;
-  var $schema = it.schema[$keyword];
-  var $schemaPath = it.schemaPath + it.util.getProperty($keyword);
-  var $errSchemaPath = it.errSchemaPath + '/' + $keyword;
-  var $breakOnError = !it.opts.allErrors;
-  var $errorKeyword;
-  var $data = 'data' + ($dataLvl || '');
-  var $valid = 'valid' + $lvl;
-  out += 'var ' + ($valid) + ' = undefined;';
-  if (it.opts.format === false) {
-    out += ' ' + ($valid) + ' = true; ';
-    return out;
-  }
-  var $schemaFormat = it.schema.format,
-    $isDataFormat = it.opts.v5 && $schemaFormat.$data,
-    $closingBraces = '';
-  if ($isDataFormat) {
-    var $schemaValueFormat = it.util.getData($schemaFormat.$data, $dataLvl, it.dataPathArr),
-      $format = 'format' + $lvl,
-      $compare = 'compare' + $lvl;
-    out += ' var ' + ($format) + ' = formats[' + ($schemaValueFormat) + '] , ' + ($compare) + ' = ' + ($format) + ' && ' + ($format) + '.compare;';
-  } else {
-    var $format = it.formats[$schemaFormat];
-    if (!($format && $format.compare)) {
-      out += '  ' + ($valid) + ' = true; ';
-      return out;
-    }
-    var $compare = 'formats' + it.util.getProperty($schemaFormat) + '.compare';
-  }
-  var $isMax = $keyword == 'formatMaximum',
-    $exclusiveKeyword = 'formatExclusive' + ($isMax ? 'Maximum' : 'Minimum'),
-    $schemaExcl = it.schema[$exclusiveKeyword],
-    $isDataExcl = it.opts.v5 && $schemaExcl && $schemaExcl.$data,
-    $op = $isMax ? '<' : '>',
-    $result = 'result' + $lvl;
-  var $isData = it.opts.v5 && $schema && $schema.$data,
-    $schemaValue;
-  if ($isData) {
-    out += ' var schema' + ($lvl) + ' = ' + (it.util.getData($schema.$data, $dataLvl, it.dataPathArr)) + '; ';
-    $schemaValue = 'schema' + $lvl;
-  } else {
-    $schemaValue = $schema;
-  }
-  if ($isDataExcl) {
-    var $schemaValueExcl = it.util.getData($schemaExcl.$data, $dataLvl, it.dataPathArr),
-      $exclusive = 'exclusive' + $lvl,
-      $opExpr = 'op' + $lvl,
-      $opStr = '\' + ' + $opExpr + ' + \'';
-    out += ' var schemaExcl' + ($lvl) + ' = ' + ($schemaValueExcl) + '; ';
-    $schemaValueExcl = 'schemaExcl' + $lvl;
-    out += ' if (typeof ' + ($schemaValueExcl) + ' != \'boolean\' && ' + ($schemaValueExcl) + ' !== undefined) { ' + ($valid) + ' = false; ';
-    var $errorKeyword = $exclusiveKeyword;
-    var $$outStack = $$outStack || [];
-    $$outStack.push(out);
-    out = ''; /* istanbul ignore else */
-    if (it.createErrors !== false) {
-      out += ' { keyword: \'' + ($errorKeyword || '_formatExclusiveLimit') + '\' , dataPath: (dataPath || \'\') + ' + (it.errorPath) + ' , schemaPath: ' + (it.util.toQuotedString($errSchemaPath)) + ' , params: {} ';
-      if (it.opts.messages !== false) {
-        out += ' , message: \'' + ($exclusiveKeyword) + ' should be boolean\' ';
-      }
-      if (it.opts.verbose) {
-        out += ' , schema: validate.schema' + ($schemaPath) + ' , parentSchema: validate.schema' + (it.schemaPath) + ' , data: ' + ($data) + ' ';
-      }
-      out += ' } ';
-    } else {
-      out += ' {} ';
-    }
-    var __err = out;
-    out = $$outStack.pop();
-    if (!it.compositeRule && $breakOnError) { /* istanbul ignore if */
-      if (it.async) {
-        out += ' throw new ValidationError([' + (__err) + ']); ';
-      } else {
-        out += ' validate.errors = [' + (__err) + ']; return false; ';
-      }
-    } else {
-      out += ' var err = ' + (__err) + ';  if (vErrors === null) vErrors = [err]; else vErrors.push(err); errors++; ';
-    }
-    out += ' }  ';
-    if ($breakOnError) {
-      $closingBraces += '}';
-      out += ' else { ';
-    }
-    if ($isData) {
-      out += ' if (' + ($schemaValue) + ' === undefined) ' + ($valid) + ' = true; else if (typeof ' + ($schemaValue) + ' != \'string\') ' + ($valid) + ' = false; else { ';
-      $closingBraces += '}';
-    }
-    if ($isDataFormat) {
-      out += ' if (!' + ($compare) + ') ' + ($valid) + ' = true; else { ';
-      $closingBraces += '}';
-    }
-    out += ' var ' + ($result) + ' = ' + ($compare) + '(' + ($data) + ',  ';
-    if ($isData) {
-      out += '' + ($schemaValue);
-    } else {
-      out += '' + (it.util.toQuotedString($schema));
-    }
-    out += ' ); if (' + ($result) + ' === undefined) ' + ($valid) + ' = false; var ' + ($exclusive) + ' = ' + ($schemaValueExcl) + ' === true; if (' + ($valid) + ' === undefined) { ' + ($valid) + ' = ' + ($exclusive) + ' ? ' + ($result) + ' ' + ($op) + ' 0 : ' + ($result) + ' ' + ($op) + '= 0; } if (!' + ($valid) + ') var op' + ($lvl) + ' = ' + ($exclusive) + ' ? \'' + ($op) + '\' : \'' + ($op) + '=\';';
-  } else {
-    var $exclusive = $schemaExcl === true,
-      $opStr = $op;
-    if (!$exclusive) $opStr += '=';
-    var $opExpr = '\'' + $opStr + '\'';
-    if ($isData) {
-      out += ' if (' + ($schemaValue) + ' === undefined) ' + ($valid) + ' = true; else if (typeof ' + ($schemaValue) + ' != \'string\') ' + ($valid) + ' = false; else { ';
-      $closingBraces += '}';
-    }
-    if ($isDataFormat) {
-      out += ' if (!' + ($compare) + ') ' + ($valid) + ' = true; else { ';
-      $closingBraces += '}';
-    }
-    out += ' var ' + ($result) + ' = ' + ($compare) + '(' + ($data) + ',  ';
-    if ($isData) {
-      out += '' + ($schemaValue);
-    } else {
-      out += '' + (it.util.toQuotedString($schema));
-    }
-    out += ' ); if (' + ($result) + ' === undefined) ' + ($valid) + ' = false; if (' + ($valid) + ' === undefined) ' + ($valid) + ' = ' + ($result) + ' ' + ($op);
-    if (!$exclusive) {
-      out += '=';
-    }
-    out += ' 0;';
-  }
-  out += '' + ($closingBraces) + 'if (!' + ($valid) + ') { ';
-  var $errorKeyword = $keyword;
-  var $$outStack = $$outStack || [];
-  $$outStack.push(out);
-  out = ''; /* istanbul ignore else */
-  if (it.createErrors !== false) {
-    out += ' { keyword: \'' + ($errorKeyword || '_formatLimit') + '\' , dataPath: (dataPath || \'\') + ' + (it.errorPath) + ' , schemaPath: ' + (it.util.toQuotedString($errSchemaPath)) + ' , params: { comparison: ' + ($opExpr) + ', limit:  ';
-    if ($isData) {
-      out += '' + ($schemaValue);
-    } else {
-      out += '' + (it.util.toQuotedString($schema));
-    }
-    out += ' , exclusive: ' + ($exclusive) + ' } ';
-    if (it.opts.messages !== false) {
-      out += ' , message: \'should be ' + ($opStr) + ' "';
-      if ($isData) {
-        out += '\' + ' + ($schemaValue) + ' + \'';
-      } else {
-        out += '' + (it.util.escapeQuotes($schema));
-      }
-      out += '"\' ';
-    }
-    if (it.opts.verbose) {
-      out += ' , schema:  ';
-      if ($isData) {
-        out += 'validate.schema' + ($schemaPath);
-      } else {
-        out += '' + (it.util.toQuotedString($schema));
-      }
-      out += '         , parentSchema: validate.schema' + (it.schemaPath) + ' , data: ' + ($data) + ' ';
-    }
-    out += ' } ';
-  } else {
-    out += ' {} ';
-  }
-  var __err = out;
-  out = $$outStack.pop();
-  if (!it.compositeRule && $breakOnError) { /* istanbul ignore if */
-    if (it.async) {
-      out += ' throw new ValidationError([' + (__err) + ']); ';
-    } else {
-      out += ' validate.errors = [' + (__err) + ']; return false; ';
-    }
-  } else {
-    out += ' var err = ' + (__err) + ';  if (vErrors === null) vErrors = [err]; else vErrors.push(err); errors++; ';
-  }
-  out += '}';
-  return out;
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dotjs/_limit.js
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dotjs/_limit.js b/node_modules/ajv/lib/dotjs/_limit.js
deleted file mode 100644
index 4d92024..0000000
--- a/node_modules/ajv/lib/dotjs/_limit.js
+++ /dev/null
@@ -1,124 +0,0 @@
-'use strict';
-module.exports = function generate__limit(it, $keyword) {
-  var out = ' ';
-  var $lvl = it.level;
-  var $dataLvl = it.dataLevel;
-  var $schema = it.schema[$keyword];
-  var $schemaPath = it.schemaPath + it.util.getProperty($keyword);
-  var $errSchemaPath = it.errSchemaPath + '/' + $keyword;
-  var $breakOnError = !it.opts.allErrors;
-  var $errorKeyword;
-  var $data = 'data' + ($dataLvl || '');
-  var $isData = it.opts.v5 && $schema && $schema.$data,
-    $schemaValue;
-  if ($isData) {
-    out += ' var schema' + ($lvl) + ' = ' + (it.util.getData($schema.$data, $dataLvl, it.dataPathArr)) + '; ';
-    $schemaValue = 'schema' + $lvl;
-  } else {
-    $schemaValue = $schema;
-  }
-  var $isMax = $keyword == 'maximum',
-    $exclusiveKeyword = $isMax ? 'exclusiveMaximum' : 'exclusiveMinimum',
-    $schemaExcl = it.schema[$exclusiveKeyword],
-    $isDataExcl = it.opts.v5 && $schemaExcl && $schemaExcl.$data,
-    $op = $isMax ? '<' : '>',
-    $notOp = $isMax ? '>' : '<';
-  if ($isDataExcl) {
-    var $schemaValueExcl = it.util.getData($schemaExcl.$data, $dataLvl, it.dataPathArr),
-      $exclusive = 'exclusive' + $lvl,
-      $opExpr = 'op' + $lvl,
-      $opStr = '\' + ' + $opExpr + ' + \'';
-    out += ' var schemaExcl' + ($lvl) + ' = ' + ($schemaValueExcl) + '; ';
-    $schemaValueExcl = 'schemaExcl' + $lvl;
-    out += ' var exclusive' + ($lvl) + '; if (typeof ' + ($schemaValueExcl) + ' != \'boolean\' && typeof ' + ($schemaValueExcl) + ' != \'undefined\') { ';
-    var $errorKeyword = $exclusiveKeyword;
-    var $$outStack = $$outStack || [];
-    $$outStack.push(out);
-    out = ''; /* istanbul ignore else */
-    if (it.createErrors !== false) {
-      out += ' { keyword: \'' + ($errorKeyword || '_exclusiveLimit') + '\' , dataPath: (dataPath || \'\') + ' + (it.errorPath) + ' , schemaPath: ' + (it.util.toQuotedString($errSchemaPath)) + ' , params: {} ';
-      if (it.opts.messages !== false) {
-        out += ' , message: \'' + ($exclusiveKeyword) + ' should be boolean\' ';
-      }
-      if (it.opts.verbose) {
-        out += ' , schema: validate.schema' + ($schemaPath) + ' , parentSchema: validate.schema' + (it.schemaPath) + ' , data: ' + ($data) + ' ';
-      }
-      out += ' } ';
-    } else {
-      out += ' {} ';
-    }
-    var __err = out;
-    out = $$outStack.pop();
-    if (!it.compositeRule && $breakOnError) { /* istanbul ignore if */
-      if (it.async) {
-        out += ' throw new ValidationError([' + (__err) + ']); ';
-      } else {
-        out += ' validate.errors = [' + (__err) + ']; return false; ';
-      }
-    } else {
-      out += ' var err = ' + (__err) + ';  if (vErrors === null) vErrors = [err]; else vErrors.push(err); errors++; ';
-    }
-    out += ' } else if( ';
-    if ($isData) {
-      out += ' (' + ($schemaValue) + ' !== undefined && typeof ' + ($schemaValue) + ' != \'number\') || ';
-    }
-    out += ' ((exclusive' + ($lvl) + ' = ' + ($schemaValueExcl) + ' === true) ? ' + ($data) + ' ' + ($notOp) + '= ' + ($schemaValue) + ' : ' + ($data) + ' ' + ($notOp) + ' ' + ($schemaValue) + ') || ' + ($data) + ' !== ' + ($data) + ') { var op' + ($lvl) + ' = exclusive' + ($lvl) + ' ? \'' + ($op) + '\' : \'' + ($op) + '=\';';
-  } else {
-    var $exclusive = $schemaExcl === true,
-      $opStr = $op;
-    if (!$exclusive) $opStr += '=';
-    var $opExpr = '\'' + $opStr + '\'';
-    out += ' if ( ';
-    if ($isData) {
-      out += ' (' + ($schemaValue) + ' !== undefined && typeof ' + ($schemaValue) + ' != \'number\') || ';
-    }
-    out += ' ' + ($data) + ' ' + ($notOp);
-    if ($exclusive) {
-      out += '=';
-    }
-    out += ' ' + ($schemaValue) + ' || ' + ($data) + ' !== ' + ($data) + ') {';
-  }
-  var $errorKeyword = $keyword;
-  var $$outStack = $$outStack || [];
-  $$outStack.push(out);
-  out = ''; /* istanbul ignore else */
-  if (it.createErrors !== false) {
-    out += ' { keyword: \'' + ($errorKeyword || '_limit') + '\' , dataPath: (dataPath || \'\') + ' + (it.errorPath) + ' , schemaPath: ' + (it.util.toQuotedString($errSchemaPath)) + ' , params: { comparison: ' + ($opExpr) + ', limit: ' + ($schemaValue) + ', exclusive: ' + ($exclusive) + ' } ';
-    if (it.opts.messages !== false) {
-      out += ' , message: \'should be ' + ($opStr) + ' ';
-      if ($isData) {
-        out += '\' + ' + ($schemaValue);
-      } else {
-        out += '' + ($schema) + '\'';
-      }
-    }
-    if (it.opts.verbose) {
-      out += ' , schema:  ';
-      if ($isData) {
-        out += 'validate.schema' + ($schemaPath);
-      } else {
-        out += '' + ($schema);
-      }
-      out += '         , parentSchema: validate.schema' + (it.schemaPath) + ' , data: ' + ($data) + ' ';
-    }
-    out += ' } ';
-  } else {
-    out += ' {} ';
-  }
-  var __err = out;
-  out = $$outStack.pop();
-  if (!it.compositeRule && $breakOnError) { /* istanbul ignore if */
-    if (it.async) {
-      out += ' throw new ValidationError([' + (__err) + ']); ';
-    } else {
-      out += ' validate.errors = [' + (__err) + ']; return false; ';
-    }
-  } else {
-    out += ' var err = ' + (__err) + ';  if (vErrors === null) vErrors = [err]; else vErrors.push(err); errors++; ';
-  }
-  out += ' } ';
-  if ($breakOnError) {
-    out += ' else { ';
-  }
-  return out;
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dotjs/_limitItems.js
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dotjs/_limitItems.js b/node_modules/ajv/lib/dotjs/_limitItems.js
deleted file mode 100644
index 6a84362..0000000
--- a/node_modules/ajv/lib/dotjs/_limitItems.js
+++ /dev/null
@@ -1,76 +0,0 @@
-'use strict';
-module.exports = function generate__limitItems(it, $keyword) {
-  var out = ' ';
-  var $lvl = it.level;
-  var $dataLvl = it.dataLevel;
-  var $schema = it.schema[$keyword];
-  var $schemaPath = it.schemaPath + it.util.getProperty($keyword);
-  var $errSchemaPath = it.errSchemaPath + '/' + $keyword;
-  var $breakOnError = !it.opts.allErrors;
-  var $errorKeyword;
-  var $data = 'data' + ($dataLvl || '');
-  var $isData = it.opts.v5 && $schema && $schema.$data,
-    $schemaValue;
-  if ($isData) {
-    out += ' var schema' + ($lvl) + ' = ' + (it.util.getData($schema.$data, $dataLvl, it.dataPathArr)) + '; ';
-    $schemaValue = 'schema' + $lvl;
-  } else {
-    $schemaValue = $schema;
-  }
-  var $op = $keyword == 'maxItems' ? '>' : '<';
-  out += 'if ( ';
-  if ($isData) {
-    out += ' (' + ($schemaValue) + ' !== undefined && typeof ' + ($schemaValue) + ' != \'number\') || ';
-  }
-  out += ' ' + ($data) + '.length ' + ($op) + ' ' + ($schemaValue) + ') { ';
-  var $errorKeyword = $keyword;
-  var $$outStack = $$outStack || [];
-  $$outStack.push(out);
-  out = ''; /* istanbul ignore else */
-  if (it.createErrors !== false) {
-    out += ' { keyword: \'' + ($errorKeyword || '_limitItems') + '\' , dataPath: (dataPath || \'\') + ' + (it.errorPath) + ' , schemaPath: ' + (it.util.toQuotedString($errSchemaPath)) + ' , params: { limit: ' + ($schemaValue) + ' } ';
-    if (it.opts.messages !== false) {
-      out += ' , message: \'should NOT have ';
-      if ($keyword == 'maxItems') {
-        out += 'more';
-      } else {
-        out += 'less';
-      }
-      out += ' than ';
-      if ($isData) {
-        out += '\' + ' + ($schemaValue) + ' + \'';
-      } else {
-        out += '' + ($schema);
-      }
-      out += ' items\' ';
-    }
-    if (it.opts.verbose) {
-      out += ' , schema:  ';
-      if ($isData) {
-        out += 'validate.schema' + ($schemaPath);
-      } else {
-        out += '' + ($schema);
-      }
-      out += '         , parentSchema: validate.schema' + (it.schemaPath) + ' , data: ' + ($data) + ' ';
-    }
-    out += ' } ';
-  } else {
-    out += ' {} ';
-  }
-  var __err = out;
-  out = $$outStack.pop();
-  if (!it.compositeRule && $breakOnError) { /* istanbul ignore if */
-    if (it.async) {
-      out += ' throw new ValidationError([' + (__err) + ']); ';
-    } else {
-      out += ' validate.errors = [' + (__err) + ']; return false; ';
-    }
-  } else {
-    out += ' var err = ' + (__err) + ';  if (vErrors === null) vErrors = [err]; else vErrors.push(err); errors++; ';
-  }
-  out += '} ';
-  if ($breakOnError) {
-    out += ' else { ';
-  }
-  return out;
-}

http://git-wip-us.apache.org/repos/asf/incubator-griffin-site/blob/ca1c37a7/node_modules/ajv/lib/dotjs/_limitLength.js
----------------------------------------------------------------------
diff --git a/node_modules/ajv/lib/dotjs/_limitLength.js b/node_modules/ajv/lib/dotjs/_limitLength.js
deleted file mode 100644
index e378104..0000000
--- a/node_modules/ajv/lib/dotjs/_limitLength.js
+++ /dev/null
@@ -1,81 +0,0 @@
-'use strict';
-module.exports = function generate__limitLength(it, $keyword) {
-  var out = ' ';
-  var $lvl = it.level;
-  var $dataLvl = it.dataLevel;
-  var $schema = it.schema[$keyword];
-  var $schemaPath = it.schemaPath + it.util.getProperty($keyword);
-  var $errSchemaPath = it.errSchemaPath + '/' + $keyword;
-  var $breakOnError = !it.opts.allErrors;
-  var $errorKeyword;
-  var $data = 'data' + ($dataLvl || '');
-  var $isData = it.opts.v5 && $schema && $schema.$data,
-    $schemaValue;
-  if ($isData) {
-    out += ' var schema' + ($lvl) + ' = ' + (it.util.getData($schema.$data, $dataLvl, it.dataPathArr)) + '; ';
-    $schemaValue = 'schema' + $lvl;
-  } else {
-    $schemaValue = $schema;
-  }
-  var $op = $keyword == 'maxLength' ? '>' : '<';
-  out += 'if ( ';
-  if ($isData) {
-    out += ' (' + ($schemaValue) + ' !== undefined && typeof ' + ($schemaValue) + ' != \'number\') || ';
-  }
-  if (it.opts.unicode === false) {
-    out += ' ' + ($data) + '.length ';
-  } else {
-    out += ' ucs2length(' + ($data) + ') ';
-  }
-  out += ' ' + ($op) + ' ' + ($schemaValue) + ') { ';
-  var $errorKeyword = $keyword;
-  var $$outStack = $$outStack || [];
-  $$outStack.push(out);
-  out = ''; /* istanbul ignore else */
-  if (it.createErrors !== false) {
-    out += ' { keyword: \'' + ($errorKeyword || '_limitLength') + '\' , dataPath: (dataPath || \'\') + ' + (it.errorPath) + ' , schemaPath: ' + (it.util.toQuotedString($errSchemaPath)) + ' , params: { limit: ' + ($schemaValue) + ' } ';
-    if (it.opts.messages !== false) {
-      out += ' , message: \'should NOT be ';
-      if ($keyword == 'maxLength') {
-        out += 'longer';
-      } else {
-        out += 'shorter';
-      }
-      out += ' than ';
-      if ($isData) {
-        out += '\' + ' + ($schemaValue) + ' + \'';
-      } else {
-        out += '' + ($schema);
-      }
-      out += ' characters\' ';
-    }
-    if (it.opts.verbose) {
-      out += ' , schema:  ';
-      if ($isData) {
-        out += 'validate.schema' + ($schemaPath);
-      } else {
-        out += '' + ($schema);
-      }
-      out += '         , parentSchema: validate.schema' + (it.schemaPath) + ' , data: ' + ($data) + ' ';
-    }
-    out += ' } ';
-  } else {
-    out += ' {} ';
-  }
-  var __err = out;
-  out = $$outStack.pop();
-  if (!it.compositeRule && $breakOnError) { /* istanbul ignore if */
-    if (it.async) {
-      out += ' throw new ValidationError([' + (__err) + ']); ';
-    } else {
-      out += ' validate.errors = [' + (__err) + ']; return false; ';
-    }
-  } else {
-    out += ' var err = ' + (__err) + ';  if (vErrors === null) vErrors = [err]; else vErrors.push(err); errors++; ';
-  }
-  out += '} ';
-  if ($breakOnError) {
-    out += ' else { ';
-  }
-  return out;
-}