You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@nlpcraft.apache.org by se...@apache.org on 2022/12/23 10:21:15 UTC

[incubator-nlpcraft] branch NLPCRAFT-521 created (now bd58872b)

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

sergeykamov pushed a change to branch NLPCRAFT-521
in repository https://gitbox.apache.org/repos/asf/incubator-nlpcraft.git


      at bd58872b WIP.

This branch includes the following new commits:

     new 2c1ac981 WIP.
     new ef692242 WIP.
     new bd58872b WIP.

The 3 revisions listed above as "new" are entirely new to this
repository and will be described in separate emails.  The revisions
listed as "add" were already present in the repository and have only
been added to this reference.



[incubator-nlpcraft] 01/03: WIP.

Posted by se...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sergeykamov pushed a commit to branch NLPCRAFT-521
in repository https://gitbox.apache.org/repos/asf/incubator-nlpcraft.git

commit 2c1ac98112e268b9adc461708736dcdab3f8f60f
Author: Sergey Kamov <sk...@gmail.com>
AuthorDate: Fri Dec 23 12:43:07 2022 +0400

    WIP.
---
 .../examples/lightswitch/LightSwitchFrModel.scala  |  2 +-
 .../examples/lightswitch/LightSwitchRuModel.scala  |  2 +-
 .../examples/lightswitch/LightSwitchModel.scala    |  2 +-
 .../pizzeria/components/PizzeriaOrderMapper.scala  | 10 +++---
 .../components/PizzeriaOrderValidator.scala        |  2 +-
 .../stanford/NCStanfordNLPEntityParser.scala       |  2 +-
 .../main/scala/org/apache/nlpcraft/NCEntity.scala  |  8 ++---
 .../internal/conversation/NCConversationData.scala |  2 +-
 .../internal/impl/NCModelPipelineManager.scala     |  2 +-
 .../intent/compiler/NCIDLCodeGenerator.scala       | 10 +++---
 .../internal/intent/compiler/NCIDLCompiler.scala   |  2 +-
 .../internal/intent/compiler/antlr4/NCIDL.g4       |  2 +-
 .../intent/matcher/NCIntentSolverManager.scala     |  4 +--
 .../nlpcraft/nlp/parsers/NCNLPEntityParser.scala   |  2 +-
 .../nlp/parsers/NCOpenNLPEntityParser.scala        |  2 +-
 .../nlpcraft/nlp/parsers/NCSemanticElement.scala   | 18 +++++------
 .../nlp/parsers/NCSemanticEntityParser.scala       | 16 +++++-----
 .../nlp/parsers/impl/NCSemanticSourceReader.scala  |  2 +-
 .../parsers/impl/NCSemanticSynonymsProcessor.scala |  6 ++--
 .../conversation/NCConversationManagerSpec.scala   |  4 +--
 .../nlpcraft/internal/impl/NCModelClientSpec.scala |  2 +-
 .../intent/compiler/functions/NCIDLFunctions.scala | 10 +++---
 .../functions/NCIDLFunctionsEntitiesUsed.scala     |  4 +--
 .../compiler/functions/NCIDLFunctionsEntity.scala  | 36 +++++++++++-----------
 .../nlpcraft/internal/intent/compiler/test_ok.idl  |  2 +-
 .../apache/nlpcraft/nlp/NCEntityMapperSpec.scala   |  4 +--
 .../apache/nlpcraft/nlp/NCEntityParserSpec.scala   |  2 +-
 .../parsers/NCSemanticEntityParserJsonSpec.scala   |  2 +-
 .../parsers/NCSemanticEntityParserLemmaSpec.scala  |  2 +-
 .../nlp/parsers/NCSemanticEntityParserSpec.scala   | 18 +++++------
 .../parsers/NCSemanticEntityParserYamlSpec.scala   |  2 +-
 .../nlp/parsers/NCSemanticTestElement.scala        |  2 +-
 .../apache/nlpcraft/nlp/util/NCTestEntity.scala    | 12 ++++----
 .../org/apache/nlpcraft/nlp/util/NCTestUtils.scala |  4 +--
 34 files changed, 101 insertions(+), 101 deletions(-)

diff --git a/nlpcraft-examples/lightswitch-fr/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchFrModel.scala b/nlpcraft-examples/lightswitch-fr/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchFrModel.scala
index d93cc571..a434295d 100644
--- a/nlpcraft-examples/lightswitch-fr/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchFrModel.scala
+++ b/nlpcraft-examples/lightswitch-fr/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchFrModel.scala
@@ -60,7 +60,7 @@ class LightSwitchFrModel extends NCModel(
         @NCIntentTerm("act") actEnt: NCEntity,
         @NCIntentTerm("loc") locEnts: List[NCEntity]
     ): NCResult =
-        val action = if actEnt.getId == "ls:on" then "allumer" else "éteindre"
+        val action = if actEnt.getType == "ls:on" then "allumer" else "éteindre"
         val locations = if locEnts.isEmpty then "toute la maison" else locEnts.map(_.mkText).mkString(", ")
 
         // Add HomeKit, Arduino or other integration here.
diff --git a/nlpcraft-examples/lightswitch-ru/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchRuModel.scala b/nlpcraft-examples/lightswitch-ru/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchRuModel.scala
index c7169f47..17c7215f 100644
--- a/nlpcraft-examples/lightswitch-ru/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchRuModel.scala
+++ b/nlpcraft-examples/lightswitch-ru/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchRuModel.scala
@@ -54,7 +54,7 @@ class LightSwitchRuModel extends NCModel(
         @NCIntentTerm("act") actEnt: NCEntity,
         @NCIntentTerm("loc") locEnts: List[NCEntity]
     ): NCResult =
-        val action = if actEnt.getId == "ls:on" then "включить" else "выключить"
+        val action = if actEnt.getType == "ls:on" then "включить" else "выключить"
         val locations = if locEnts.isEmpty then "весь дом" else locEnts.map(_.mkText).mkString(", ")
 
         // Add HomeKit, Arduino or other integration here.
diff --git a/nlpcraft-examples/lightswitch/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchModel.scala b/nlpcraft-examples/lightswitch/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchModel.scala
index 9f73bb3a..2085bfd4 100644
--- a/nlpcraft-examples/lightswitch/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchModel.scala
+++ b/nlpcraft-examples/lightswitch/src/main/scala/org/apache/nlpcraft/examples/lightswitch/LightSwitchModel.scala
@@ -54,7 +54,7 @@ class LightSwitchModel extends NCModel(
         @NCIntentTerm("act") actEnt: NCEntity,
         @NCIntentTerm("loc") locEnts: List[NCEntity]
     ): NCResult =
-        val status = if actEnt.getId == "ls:on" then "on" else "off"
+        val status = if actEnt.getType == "ls:on" then "on" else "off"
         val locations = if locEnts.isEmpty then "entire house" else locEnts.map(_.mkText).mkString(", ")
 
         // Add HomeKit, Arduino or other integration here.=
diff --git a/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderMapper.scala b/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderMapper.scala
index 673b62b8..22526bd8 100644
--- a/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderMapper.scala
+++ b/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderMapper.scala
@@ -49,7 +49,7 @@ object PizzeriaOrderMapper:
         def tokens: List[NCToken] = entity.getTokens
 
     private def str(es: Iterable[NCEntity]): String =
-        es.map(e => s"id=${e.getId}(${e.tokens.map(_.getIndex).mkString("[", ",", "]")})").mkString("{", ", ", "}")
+        es.map(e => s"id=${e.getType}(${e.tokens.map(_.getIndex).mkString("[", ",", "]")})").mkString("{", ", ", "}")
 
     def apply(extra: PizzeriaOrderMapperDesc, dests: PizzeriaOrderMapperDesc*): PizzeriaOrderMapper = new PizzeriaOrderMapper(extra, dests)
 
@@ -63,11 +63,11 @@ case class PizzeriaOrderMapper(extra: PizzeriaOrderMapperDesc, dests: Seq[Pizzer
                 put[String](destProp, extraEnt[String](extra.propertyName).toLowerCase)
                 override val getTokens: List[NCToken] = (destEnt.tokens ++ extraEnt.tokens).sortBy(_.getIndex)
                 override val getRequestId: String = req.getRequestId
-                override val getId: String = destEnt.getId
+                override val getType: String = destEnt.getType
 
         val destsMap = dests.map(p => p.elementId -> p).toMap
-        val destEnts = mutable.HashSet.empty ++ ents.filter(e => destsMap.contains(e.getId))
-        val extraEnts = ents.filter(_.getId == extra.elementId)
+        val destEnts = mutable.HashSet.empty ++ ents.filter(e => destsMap.contains(e.getType))
+        val extraEnts = ents.filter(_.getType == extra.elementId)
 
         if destEnts.nonEmpty && extraEnts.nonEmpty && destEnts.size >= extraEnts.size then
             val used = (destEnts ++ extraEnts).toSet
@@ -79,7 +79,7 @@ case class PizzeriaOrderMapper(extra: PizzeriaOrderMapperDesc, dests: Seq[Pizzer
                 dest2Extra += destEnt -> extraEnt
 
             val unrelated = ents.filter(e => !used.contains(e))
-            val artificial = for ((m, e) <- dest2Extra) yield map(m, destsMap(m.getId).propertyName, e)
+            val artificial = for ((m, e) <- dest2Extra) yield map(m, destsMap(m.getType).propertyName, e)
             val unused = destEnts
 
             val res = (unrelated ++ artificial ++ unused).sortBy(_.tokens.head.getIndex)
diff --git a/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderValidator.scala b/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderValidator.scala
index b0d2f8b3..64792b5c 100644
--- a/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderValidator.scala
+++ b/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderValidator.scala
@@ -24,7 +24,7 @@ import org.apache.nlpcraft.*
   */
 class PizzeriaOrderValidator extends NCEntityValidator:
     override def validate(req: NCRequest, cfg: NCModelConfig, ents: List[NCEntity]): Unit =
-        def count(id: String): Int = ents.count(_.getId == id)
+        def count(id: String): Int = ents.count(_.getType == id)
 
         val cntPizza = count("ord:pizza")
         val cntDrink = count("ord:drink")
diff --git a/nlpcraft-stanford/src/main/scala/org/apache/nlpcraft/nlp/entity/parser/stanford/NCStanfordNLPEntityParser.scala b/nlpcraft-stanford/src/main/scala/org/apache/nlpcraft/nlp/entity/parser/stanford/NCStanfordNLPEntityParser.scala
index 1677c6dd..bc178685 100644
--- a/nlpcraft-stanford/src/main/scala/org/apache/nlpcraft/nlp/entity/parser/stanford/NCStanfordNLPEntityParser.scala
+++ b/nlpcraft-stanford/src/main/scala/org/apache/nlpcraft/nlp/entity/parser/stanford/NCStanfordNLPEntityParser.scala
@@ -70,6 +70,6 @@ class NCStanfordNLPEntityParser(stanford: StanfordCoreNLP, supported: Set[String
 
                                 override val getTokens: List[NCToken] = entToks
                                 override val getRequestId: String = req.getRequestId
-                                override val getId: String = s"stanford:$typ"
+                                override val getType: String = s"stanford:$typ"
 
         res.toList
\ No newline at end of file
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/NCEntity.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/NCEntity.scala
index 96c77bd1..885d0fe3 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/NCEntity.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/NCEntity.scala
@@ -69,11 +69,11 @@ trait NCEntity extends NCPropertyMap:
       *
       * @return Optional set of groups this entity belongs to. Returned set can be empty but never `null`.
       */
-    def getGroups: Set[String] = Set(getId)
+    def getGroups: Set[String] = Set(getType)
 
     /**
-      * Gets globally unique ID of this entity.
+      * Gets entity type.
       *
-      * @return Globally unique ID of this entity.
+      * @return Entity type.
       */
-    def getId: String
+    def getType: String
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/conversation/NCConversationData.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/conversation/NCConversationData.scala
index e6a8ed06..c1606b3a 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/conversation/NCConversationData.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/conversation/NCConversationData.scala
@@ -189,7 +189,7 @@ case class NCConversationData(
         else
             val tbl = NCAsciiTable("Entity ID", "Groups", "Request ID")
             ctx.foreach(ent => tbl += (
-                ent.getId,
+                ent.getType,
                 ent.getGroups.mkString(", "),
                 ent.getRequestId
             ))
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/impl/NCModelPipelineManager.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/impl/NCModelPipelineManager.scala
index c2f56c74..11367a23 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/impl/NCModelPipelineManager.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/impl/NCModelPipelineManager.scala
@@ -176,7 +176,7 @@ class NCModelPipelineManager(cfg: NCModelConfig, pipeline: NCPipeline) extends L
             for e <- v.getEntities do
                 val toks = e.getTokens
                 tbl += (
-                    e.getId,
+                    e.getType,
                     toks.map(_.getText).mkString("|"),
                     toks.map(p => s"${p.getStartCharIndex}-${p.getEndCharIndex}").mkString("|"),
                     mkProps(e)
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCodeGenerator.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCodeGenerator.scala
index eab9d4b7..dae8f866 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCodeGenerator.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCodeGenerator.scala
@@ -900,22 +900,22 @@ trait NCIDLCodeGenerator:
                 case "mdl_origin" => z0(() => Z(idlCtx.mdlCfg.getOrigin.orNull, 0))
 
                 // Entity functions.
-                case "ent_id" => arg1Tok() match { case x => stack.push(() => Z(toEntity(x().value).impl.getId, 1)) }
+                case "ent_type" => arg1Tok() match { case x => stack.push(() => Z(toEntity(x().value).impl.getType, 1)) }
                 case "ent_index" => arg1Tok() match { case x => stack.push(() => Z(toEntity(x().value).index, 1)) }
                 case "ent_text" => arg1Tok() match { case x => stack.push(() => Z(toEntity(x().value).text, 1)) }
                 case "ent_count" => checkAvail(); z0(() => Z(idlCtx.entities.size, 0))
                 case "ent_groups" => arg1Tok() match { case x => stack.push(() => Z(JList.copyOf(toEntity(x().value).impl.getGroups.asJava), 1)) }
                 case "ent_all" => checkAvail(); z0(() => Z(idlCtx.entities.asJava, 0))
-                case "ent_all_for_id" => checkAvail(); doForAll((e, id) => e.impl.getId == id)
+                case "ent_all_for_id" => checkAvail(); doForAll((e, id) => e.impl.getType == id)
                 case "ent_all_for_group" => checkAvail(); doForAll((e, grp) => e.impl.getGroups.contains(grp))
                 case "ent_this" => z0(() => Z(ent, 1))
                 case "ent_is_last" => checkAvail(); arg1Tok() match { case x => stack.push(() => { Z(toEntity(x().value).index == idlCtx.entities.size - 1, 1) }) }
                 case "ent_is_first" => checkAvail(); arg1Tok() match { case x => stack.push(() => { Z(toEntity(x().value).index == 0, 1) }) }
-                case "ent_is_before_id" => checkAvail(); doIsBefore((e, id) => e.impl.getId == id)
+                case "ent_is_before_id" => checkAvail(); doIsBefore((e, id) => e.impl.getType == id)
                 case "ent_is_before_group" => checkAvail(); doIsBefore((e, grpId) => e.impl.getGroups.contains(grpId))
-                case "ent_is_after_id" => checkAvail(); doIsAfter((e, id) => e.impl.getId == id)
+                case "ent_is_after_id" => checkAvail(); doIsAfter((e, id) => e.impl.getType == id)
                 case "ent_is_after_group" => checkAvail(); doIsAfter((e, grpId) => e.impl.getGroups.contains(grpId))
-                case "ent_is_between_ids" => checkAvail(); doIsBetween((e, id) => e.impl.getId == id)
+                case "ent_is_between_ids" => checkAvail(); doIsBetween((e, id) => e.impl.getType == id)
                 case "ent_is_between_groups" => checkAvail(); doIsBetween((e, grpId) => e.impl.getGroups.contains(grpId))
 
                 // Request data.
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCompiler.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCompiler.scala
index dded76da..ccedb618 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCompiler.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCompiler.scala
@@ -121,7 +121,7 @@ class NCIDLCompiler(cfg: NCModelConfig) extends LazyLogging with mutable.Cloneab
         override def exitCallExpr(ctx: IDP.CallExprContext): Unit =
             val fun =
                 if ctx.FUN_NAME() != null then ctx.FUN_NAME().getText
-                else "ent_id"
+                else "ent_type"
 
             expr += parseCallExpr(fun)(ctx)
 
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4 b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4
index 0b754e15..6f614d76 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4
@@ -143,7 +143,7 @@ FUN_NAME
     | 'meta_frag'
     | 'json'
     | 'if'
-    | 'ent_id'
+    | 'ent_type'
     | 'ent_index'
     | 'ent_text'
     | 'ent_groups'
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/matcher/NCIntentSolverManager.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/matcher/NCIntentSolverManager.scala
index ed432620..243dfe23 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/matcher/NCIntentSolverManager.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/matcher/NCIntentSolverManager.scala
@@ -313,7 +313,7 @@ class NCIntentSolverManager(
                                 val variantPart =
                                     m.variant.
                                         entities.
-                                        map(t => s"${t.getId}${t.getGroups}${t.mkText}").
+                                        map(t => s"${t.getType}${t.getGroups}${t.mkText}").
                                         mkString("")
 
                                 val intentPart = m.intentMatch.intent.toString
@@ -362,7 +362,7 @@ class NCIntentSolverManager(
                         var entIdx = 0
                         for (e <- grp.usedEntities)
                             val conv = if e.conv then "(conv) " else ""
-                            ents += s"    #$entIdx: $conv${e.entity.getId}(${e.entity.mkText})"
+                            ents += s"    #$entIdx: $conv${e.entity.getType}(${e.entity.mkText})"
                             entIdx += 1
                     else
                         ents += "    <empty>"
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCNLPEntityParser.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCNLPEntityParser.scala
index b184f779..cf1b3225 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCNLPEntityParser.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCNLPEntityParser.scala
@@ -63,5 +63,5 @@ class NCNLPEntityParser(predicate: NCToken => Boolean = _ => true) extends NCEnt
 
                 override val getTokens: List[NCToken] = List(t)
                 override val getRequestId: String = req.getRequestId
-                override val getId: String = id
+                override val getType: String = id
         )
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCOpenNLPEntityParser.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCOpenNLPEntityParser.scala
index 8cb7d661..8314c6c8 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCOpenNLPEntityParser.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCOpenNLPEntityParser.scala
@@ -105,6 +105,6 @@ class NCOpenNLPEntityParser(findersMdlsRes: List[String]) extends NCEntityParser
 
                     override val getTokens: List[NCToken] = toks.flatMap(t => Option.when(t.getIndex >= i1 && t.getIndex <= i2)(t))
                     override val getRequestId: String = req.getRequestId
-                    override val getId: String = s"opennlp:${h.name}"
+                    override val getType: String = s"opennlp:${h.name}"
             )
         }).toList
\ No newline at end of file
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticElement.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticElement.scala
index 8aa95473..20780bc7 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticElement.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticElement.scala
@@ -18,7 +18,7 @@
 package org.apache.nlpcraft.nlp.parsers
 
 import org.apache.nlpcraft.nlp.stemmer.NCStemmer
-
+import org.apache.nlpcraft.*
 /**
   *
   * Configuration element which helps to detect [[org.apache.nlpcraft.NCEntity NCEntity]] for
@@ -30,18 +30,18 @@ import org.apache.nlpcraft.nlp.stemmer.NCStemmer
   */
 trait NCSemanticElement:
     /**
-      * Gets **id** for created [[org.apache.nlpcraft.NCEntity NCEntity]] instance.
-      * Representation of [[org.apache.nlpcraft.NCEntity.getId NCEntity.getId()]] method.
-      * @return Element ID.
+      * Gets **type** for created [[NCEntity]] instance.
+      * Representation of [[NCEntity.getType]] method.
+      * @return Element type.
       */
-    def getId: String
+    def getType: String
 
     /**
-      * Gets **groups** for created [[org.apache.nlpcraft.NCEntity NCEntity]] instance.
-      * Representation of [[org.apache.nlpcraft.NCEntity.getGroups NCEntity.getGroups()]] method.
+      * Gets **groups** for created [[NCEntity]] instance.
+      * Representation of [[NCEntity.getGroups]] method.
       * @return Groups.
       */
-    def getGroups: Set[String] = Set(getId)
+    def getGroups: Set[String] = Set(getType)
 
     /**
       * Gets values map. Each element can contain multiple value,
@@ -58,7 +58,7 @@ trait NCSemanticElement:
     def getSynonyms: Set[String] = Set.empty
 
     /**
-      * Gets [[org.apache.nlpcraft.NCPropertyMap metadata]] property for created [[org.apache.nlpcraft.NCEntity NCEntity]] instance.
+      * Gets [[NCPropertyMap metadata]] property for created [[NCEntity]] instance.
       * @return Groups.
       */
     def getProperties: Map[String, AnyRef] = Map.empty
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParser.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParser.scala
index 8004d3e9..e0b2f816 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParser.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParser.scala
@@ -199,7 +199,7 @@ class NCSemanticEntityParser private (
       */
     private def init(): Unit =
         val (macros, elements, elemsMap) =
-            def toMap(elems: Seq[NCSemanticElement]): Map[String, NCSemanticElement] = elems.map(p => p.getId -> p).toMap
+            def toMap(elems: Seq[NCSemanticElement]): Map[String, NCSemanticElement] = elems.map(p => p.getType -> p).toMap
 
             mdlResOpt match
                 case Some(mdlSrc) =>
@@ -238,7 +238,7 @@ class NCSemanticEntityParser private (
 
         val cache = mutable.HashSet.empty[Seq[Int]] // Variants (tokens without stopwords) can be repeated.
 
-        case class Holder(elemId: String, tokens: List[NCToken], value: Option[String]):
+        case class Holder(elemType: String, tokens: List[NCToken], value: Option[String]):
             val tokensSet: Set[NCToken] = tokens.toSet
             val idxs: Set[Int] = tokensSet.map(_.getIndex)
 
@@ -284,10 +284,10 @@ class NCSemanticEntityParser private (
 
         // Deletes redundant.
         hs = hs.distinct
-        
+
         val del = mutable.ArrayBuffer.empty[Holder]
         // 1. Look at each element with its value.
-        for (((_, _), seq) <- hs.groupBy(h => (h.elemId, h.value)) if seq.size > 1)
+        for (((_, _), seq) <- hs.groupBy(h => (h.elemType, h.value)) if seq.size > 1)
             // 2. If some variants are duplicated - keep only one, with most tokens counts.
             val seqIdxs = seq.zipWithIndex
 
@@ -297,15 +297,15 @@ class NCSemanticEntityParser private (
         hs --= del
 
         hs.toSeq.map(h => {
-            val e = elemsMap(h.elemId)
+            val e = elemsMap(h.elemType)
             new NCPropertyMapAdapter with NCEntity:
-                if e.getProperties != null then e.getProperties.foreach { (k, v) => put(s"${h.elemId}:$k", v) }
+                if e.getProperties != null then e.getProperties.foreach { (k, v) => put(s"${h.elemType}:$k", v) }
                 h.value match
-                    case Some(value) => put(s"${h.elemId}:value", value)
+                    case Some(value) => put(s"${h.elemType}:value", value)
                     case None => // No-op.
 
                 override val getTokens: List[NCToken] = h.tokens
                 override val getRequestId: String = req.getRequestId
-                override val getId: String = h.elemId
+                override val getType: String = h.elemType
                 override val getGroups: Set[String] = e.getGroups
         }).toList
\ No newline at end of file
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSourceReader.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSourceReader.scala
index c9a2cfd5..6e8fc635 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSourceReader.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSourceReader.scala
@@ -71,7 +71,7 @@ private[parsers] object NCSemanticSourceReader:
         if e == null then null
         else
             new NCPropertyMapAdapter with NCSemanticElement:
-                override val getId: String = e.id
+                override val getType: String = e.id
                 override val getGroups: Set[String] =
                     val gs = e.groups
 
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSynonymsProcessor.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSynonymsProcessor.scala
index f6d6e551..0102a158 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSynonymsProcessor.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSynonymsProcessor.scala
@@ -117,12 +117,12 @@ private[parsers] object NCSemanticSynonymsProcessor extends LazyLogging:
         // Duplicates.
         val ids = mutable.HashSet.empty[String]
 
-        for (id <- elems.map(_.getId))
+        for (id <- elems.map(_.getType))
             if ids.contains(id) then E(s"Duplicate element ID [element=$id]")
             else ids += id
 
         for (e <- elems)
-            val elemId = e.getId
+            val elemId = e.getType
 
             if elemId == null || elemId.isEmpty then E(s"Some element IDs are not provided or empty.")
             else if !elemId.matches(ID_REGEX) then E(s"Element ID does not match regex [element=$elemId, regex=$ID_REGEX]")
@@ -227,7 +227,7 @@ private[parsers] object NCSemanticSynonymsProcessor extends LazyLogging:
         val buf = mutable.ArrayBuffer.empty[Holder]
 
         for (e <- elements)
-            val elemId = e.getId
+            val elemId = e.getType
 
             def add(syns: Seq[NCSemanticSynonym]): Unit = buf ++= syns.map(Holder(_, elemId))
             def addSpec(txt: String, value: String = null): Unit =
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/conversation/NCConversationManagerSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/conversation/NCConversationManagerSpec.scala
index 7af99aa6..d7af5abd 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/conversation/NCConversationManagerSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/conversation/NCConversationManagerSpec.scala
@@ -59,9 +59,9 @@ class NCConversationManagerSpec extends AnyFunSuite:
         checkSize(2)
 
         // Partially cleared.
-        conv.clear(_.getId == "e1")
+        conv.clear(_.getType == "e1")
         checkSize(1)
-        require(conv.getEntities.head.getId == "e2")
+        require(conv.getEntities.head.getType == "e2")
     }
 
     test("test timeout") {
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/impl/NCModelClientSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/impl/NCModelClientSpec.scala
index ddbb5ebf..89760017 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/impl/NCModelClientSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/impl/NCModelClientSpec.scala
@@ -34,7 +34,7 @@ class NCModelClientSpec extends AnyFunSuite:
       * @param e
       */
     private def s(e: NCEntity): String =
-        s"Entity [id=${e.getId}, text=${e.mkText}, properties={${e.keysSet.map(k => s"$k=${e(k)}")}}]"
+        s"Entity [id=${e.getType}, text=${e.mkText}, properties={${e.keysSet.map(k => s"$k=${e(k)}")}}]"
 
     /**
       *
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctions.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctions.scala
index f6c84d55..b2ea96eb 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctions.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctions.scala
@@ -98,7 +98,7 @@ private[functions] object NCIDLFunctions:
       *
       * @param e
       */
-    private def e2s(e: NCEntity): String = s"${e.getId} (${e.getTokens.map(_.getText).mkString(" ")})"
+    private def e2s(e: NCEntity): String = s"${e.getType} (${e.getTokens.map(_.getText).mkString(" ")})"
 
     /**
       *
@@ -136,7 +136,7 @@ private[functions] object NCIDLFunctions:
 
     /**
       *
-      * @param id
+      * @param typ
       * @param reqId
       * @param value
       * @param groups
@@ -144,16 +144,16 @@ private[functions] object NCIDLFunctions:
       * @param tokens
       */
     def mkEntity(
-        id: String = UUID.randomUUID().toString,
+        typ: String = UUID.randomUUID().toString,
         reqId: String = UUID.randomUUID().toString,
-        value: String = null, 
+        value: String = null,
         groups: Set[String] = null,
         meta: Map[String, AnyRef] = Map.empty[String, AnyRef],
         tokens: Seq[NCTestToken]
     ): NCEntity =
         require(tokens.nonEmpty)
 
-        NCTestEntity(id, reqId, groups, meta, tokens)
+        NCTestEntity(typ, reqId, groups, meta, tokens)
 
 import org.apache.nlpcraft.internal.intent.compiler.functions.NCIDLFunctions.*
 
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntitiesUsed.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntitiesUsed.scala
index 63b3f19b..2506d1f9 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntitiesUsed.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntitiesUsed.scala
@@ -28,8 +28,8 @@ import org.apache.nlpcraft.*
   */
 class NCIDLFunctionsEntitiesUsed extends NCIDLFunctions:
     test("test") {
-        val e1 = mkEntity(id = "a", tokens = NCTestToken())
-        val e2 = mkEntity(id = "b", tokens = NCTestToken())
+        val e1 = mkEntity(typ = "a", tokens = NCTestToken())
+        val e2 = mkEntity(typ = "b", tokens = NCTestToken())
 
         test(
             TestDesc(
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntity.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntity.scala
index b55b6af5..2c2a8766 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntity.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntity.scala
@@ -38,24 +38,24 @@ class NCIDLFunctionsEntity extends NCIDLFunctions:
         test(
             TestDesc(
                 truth = "# == 'a'",
-                entity = mkEntity(id = "a", tokens = t1t2)
+                entity = mkEntity(typ = "a", tokens = t1t2)
             ),
             TestDesc(
-                truth = "ent_id == 'a'",
-                entity = mkEntity(id = "a", tokens = t1t2)
+                truth = "ent_type == 'a'",
+                entity = mkEntity(typ = "a", tokens = t1t2)
             ),
             TestDesc(
                 truth = "ent_index == 100",
-                entity = mkEntity(id = "a", tokens = NCTestToken(txt = "w2", idx = 100))
+                entity = mkEntity(typ = "a", tokens = NCTestToken(txt = "w2", idx = 100))
             ),
             TestDesc(
                 truth = "ent_text == 'W1 w2'",
-                entity = mkEntity(id = "a", tokens = t1t2)
+                entity = mkEntity(typ = "a", tokens = t1t2)
             ),
 
             TestDesc(
                 truth = "ent_count == 1",
-                entity = mkEntity(id = "a", tokens = t1t2)
+                entity = mkEntity(typ = "a", tokens = t1t2)
             ),
             TestDesc(
                 truth = "ent_this() == ent_this()",
@@ -63,18 +63,18 @@ class NCIDLFunctionsEntity extends NCIDLFunctions:
             ),
             TestDesc(
                 truth = "ent_groups() == list('g1', 'g2')",
-                entity = mkEntity(id = "a", groups = Set("g1", "g2"), tokens = t1t2)
+                entity = mkEntity(typ = "a", groups = Set("g1", "g2"), tokens = t1t2)
             ),
             TestDesc(
                 truth = "ent_groups() == list('a')",
-                entity = mkEntity(id = "a", tokens = t1t2)
+                entity = mkEntity(typ = "a", tokens = t1t2)
             )
         )
     }
 
     test("test tokens first and last") {
-        val e1 = mkEntity(id = "a", tokens = NCTestToken(idx = 0))
-        val e2 = mkEntity(id = "b", tokens = NCTestToken(idx = 1))
+        val e1 = mkEntity(typ = "a", tokens = NCTestToken(idx = 0))
+        val e2 = mkEntity(typ = "b", tokens = NCTestToken(idx = 1))
 
         val ctx = mkIdlContext(entities = Seq(e1, e2))
 
@@ -93,8 +93,8 @@ class NCIDLFunctionsEntity extends NCIDLFunctions:
     }
 
     test("test before and after") {
-        val e1 = mkEntity(id = "1", tokens = NCTestToken(idx = 0))
-        val e2 = mkEntity(id = "2", tokens = NCTestToken(idx = 1))
+        val e1 = mkEntity(typ = "1", tokens = NCTestToken(idx = 0))
+        val e2 = mkEntity(typ = "2", tokens = NCTestToken(idx = 1))
 
         val ctx = mkIdlContext(Seq(e1, e2))
 
@@ -123,9 +123,9 @@ class NCIDLFunctionsEntity extends NCIDLFunctions:
     }
 
     test("test between") {
-        val e1 = mkEntity(id = "1", groups = Set("grp1"), tokens = NCTestToken(idx = 0))
-        val e2 = mkEntity(id = "2", groups = Set("grp2"), tokens = NCTestToken(idx = 1))
-        val e3 = mkEntity(id = "3", groups = Set("grp3"), tokens = NCTestToken(idx = 2))
+        val e1 = mkEntity(typ = "1", groups = Set("grp1"), tokens = NCTestToken(idx = 0))
+        val e2 = mkEntity(typ = "2", groups = Set("grp2"), tokens = NCTestToken(idx = 1))
+        val e3 = mkEntity(typ = "3", groups = Set("grp3"), tokens = NCTestToken(idx = 2))
 
         val ctx = mkIdlContext(Seq(e1, e2, e3))
 
@@ -144,9 +144,9 @@ class NCIDLFunctionsEntity extends NCIDLFunctions:
     }
     
     test("test all methods") {
-        val e1 = mkEntity(id = "1", tokens = NCTestToken())
-        val e2 = mkEntity(id = "2", groups = Set("g", "z", "w"), tokens = NCTestToken())
-        val e3 = mkEntity(id = "2", tokens = NCTestToken())
+        val e1 = mkEntity(typ = "1", tokens = NCTestToken())
+        val e2 = mkEntity(typ = "2", groups = Set("g", "z", "w"), tokens = NCTestToken())
+        val e3 = mkEntity(typ = "2", tokens = NCTestToken())
 
         val ctx = mkIdlContext(Seq(e1, e2, e3))
 
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/test_ok.idl b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/test_ok.idl
index 41afdb3a..8dc795ee 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/test_ok.idl
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/test_ok.idl
@@ -21,7 +21,7 @@
 
 // Re-usable predicate #1.
 fragment=p1
-    term={ent_id == 2}
+    term={ent_type == 2}
     term={meta_frag('a') && has_any(get(meta_frag('b'), 'Москва'), list(1, 2))}
     term(alias)={mdl_id == "test.mdl.id"}
 
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityMapperSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityMapperSpec.scala
index 754dcd91..9b32ab7f 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityMapperSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityMapperSpec.scala
@@ -31,7 +31,7 @@ import scala.util.Using
 class NCEntityMapperSpec extends AnyFunSuite:
     private case class Combiner(ids: String*) extends NCEntityMapper:
         override def map(req: NCRequest, cfg: NCModelConfig, es: List[NCEntity]): List[NCEntity] =
-            val replaced = es.filter(p => ids.contains(p.getId))
+            val replaced = es.filter(p => ids.contains(p.getType))
 
             if replaced.isEmpty then
                 es
@@ -39,7 +39,7 @@ class NCEntityMapperSpec extends AnyFunSuite:
                 val newEntity: NCEntity = new NCPropertyMapAdapter with NCEntity:
                     override val getTokens: List[NCToken] = replaced.flatMap(_.getTokens).sortBy(_.getIndex).toList
                     override val getRequestId: String = req.getRequestId
-                    override val getId: String = ids.mkString
+                    override val getType: String = ids.mkString
 
                 val buf = collection.mutable.ArrayBuffer.empty[NCEntity]
                 buf ++= es
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityParserSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityParserSpec.scala
index db7c179e..ca036729 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityParserSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityParserSpec.scala
@@ -36,7 +36,7 @@ object NCEntityParserSpec:
                 val ent: NCEntity = new NCPropertyMapAdapter with NCEntity :
                     override def getTokens: List[NCToken] = toks
                     override def getRequestId: String = req.getRequestId
-                    override def getId: String = "quoted"
+                    override def getType: String = "quoted"
                 List(ent)
             else
                 List.empty
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserJsonSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserJsonSpec.scala
index d7c62a57..68ce0ed7 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserJsonSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserJsonSpec.scala
@@ -46,7 +46,7 @@ class NCSemanticEntityParserJsonSpec extends AnyFunSuite:
 
         val tok = ents.head
         
-        require(tok.getId == id)
+        require(tok.getType == id)
         elemData match
             case Some(m) => m.foreach { (k, v) => require(tok[Any](s"$id:$k") == v) }
             case None => // No-op.
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserLemmaSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserLemmaSpec.scala
index a443eae1..312c85ef 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserLemmaSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserLemmaSpec.scala
@@ -80,7 +80,7 @@ class NCSemanticEntityParserLemmaSpec extends AnyFunSuite:
 
             for (expData <- expVrnts)
                 val idx = vrnts.zipWithIndex.
-                    find { case (v, _) => expData == v.getEntities.map(e => Data(e.mkText, e.getId)) }.
+                    find { case (v, _) => expData == v.getEntities.map(e => Data(e.mkText, e.getType)) }.
                     getOrElse(throw new AssertionError(s"Cannot find variant: $expData"))._2
                 vrnts.remove(idx)
 
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserSpec.scala
index 515806cf..e813a45f 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserSpec.scala
@@ -55,11 +55,11 @@ class NCSemanticEntityParserSpec extends AnyFunSuite:
     /**
       *
       * @param txt
-      * @param id
+      * @param typ
       * @param value
       * @param elemData
       */
-    private def check(txt: String, id: String, value: Option[String] = None, elemData: Option[Map[String, Any]] = None): Unit =
+    private def check(txt: String, typ: String, value: Option[String] = None, elemData: Option[Map[String, Any]] = None): Unit =
         val req = NCTestRequest(txt)
         val toks = EN_TOK_PARSER.tokenize(txt)
 
@@ -74,21 +74,21 @@ class NCSemanticEntityParserSpec extends AnyFunSuite:
         require(ents.sizeIs == 1)
 
         val e = ents.head
-        require(e.getId == id)
+        require(e.getType == typ)
 
         value match
-            case Some(v) => require(e[Any](s"$id:value") == v)
+            case Some(v) => require(e[Any](s"$typ:value") == v)
             case None => // No-op.
         elemData match
-            case Some(m) => m.foreach { (k, v) => require(e[Any](s"$id:$k") == v) }
+            case Some(m) => m.foreach { (k, v) => require(e[Any](s"$typ:$k") == v) }
             case None => // No-op.
 
     /**
       *
       * @param txt
-      * @param ids
+      * @param types
       */
-    private def checkMultiple(txt: String, ids: String*): Unit =
+    private def checkMultiple(txt: String, types: String*): Unit =
         val req = NCTestRequest(txt)
         val toks = EN_TOK_PARSER.tokenize(txt)
 
@@ -100,8 +100,8 @@ class NCSemanticEntityParserSpec extends AnyFunSuite:
         val ents = semParser.parse(req, CFG, toks)
 
         NCTestUtils.printEntities(txt, ents)
-        require(ents.sizeIs == ids.size)
-        ents.map(_.getId).sorted.zip(ids.sorted).foreach { case (eId, id) => require(eId == id) }
+        require(ents.sizeIs == types.size)
+        ents.map(_.getType).sorted.zip(types.sorted).foreach { case (eTyp, typ) => require(eTyp == typ) }
 
     /**
       *
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserYamlSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserYamlSpec.scala
index 1828b759..5239ce1f 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserYamlSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserYamlSpec.scala
@@ -45,7 +45,7 @@ class NCSemanticEntityParserYamlSpec extends AnyFunSuite:
 
         val tok = ents.head
         
-        require(tok.getId == id)
+        require(tok.getType == id)
 
     /**
       * 
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticTestElement.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticTestElement.scala
index b4090868..ee58ecd0 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticTestElement.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticTestElement.scala
@@ -36,7 +36,7 @@ case class NCSemanticTestElement(
     groups: Seq[String] = Seq.empty,
     props: Map[String, AnyRef] = Map.empty
 ) extends NCSemanticElement:
-    override val getId: String = id
+    override val getType: String = id
     override val getGroups: Set[String] = groups.toSet
     override val getValues: Map[String, Set[String]] = values
     override val getSynonyms: Set[String] = synonyms
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestEntity.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestEntity.scala
index 203e35ec..8dd85ef0 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestEntity.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestEntity.scala
@@ -24,20 +24,20 @@ import org.apache.nlpcraft.nlp.util.NCTestPipeline.*
   *
   */
 object NCTestEntity:
-    def apply(id: String, token: NCTestToken) = new NCTestEntity(id, tokens = Seq(token))
-    def apply(id: String, reqId: String, token: NCTestToken) = new NCTestEntity(id, reqId, tokens = Seq(token))
+    def apply(typ: String, token: NCTestToken) = new NCTestEntity(typ, tokens = Seq(token))
+    def apply(typ: String, reqId: String, token: NCTestToken) = new NCTestEntity(typ, reqId, tokens = Seq(token))
 
 /**
   * Entity test implementation.
   *
-  * @param id
+  * @param typ
   * @param reqId
   * @param groups
   * @param meta
   * @param tokens
   */
 case class NCTestEntity(
-    id: String,
+    typ: String,
     reqId: String = null,
     groups: Set[String] = null,
     meta: Map[String, AnyRef] = null,
@@ -47,5 +47,5 @@ case class NCTestEntity(
 
     override def getTokens: List[NCToken] = tokens.toList
     override def getRequestId: String = reqId
-    override def getGroups: Set[String] = if groups != null then groups else Set(id)
-    override def getId: String = id
\ No newline at end of file
+    override def getGroups: Set[String] = if groups != null then groups else Set(typ)
+    override def getType: String = typ
\ No newline at end of file
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestUtils.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestUtils.scala
index 8afc5cf8..556f5e3f 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestUtils.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestUtils.scala
@@ -71,7 +71,7 @@ object NCTestUtils:
         for (e <- ents)
             val toks = e.getTokens
             tbl += (
-                e.getId,
+                e.getType,
                 toks.map(_.getText).mkString("|"),
                 toks.map(p => s"${p.getStartCharIndex}-${p.getEndCharIndex}").mkString("|"),
                 mkProps(e)
@@ -93,7 +93,7 @@ object NCTestUtils:
             for (e <- v.getEntities)
                 val toks = e.getTokens
                 tbl += (
-                    e.getId,
+                    e.getType,
                     toks.map(_.getText).mkString("|"),
                     toks.map(p => s"${p.getStartCharIndex}-${p.getEndCharIndex}").mkString("|"),
                     mkProps(e)


[incubator-nlpcraft] 03/03: WIP.

Posted by se...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sergeykamov pushed a commit to branch NLPCRAFT-521
in repository https://gitbox.apache.org/repos/asf/incubator-nlpcraft.git

commit bd58872b7b585f509415ffef7f079d60f3e894e5
Author: Sergey Kamov <sk...@gmail.com>
AuthorDate: Fri Dec 23 14:13:44 2022 +0400

    WIP.
---
 .../pizzeria/components/PizzeriaOrderMapper.scala  |   12 +-
 .../components/PizzeriaOrderValidator.scala        |    2 +-
 .../internal/conversation/NCConversationData.scala |    2 +-
 .../internal/impl/NCModelPipelineManager.scala     |    2 +-
 .../intent/compiler/NCIDLCodeGenerator.scala       |    8 +-
 .../internal/intent/compiler/antlr4/NCIDL.g4       |    8 +-
 .../intent/compiler/antlr4/NCIDLLexer.interp       |    2 +-
 .../intent/compiler/antlr4/NCIDLLexer.java         | 1317 ++++++++++----------
 .../nlpcraft/nlp/parsers/NCNLPEntityParser.scala   |   16 +-
 .../nlp/parsers/NCOpenNLPEntityParser.scala        |    4 +-
 .../nlp/parsers/NCSemanticEntityParser.scala       |   10 +-
 .../parsers/impl/NCSemanticSynonymsProcessor.scala |   66 +-
 .../nlpcraft/internal/impl/NCModelClientSpec.scala |    2 +-
 .../compiler/functions/NCIDLFunctionsEntity.scala  |    8 +-
 .../apache/nlpcraft/nlp/NCEntityMapperSpec.scala   |    6 +-
 .../parsers/NCSemanticEntityParserJsonSpec.scala   |   10 +-
 .../parsers/NCSemanticEntityParserLemmaSpec.scala  |    2 +-
 .../parsers/NCSemanticEntityParserYamlSpec.scala   |    8 +-
 .../nlp/parsers/NCSemanticTestElement.scala        |    8 +-
 .../org/apache/nlpcraft/nlp/util/NCTestUtils.scala |    4 +-
 20 files changed, 751 insertions(+), 746 deletions(-)

diff --git a/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderMapper.scala b/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderMapper.scala
index 22526bd8..19fd03c6 100644
--- a/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderMapper.scala
+++ b/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderMapper.scala
@@ -25,16 +25,16 @@ import scala.collection.*
 
 /**
   *
-  * @param elementId Element.
+  * @param elementType Element type.
   * @param propertyName Element's property name.
   */
-case class PizzeriaOrderMapperDesc(elementId: String, propertyName: String)
+case class PizzeriaOrderMapperDesc(elementType: String, propertyName: String)
 
 /**
   * Element extender.
   * For each 'main' dest element it tries to find related extra element and convert this pair to new complex element.
   * New element:
-  * 1. Gets same ID as main element, also all main element properties copied into this new one.
+  * 1. Gets same type as main element, also all main element properties copied into this new one.
   * 2. Gets tokens from both elements.
   * 3. Configured extra element property copied into new element's properties.
   *
@@ -49,7 +49,7 @@ object PizzeriaOrderMapper:
         def tokens: List[NCToken] = entity.getTokens
 
     private def str(es: Iterable[NCEntity]): String =
-        es.map(e => s"id=${e.getType}(${e.tokens.map(_.getIndex).mkString("[", ",", "]")})").mkString("{", ", ", "}")
+        es.map(e => s"type=${e.getType}(${e.tokens.map(_.getIndex).mkString("[", ",", "]")})").mkString("{", ", ", "}")
 
     def apply(extra: PizzeriaOrderMapperDesc, dests: PizzeriaOrderMapperDesc*): PizzeriaOrderMapper = new PizzeriaOrderMapper(extra, dests)
 
@@ -65,9 +65,9 @@ case class PizzeriaOrderMapper(extra: PizzeriaOrderMapperDesc, dests: Seq[Pizzer
                 override val getRequestId: String = req.getRequestId
                 override val getType: String = destEnt.getType
 
-        val destsMap = dests.map(p => p.elementId -> p).toMap
+        val destsMap = dests.map(p => p.elementType -> p).toMap
         val destEnts = mutable.HashSet.empty ++ ents.filter(e => destsMap.contains(e.getType))
-        val extraEnts = ents.filter(_.getType == extra.elementId)
+        val extraEnts = ents.filter(_.getType == extra.elementType)
 
         if destEnts.nonEmpty && extraEnts.nonEmpty && destEnts.size >= extraEnts.size then
             val used = (destEnts ++ extraEnts).toSet
diff --git a/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderValidator.scala b/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderValidator.scala
index 64792b5c..e99faeaa 100644
--- a/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderValidator.scala
+++ b/nlpcraft-examples/pizzeria/src/main/scala/org/apache/nlpcraft/examples/pizzeria/components/PizzeriaOrderValidator.scala
@@ -24,7 +24,7 @@ import org.apache.nlpcraft.*
   */
 class PizzeriaOrderValidator extends NCEntityValidator:
     override def validate(req: NCRequest, cfg: NCModelConfig, ents: List[NCEntity]): Unit =
-        def count(id: String): Int = ents.count(_.getType == id)
+        def count(typ: String): Int = ents.count(_.getType == typ)
 
         val cntPizza = count("ord:pizza")
         val cntDrink = count("ord:drink")
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/conversation/NCConversationData.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/conversation/NCConversationData.scala
index c1606b3a..83f8da8d 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/conversation/NCConversationData.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/conversation/NCConversationData.scala
@@ -187,7 +187,7 @@ case class NCConversationData(
 
         if ctx.isEmpty then logger.trace(s"STM is empty for [$z]")
         else
-            val tbl = NCAsciiTable("Entity ID", "Groups", "Request ID")
+            val tbl = NCAsciiTable("Entity Type", "Groups", "Request ID")
             ctx.foreach(ent => tbl += (
                 ent.getType,
                 ent.getGroups.mkString(", "),
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/impl/NCModelPipelineManager.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/impl/NCModelPipelineManager.scala
index 11367a23..7087a19d 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/impl/NCModelPipelineManager.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/impl/NCModelPipelineManager.scala
@@ -171,7 +171,7 @@ class NCModelPipelineManager(cfg: NCModelConfig, pipeline: NCPipeline) extends L
         val vrns = variants.filter(_.getEntities.nonEmpty)
 
         for (v, i) <- vrns.zipWithIndex do
-            val tbl = NCAsciiTable("EntityId", "Tokens", "Tokens Position", "Properties")
+            val tbl = NCAsciiTable("EntityType", "Tokens", "Tokens Position", "Properties")
 
             for e <- v.getEntities do
                 val toks = e.getTokens
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCodeGenerator.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCodeGenerator.scala
index dae8f866..c2a6f0d9 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCodeGenerator.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/NCIDLCodeGenerator.scala
@@ -906,16 +906,16 @@ trait NCIDLCodeGenerator:
                 case "ent_count" => checkAvail(); z0(() => Z(idlCtx.entities.size, 0))
                 case "ent_groups" => arg1Tok() match { case x => stack.push(() => Z(JList.copyOf(toEntity(x().value).impl.getGroups.asJava), 1)) }
                 case "ent_all" => checkAvail(); z0(() => Z(idlCtx.entities.asJava, 0))
-                case "ent_all_for_id" => checkAvail(); doForAll((e, id) => e.impl.getType == id)
+                case "ent_all_for_type" => checkAvail(); doForAll((e, typ) => e.impl.getType == typ)
                 case "ent_all_for_group" => checkAvail(); doForAll((e, grp) => e.impl.getGroups.contains(grp))
                 case "ent_this" => z0(() => Z(ent, 1))
                 case "ent_is_last" => checkAvail(); arg1Tok() match { case x => stack.push(() => { Z(toEntity(x().value).index == idlCtx.entities.size - 1, 1) }) }
                 case "ent_is_first" => checkAvail(); arg1Tok() match { case x => stack.push(() => { Z(toEntity(x().value).index == 0, 1) }) }
-                case "ent_is_before_id" => checkAvail(); doIsBefore((e, id) => e.impl.getType == id)
+                case "ent_is_before_type" => checkAvail(); doIsBefore((e, typ) => e.impl.getType == typ)
                 case "ent_is_before_group" => checkAvail(); doIsBefore((e, grpId) => e.impl.getGroups.contains(grpId))
-                case "ent_is_after_id" => checkAvail(); doIsAfter((e, id) => e.impl.getType == id)
+                case "ent_is_after_type" => checkAvail(); doIsAfter((e, typ) => e.impl.getType == typ)
                 case "ent_is_after_group" => checkAvail(); doIsAfter((e, grpId) => e.impl.getGroups.contains(grpId))
-                case "ent_is_between_ids" => checkAvail(); doIsBetween((e, id) => e.impl.getType == id)
+                case "ent_is_between_types" => checkAvail(); doIsBetween((e, typ) => e.impl.getType == typ)
                 case "ent_is_between_groups" => checkAvail(); doIsBetween((e, grpId) => e.impl.getGroups.contains(grpId))
 
                 // Request data.
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4 b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4
index 6f614d76..299af32d 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4
@@ -149,16 +149,16 @@ FUN_NAME
     | 'ent_groups'
     | 'ent_count'
     | 'ent_all'
-    | 'ent_all_for_id'
+    | 'ent_all_for_type'
     | 'ent_all_for_group'
     | 'ent_this'
     | 'ent_is_last'
     | 'ent_is_first'
-    | 'ent_is_before_id'
+    | 'ent_is_before_type'
     | 'ent_is_before_group'
-    | 'ent_is_after_id'
+    | 'ent_is_after_type'
     | 'ent_is_after_group'
-    | 'ent_is_between_ids'
+    | 'ent_is_between_types'
     | 'ent_is_between_groups'
     | 'mdl_id'
     | 'mdl_name'
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.interp b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.interp
index e70c4b41..688edf0f 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.interp
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.interp
@@ -172,4 +172,4 @@ mode names:
 DEFAULT_MODE
 
 atn:
-[4, 0, 52, 1250, 6, -1, 2, 0, 7, 0, 2, 1, 7, 1, 2, 2, 7, 2, 2, 3, 7, 3, 2, 4, 7, 4, 2, 5, 7, 5, 2, 6, 7, 6, 2, 7, 7, 7, 2, 8, 7, 8, 2, 9, 7, 9, 2, 10, 7, 10, 2, 11, 7, 11, 2, 12, 7, 12, 2, 13, 7, 13, 2, 14, 7, 14, 2, 15, 7, 15, 2, 16, 7, 16, 2, 17, 7, 17, 2, 18, 7, 18, 2, 19, 7, 19, 2, 20, 7, 20, 2, 21, 7, 21, 2, 22, 7, 22, 2, 23, 7, 23, 2, 24, 7, 24, 2, 25, 7, 25, 2, 26, 7, 26, 2, 27, 7, 27, 2, 28, 7, 28, 2, 29, 7, 29, 2, 30, 7, 30, 2, 31, 7, 31, 2, 32, 7, 32, 2, 33, 7, 33, 2, 34, 7, 34 [...]
\ No newline at end of file
+[4, 0, 52, 1258, 6, -1, 2, 0, 7, 0, 2, 1, 7, 1, 2, 2, 7, 2, 2, 3, 7, 3, 2, 4, 7, 4, 2, 5, 7, 5, 2, 6, 7, 6, 2, 7, 7, 7, 2, 8, 7, 8, 2, 9, 7, 9, 2, 10, 7, 10, 2, 11, 7, 11, 2, 12, 7, 12, 2, 13, 7, 13, 2, 14, 7, 14, 2, 15, 7, 15, 2, 16, 7, 16, 2, 17, 7, 17, 2, 18, 7, 18, 2, 19, 7, 19, 2, 20, 7, 20, 2, 21, 7, 21, 2, 22, 7, 22, 2, 23, 7, 23, 2, 24, 7, 24, 2, 25, 7, 25, 2, 26, 7, 26, 2, 27, 7, 27, 2, 28, 7, 28, 2, 29, 7, 29, 2, 30, 7, 30, 2, 31, 7, 31, 2, 32, 7, 32, 2, 33, 7, 33, 2, 34, 7, 34 [...]
\ No newline at end of file
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.java b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.java
index db05c678..a1ef1cf4 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.java
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.java
@@ -125,7 +125,7 @@ public class NCIDLLexer extends Lexer {
 	public ATN getATN() { return _ATN; }
 
 	public static final String _serializedATN =
-		"\u0004\u00004\u04e2\u0006\uffff\uffff\u0002\u0000\u0007\u0000\u0002\u0001"+
+		"\u0004\u00004\u04ea\u0006\uffff\uffff\u0002\u0000\u0007\u0000\u0002\u0001"+
 		"\u0007\u0001\u0002\u0002\u0007\u0002\u0002\u0003\u0007\u0003\u0002\u0004"+
 		"\u0007\u0004\u0002\u0005\u0007\u0005\u0002\u0006\u0007\u0006\u0002\u0007"+
 		"\u0007\u0007\u0002\b\u0007\b\u0002\t\u0007\t\u0002\n\u0007\n\u0002\u000b"+
@@ -289,662 +289,667 @@ public class NCIDLLexer extends Lexer {
 		"\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000"+
 		"\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000"+
 		"\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000"+
-		"\u0001\u0000\u0003\u0000\u03ed\b\u0000\u0001\u0001\u0001\u0001\u0001\u0001"+
-		"\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0002\u0001\u0002"+
-		"\u0001\u0002\u0001\u0002\u0001\u0002\u0001\u0002\u0001\u0002\u0001\u0003"+
-		"\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0003"+
-		"\u0001\u0003\u0001\u0004\u0001\u0004\u0001\u0004\u0001\u0004\u0001\u0004"+
-		"\u0001\u0005\u0001\u0005\u0001\u0005\u0001\u0005\u0001\u0005\u0001\u0006"+
-		"\u0001\u0006\u0001\u0006\u0001\u0006\u0001\u0006\u0001\u0007\u0001\u0007"+
+		"\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000"+
+		"\u0001\u0000\u0001\u0000\u0001\u0000\u0003\u0000\u03f5\b\u0000\u0001\u0001"+
+		"\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001"+
+		"\u0001\u0002\u0001\u0002\u0001\u0002\u0001\u0002\u0001\u0002\u0001\u0002"+
+		"\u0001\u0002\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0003"+
+		"\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0004\u0001\u0004\u0001\u0004"+
+		"\u0001\u0004\u0001\u0004\u0001\u0005\u0001\u0005\u0001\u0005\u0001\u0005"+
+		"\u0001\u0005\u0001\u0006\u0001\u0006\u0001\u0006\u0001\u0006\u0001\u0006"+
 		"\u0001\u0007\u0001\u0007\u0001\u0007\u0001\u0007\u0001\u0007\u0001\u0007"+
-		"\u0001\u0007\u0001\b\u0001\b\u0001\b\u0001\b\u0005\b\u0421\b\b\n\b\f\b"+
-		"\u0424\t\b\u0001\b\u0001\b\u0001\t\u0001\t\u0001\t\u0001\t\u0005\t\u042c"+
-		"\b\t\n\t\f\t\u042f\t\t\u0001\t\u0001\t\u0001\n\u0001\n\u0001\n\u0001\n"+
-		"\u0001\n\u0001\n\u0001\n\u0001\n\u0001\n\u0003\n\u043c\b\n\u0001\u000b"+
-		"\u0001\u000b\u0001\u000b\u0001\u000b\u0001\u000b\u0001\f\u0001\f\u0001"+
-		"\f\u0001\r\u0001\r\u0001\r\u0001\u000e\u0001\u000e\u0001\u000e\u0001\u000f"+
-		"\u0001\u000f\u0001\u000f\u0001\u0010\u0001\u0010\u0001\u0011\u0001\u0011"+
-		"\u0001\u0012\u0001\u0012\u0001\u0012\u0001\u0013\u0001\u0013\u0001\u0013"+
-		"\u0001\u0014\u0001\u0014\u0001\u0015\u0001\u0015\u0001\u0016\u0001\u0016"+
-		"\u0001\u0017\u0001\u0017\u0001\u0018\u0001\u0018\u0001\u0019\u0001\u0019"+
-		"\u0001\u001a\u0001\u001a\u0001\u001b\u0001\u001b\u0001\u001c\u0001\u001c"+
-		"\u0001\u001d\u0001\u001d\u0001\u001e\u0001\u001e\u0001\u001f\u0001\u001f"+
-		"\u0001 \u0001 \u0001!\u0001!\u0001\"\u0001\"\u0001#\u0001#\u0001$\u0001"+
-		"$\u0001%\u0001%\u0001&\u0001&\u0001\'\u0001\'\u0001(\u0001(\u0001)\u0001"+
-		")\u0001*\u0001*\u0001+\u0001+\u0001,\u0001,\u0001-\u0001-\u0001-\u0005"+
-		"-\u048e\b-\n-\f-\u0491\t-\u0003-\u0493\b-\u0001.\u0001.\u0004.\u0497\b"+
-		".\u000b.\f.\u0498\u0001/\u0001/\u0003/\u049d\b/\u0001/\u0001/\u00010\u0001"+
-		"0\u00010\u00030\u04a4\b0\u00011\u00011\u00012\u00012\u00012\u00012\u0004"+
-		"2\u04ac\b2\u000b2\f2\u04ad\u00012\u00012\u00012\u00012\u00012\u00012\u0001"+
-		"2\u00052\u04b7\b2\n2\f2\u04ba\t2\u00013\u00013\u00013\u00013\u00053\u04c0"+
-		"\b3\n3\f3\u04c3\t3\u00013\u00033\u04c6\b3\u00013\u00033\u04c9\b3\u0001"+
-		"3\u00013\u00013\u00013\u00053\u04cf\b3\n3\f3\u04d2\t3\u00013\u00013\u0003"+
-		"3\u04d6\b3\u00013\u00013\u00014\u00044\u04db\b4\u000b4\f4\u04dc\u0001"+
-		"4\u00014\u00015\u00015\u0001\u04d0\u00006\u0001\u0001\u0003\u0002\u0005"+
-		"\u0003\u0007\u0004\t\u0005\u000b\u0006\r\u0007\u000f\b\u0011\t\u0013\n"+
-		"\u0015\u000b\u0017\f\u0019\r\u001b\u000e\u001d\u000f\u001f\u0010!\u0011"+
-		"#\u0012%\u0013\'\u0014)\u0015+\u0016-\u0017/\u00181\u00193\u001a5\u001b"+
-		"7\u001c9\u001d;\u001e=\u001f? A!C\"E#G$I%K&M\'O(Q)S*U+W,Y-[.]/_0a\u0000"+
-		"c\u0000e1g2i3k4\u0001\u0000\u000e\u0001\u0000\'\'\u0001\u0000\"\"\u0001"+
-		"\u000019\u0002\u000009__\u0001\u000009\u0002\u0000EEee\u0002\u0000++-"+
-		"-\u0002\u0000\u0000\u007f\u8000\ud800\u8000\udbff\u0001\u0000\u8000\ud800"+
-		"\u8000\udbff\u0001\u0000\u8000\udc00\u8000\udfff\u0002\u0000AZaz\u0002"+
-		"\u0000\n\n\r\r\u0001\u0001\n\n\u0003\u0000\t\n\f\r  \u0573\u0000\u0001"+
-		"\u0001\u0000\u0000\u0000\u0000\u0003\u0001\u0000\u0000\u0000\u0000\u0005"+
-		"\u0001\u0000\u0000\u0000\u0000\u0007\u0001\u0000\u0000\u0000\u0000\t\u0001"+
-		"\u0000\u0000\u0000\u0000\u000b\u0001\u0000\u0000\u0000\u0000\r\u0001\u0000"+
-		"\u0000\u0000\u0000\u000f\u0001\u0000\u0000\u0000\u0000\u0011\u0001\u0000"+
-		"\u0000\u0000\u0000\u0013\u0001\u0000\u0000\u0000\u0000\u0015\u0001\u0000"+
-		"\u0000\u0000\u0000\u0017\u0001\u0000\u0000\u0000\u0000\u0019\u0001\u0000"+
-		"\u0000\u0000\u0000\u001b\u0001\u0000\u0000\u0000\u0000\u001d\u0001\u0000"+
-		"\u0000\u0000\u0000\u001f\u0001\u0000\u0000\u0000\u0000!\u0001\u0000\u0000"+
-		"\u0000\u0000#\u0001\u0000\u0000\u0000\u0000%\u0001\u0000\u0000\u0000\u0000"+
-		"\'\u0001\u0000\u0000\u0000\u0000)\u0001\u0000\u0000\u0000\u0000+\u0001"+
-		"\u0000\u0000\u0000\u0000-\u0001\u0000\u0000\u0000\u0000/\u0001\u0000\u0000"+
-		"\u0000\u00001\u0001\u0000\u0000\u0000\u00003\u0001\u0000\u0000\u0000\u0000"+
-		"5\u0001\u0000\u0000\u0000\u00007\u0001\u0000\u0000\u0000\u00009\u0001"+
-		"\u0000\u0000\u0000\u0000;\u0001\u0000\u0000\u0000\u0000=\u0001\u0000\u0000"+
-		"\u0000\u0000?\u0001\u0000\u0000\u0000\u0000A\u0001\u0000\u0000\u0000\u0000"+
-		"C\u0001\u0000\u0000\u0000\u0000E\u0001\u0000\u0000\u0000\u0000G\u0001"+
-		"\u0000\u0000\u0000\u0000I\u0001\u0000\u0000\u0000\u0000K\u0001\u0000\u0000"+
-		"\u0000\u0000M\u0001\u0000\u0000\u0000\u0000O\u0001\u0000\u0000\u0000\u0000"+
-		"Q\u0001\u0000\u0000\u0000\u0000S\u0001\u0000\u0000\u0000\u0000U\u0001"+
-		"\u0000\u0000\u0000\u0000W\u0001\u0000\u0000\u0000\u0000Y\u0001\u0000\u0000"+
-		"\u0000\u0000[\u0001\u0000\u0000\u0000\u0000]\u0001\u0000\u0000\u0000\u0000"+
-		"_\u0001\u0000\u0000\u0000\u0000e\u0001\u0000\u0000\u0000\u0000g\u0001"+
-		"\u0000\u0000\u0000\u0000i\u0001\u0000\u0000\u0000\u0000k\u0001\u0000\u0000"+
-		"\u0000\u0001\u03ec\u0001\u0000\u0000\u0000\u0003\u03ee\u0001\u0000\u0000"+
-		"\u0000\u0005\u03f5\u0001\u0000\u0000\u0000\u0007\u03fc\u0001\u0000\u0000"+
-		"\u0000\t\u0404\u0001\u0000\u0000\u0000\u000b\u0409\u0001\u0000\u0000\u0000"+
-		"\r\u040e\u0001\u0000\u0000\u0000\u000f\u0413\u0001\u0000\u0000\u0000\u0011"+
-		"\u041c\u0001\u0000\u0000\u0000\u0013\u0427\u0001\u0000\u0000\u0000\u0015"+
-		"\u043b\u0001\u0000\u0000\u0000\u0017\u043d\u0001\u0000\u0000\u0000\u0019"+
-		"\u0442\u0001\u0000\u0000\u0000\u001b\u0445\u0001\u0000\u0000\u0000\u001d"+
-		"\u0448\u0001\u0000\u0000\u0000\u001f\u044b\u0001\u0000\u0000\u0000!\u044e"+
-		"\u0001\u0000\u0000\u0000#\u0450\u0001\u0000\u0000\u0000%\u0452\u0001\u0000"+
-		"\u0000\u0000\'\u0455\u0001\u0000\u0000\u0000)\u0458\u0001\u0000\u0000"+
-		"\u0000+\u045a\u0001\u0000\u0000\u0000-\u045c\u0001\u0000\u0000\u0000/"+
-		"\u045e\u0001\u0000\u0000\u00001\u0460\u0001\u0000\u0000\u00003\u0462\u0001"+
-		"\u0000\u0000\u00005\u0464\u0001\u0000\u0000\u00007\u0466\u0001\u0000\u0000"+
-		"\u00009\u0468\u0001\u0000\u0000\u0000;\u046a\u0001\u0000\u0000\u0000="+
-		"\u046c\u0001\u0000\u0000\u0000?\u046e\u0001\u0000\u0000\u0000A\u0470\u0001"+
-		"\u0000\u0000\u0000C\u0472\u0001\u0000\u0000\u0000E\u0474\u0001\u0000\u0000"+
-		"\u0000G\u0476\u0001\u0000\u0000\u0000I\u0478\u0001\u0000\u0000\u0000K"+
-		"\u047a\u0001\u0000\u0000\u0000M\u047c\u0001\u0000\u0000\u0000O\u047e\u0001"+
-		"\u0000\u0000\u0000Q\u0480\u0001\u0000\u0000\u0000S\u0482\u0001\u0000\u0000"+
-		"\u0000U\u0484\u0001\u0000\u0000\u0000W\u0486\u0001\u0000\u0000\u0000Y"+
-		"\u0488\u0001\u0000\u0000\u0000[\u0492\u0001\u0000\u0000\u0000]\u0494\u0001"+
-		"\u0000\u0000\u0000_\u049a\u0001\u0000\u0000\u0000a\u04a3\u0001\u0000\u0000"+
-		"\u0000c\u04a5\u0001\u0000\u0000\u0000e\u04ab\u0001\u0000\u0000\u0000g"+
-		"\u04d5\u0001\u0000\u0000\u0000i\u04da\u0001\u0000\u0000\u0000k\u04e0\u0001"+
-		"\u0000\u0000\u0000mn\u0005m\u0000\u0000no\u0005e\u0000\u0000op\u0005t"+
-		"\u0000\u0000pq\u0005a\u0000\u0000qr\u0005_\u0000\u0000rs\u0005e\u0000"+
-		"\u0000st\u0005n\u0000\u0000t\u03ed\u0005t\u0000\u0000uv\u0005m\u0000\u0000"+
-		"vw\u0005e\u0000\u0000wx\u0005t\u0000\u0000xy\u0005a\u0000\u0000yz\u0005"+
-		"_\u0000\u0000z{\u0005c\u0000\u0000{|\u0005f\u0000\u0000|\u03ed\u0005g"+
-		"\u0000\u0000}~\u0005m\u0000\u0000~\u007f\u0005e\u0000\u0000\u007f\u0080"+
-		"\u0005t\u0000\u0000\u0080\u0081\u0005a\u0000\u0000\u0081\u0082\u0005_"+
-		"\u0000\u0000\u0082\u0083\u0005i\u0000\u0000\u0083\u0084\u0005n\u0000\u0000"+
-		"\u0084\u0085\u0005t\u0000\u0000\u0085\u0086\u0005e\u0000\u0000\u0086\u0087"+
-		"\u0005n\u0000\u0000\u0087\u03ed\u0005t\u0000\u0000\u0088\u0089\u0005m"+
-		"\u0000\u0000\u0089\u008a\u0005e\u0000\u0000\u008a\u008b\u0005t\u0000\u0000"+
-		"\u008b\u008c\u0005a\u0000\u0000\u008c\u008d\u0005_\u0000\u0000\u008d\u008e"+
-		"\u0005r\u0000\u0000\u008e\u008f\u0005e\u0000\u0000\u008f\u03ed\u0005q"+
-		"\u0000\u0000\u0090\u0091\u0005m\u0000\u0000\u0091\u0092\u0005e\u0000\u0000"+
-		"\u0092\u0093\u0005t\u0000\u0000\u0093\u0094\u0005a\u0000\u0000\u0094\u0095"+
-		"\u0005_\u0000\u0000\u0095\u0096\u0005s\u0000\u0000\u0096\u0097\u0005y"+
-		"\u0000\u0000\u0097\u03ed\u0005s\u0000\u0000\u0098\u0099\u0005m\u0000\u0000"+
-		"\u0099\u009a\u0005e\u0000\u0000\u009a\u009b\u0005t\u0000\u0000\u009b\u009c"+
-		"\u0005a\u0000\u0000\u009c\u009d\u0005_\u0000\u0000\u009d\u009e\u0005c"+
-		"\u0000\u0000\u009e\u009f\u0005o\u0000\u0000\u009f\u00a0\u0005n\u0000\u0000"+
-		"\u00a0\u03ed\u0005v\u0000\u0000\u00a1\u00a2\u0005m\u0000\u0000\u00a2\u00a3"+
-		"\u0005e\u0000\u0000\u00a3\u00a4\u0005t\u0000\u0000\u00a4\u00a5\u0005a"+
-		"\u0000\u0000\u00a5\u00a6\u0005_\u0000\u0000\u00a6\u00a7\u0005f\u0000\u0000"+
-		"\u00a7\u00a8\u0005r\u0000\u0000\u00a8\u00a9\u0005a\u0000\u0000\u00a9\u03ed"+
-		"\u0005g\u0000\u0000\u00aa\u00ab\u0005j\u0000\u0000\u00ab\u00ac\u0005s"+
-		"\u0000\u0000\u00ac\u00ad\u0005o\u0000\u0000\u00ad\u03ed\u0005n\u0000\u0000"+
-		"\u00ae\u00af\u0005i\u0000\u0000\u00af\u03ed\u0005f\u0000\u0000\u00b0\u00b1"+
-		"\u0005e\u0000\u0000\u00b1\u00b2\u0005n\u0000\u0000\u00b2\u00b3\u0005t"+
-		"\u0000\u0000\u00b3\u00b4\u0005_\u0000\u0000\u00b4\u00b5\u0005t\u0000\u0000"+
-		"\u00b5\u00b6\u0005y\u0000\u0000\u00b6\u00b7\u0005p\u0000\u0000\u00b7\u03ed"+
-		"\u0005e\u0000\u0000\u00b8\u00b9\u0005e\u0000\u0000\u00b9\u00ba\u0005n"+
-		"\u0000\u0000\u00ba\u00bb\u0005t\u0000\u0000\u00bb\u00bc\u0005_\u0000\u0000"+
-		"\u00bc\u00bd\u0005i\u0000\u0000\u00bd\u00be\u0005n\u0000\u0000\u00be\u00bf"+
-		"\u0005d\u0000\u0000\u00bf\u00c0\u0005e\u0000\u0000\u00c0\u03ed\u0005x"+
-		"\u0000\u0000\u00c1\u00c2\u0005e\u0000\u0000\u00c2\u00c3\u0005n\u0000\u0000"+
-		"\u00c3\u00c4\u0005t\u0000\u0000\u00c4\u00c5\u0005_\u0000\u0000\u00c5\u00c6"+
-		"\u0005t\u0000\u0000\u00c6\u00c7\u0005e\u0000\u0000\u00c7\u00c8\u0005x"+
-		"\u0000\u0000\u00c8\u03ed\u0005t\u0000\u0000\u00c9\u00ca\u0005e\u0000\u0000"+
-		"\u00ca\u00cb\u0005n\u0000\u0000\u00cb\u00cc\u0005t\u0000\u0000\u00cc\u00cd"+
-		"\u0005_\u0000\u0000\u00cd\u00ce\u0005g\u0000\u0000\u00ce\u00cf\u0005r"+
-		"\u0000\u0000\u00cf\u00d0\u0005o\u0000\u0000\u00d0\u00d1\u0005u\u0000\u0000"+
-		"\u00d1\u00d2\u0005p\u0000\u0000\u00d2\u03ed\u0005s\u0000\u0000\u00d3\u00d4"+
-		"\u0005e\u0000\u0000\u00d4\u00d5\u0005n\u0000\u0000\u00d5\u00d6\u0005t"+
-		"\u0000\u0000\u00d6\u00d7\u0005_\u0000\u0000\u00d7\u00d8\u0005c\u0000\u0000"+
-		"\u00d8\u00d9\u0005o\u0000\u0000\u00d9\u00da\u0005u\u0000\u0000\u00da\u00db"+
-		"\u0005n\u0000\u0000\u00db\u03ed\u0005t\u0000\u0000\u00dc\u00dd\u0005e"+
-		"\u0000\u0000\u00dd\u00de\u0005n\u0000\u0000\u00de\u00df\u0005t\u0000\u0000"+
-		"\u00df\u00e0\u0005_\u0000\u0000\u00e0\u00e1\u0005a\u0000\u0000\u00e1\u00e2"+
-		"\u0005l\u0000\u0000\u00e2\u03ed\u0005l\u0000\u0000\u00e3\u00e4\u0005e"+
-		"\u0000\u0000\u00e4\u00e5\u0005n\u0000\u0000\u00e5\u00e6\u0005t\u0000\u0000"+
-		"\u00e6\u00e7\u0005_\u0000\u0000\u00e7\u00e8\u0005a\u0000\u0000\u00e8\u00e9"+
-		"\u0005l\u0000\u0000\u00e9\u00ea\u0005l\u0000\u0000\u00ea\u00eb\u0005_"+
-		"\u0000\u0000\u00eb\u00ec\u0005f\u0000\u0000\u00ec\u00ed\u0005o\u0000\u0000"+
-		"\u00ed\u00ee\u0005r\u0000\u0000\u00ee\u00ef\u0005_\u0000\u0000\u00ef\u00f0"+
-		"\u0005i\u0000\u0000\u00f0\u03ed\u0005d\u0000\u0000\u00f1\u00f2\u0005e"+
-		"\u0000\u0000\u00f2\u00f3\u0005n\u0000\u0000\u00f3\u00f4\u0005t\u0000\u0000"+
-		"\u00f4\u00f5\u0005_\u0000\u0000\u00f5\u00f6\u0005a\u0000\u0000\u00f6\u00f7"+
-		"\u0005l\u0000\u0000\u00f7\u00f8\u0005l\u0000\u0000\u00f8\u00f9\u0005_"+
-		"\u0000\u0000\u00f9\u00fa\u0005f\u0000\u0000\u00fa\u00fb\u0005o\u0000\u0000"+
-		"\u00fb\u00fc\u0005r\u0000\u0000\u00fc\u00fd\u0005_\u0000\u0000\u00fd\u00fe"+
-		"\u0005g\u0000\u0000\u00fe\u00ff\u0005r\u0000\u0000\u00ff\u0100\u0005o"+
-		"\u0000\u0000\u0100\u0101\u0005u\u0000\u0000\u0101\u03ed\u0005p\u0000\u0000"+
-		"\u0102\u0103\u0005e\u0000\u0000\u0103\u0104\u0005n\u0000\u0000\u0104\u0105"+
-		"\u0005t\u0000\u0000\u0105\u0106\u0005_\u0000\u0000\u0106\u0107\u0005t"+
-		"\u0000\u0000\u0107\u0108\u0005h\u0000\u0000\u0108\u0109\u0005i\u0000\u0000"+
-		"\u0109\u03ed\u0005s\u0000\u0000\u010a\u010b\u0005e\u0000\u0000\u010b\u010c"+
-		"\u0005n\u0000\u0000\u010c\u010d\u0005t\u0000\u0000\u010d\u010e\u0005_"+
-		"\u0000\u0000\u010e\u010f\u0005i\u0000\u0000\u010f\u0110\u0005s\u0000\u0000"+
-		"\u0110\u0111\u0005_\u0000\u0000\u0111\u0112\u0005l\u0000\u0000\u0112\u0113"+
-		"\u0005a\u0000\u0000\u0113\u0114\u0005s\u0000\u0000\u0114\u03ed\u0005t"+
-		"\u0000\u0000\u0115\u0116\u0005e\u0000\u0000\u0116\u0117\u0005n\u0000\u0000"+
-		"\u0117\u0118\u0005t\u0000\u0000\u0118\u0119\u0005_\u0000\u0000\u0119\u011a"+
-		"\u0005i\u0000\u0000\u011a\u011b\u0005s\u0000\u0000\u011b\u011c\u0005_"+
-		"\u0000\u0000\u011c\u011d\u0005f\u0000\u0000\u011d\u011e\u0005i\u0000\u0000"+
-		"\u011e\u011f\u0005r\u0000\u0000\u011f\u0120\u0005s\u0000\u0000\u0120\u03ed"+
-		"\u0005t\u0000\u0000\u0121\u0122\u0005e\u0000\u0000\u0122\u0123\u0005n"+
-		"\u0000\u0000\u0123\u0124\u0005t\u0000\u0000\u0124\u0125\u0005_\u0000\u0000"+
-		"\u0125\u0126\u0005i\u0000\u0000\u0126\u0127\u0005s\u0000\u0000\u0127\u0128"+
-		"\u0005_\u0000\u0000\u0128\u0129\u0005b\u0000\u0000\u0129\u012a\u0005e"+
-		"\u0000\u0000\u012a\u012b\u0005f\u0000\u0000\u012b\u012c\u0005o\u0000\u0000"+
-		"\u012c\u012d\u0005r\u0000\u0000\u012d\u012e\u0005e\u0000\u0000\u012e\u012f"+
-		"\u0005_\u0000\u0000\u012f\u0130\u0005i\u0000\u0000\u0130\u03ed\u0005d"+
-		"\u0000\u0000\u0131\u0132\u0005e\u0000\u0000\u0132\u0133\u0005n\u0000\u0000"+
-		"\u0133\u0134\u0005t\u0000\u0000\u0134\u0135\u0005_\u0000\u0000\u0135\u0136"+
-		"\u0005i\u0000\u0000\u0136\u0137\u0005s\u0000\u0000\u0137\u0138\u0005_"+
-		"\u0000\u0000\u0138\u0139\u0005b\u0000\u0000\u0139\u013a\u0005e\u0000\u0000"+
-		"\u013a\u013b\u0005f\u0000\u0000\u013b\u013c\u0005o\u0000\u0000\u013c\u013d"+
-		"\u0005r\u0000\u0000\u013d\u013e\u0005e\u0000\u0000\u013e\u013f\u0005_"+
-		"\u0000\u0000\u013f\u0140\u0005g\u0000\u0000\u0140\u0141\u0005r\u0000\u0000"+
-		"\u0141\u0142\u0005o\u0000\u0000\u0142\u0143\u0005u\u0000\u0000\u0143\u03ed"+
-		"\u0005p\u0000\u0000\u0144\u0145\u0005e\u0000\u0000\u0145\u0146\u0005n"+
-		"\u0000\u0000\u0146\u0147\u0005t\u0000\u0000\u0147\u0148\u0005_\u0000\u0000"+
-		"\u0148\u0149\u0005i\u0000\u0000\u0149\u014a\u0005s\u0000\u0000\u014a\u014b"+
-		"\u0005_\u0000\u0000\u014b\u014c\u0005a\u0000\u0000\u014c\u014d\u0005f"+
-		"\u0000\u0000\u014d\u014e\u0005t\u0000\u0000\u014e\u014f\u0005e\u0000\u0000"+
-		"\u014f\u0150\u0005r\u0000\u0000\u0150\u0151\u0005_\u0000\u0000\u0151\u0152"+
-		"\u0005i\u0000\u0000\u0152\u03ed\u0005d\u0000\u0000\u0153\u0154\u0005e"+
-		"\u0000\u0000\u0154\u0155\u0005n\u0000\u0000\u0155\u0156\u0005t\u0000\u0000"+
-		"\u0156\u0157\u0005_\u0000\u0000\u0157\u0158\u0005i\u0000\u0000\u0158\u0159"+
-		"\u0005s\u0000\u0000\u0159\u015a\u0005_\u0000\u0000\u015a\u015b\u0005a"+
-		"\u0000\u0000\u015b\u015c\u0005f\u0000\u0000\u015c\u015d\u0005t\u0000\u0000"+
-		"\u015d\u015e\u0005e\u0000\u0000\u015e\u015f\u0005r\u0000\u0000\u015f\u0160"+
-		"\u0005_\u0000\u0000\u0160\u0161\u0005g\u0000\u0000\u0161\u0162\u0005r"+
-		"\u0000\u0000\u0162\u0163\u0005o\u0000\u0000\u0163\u0164\u0005u\u0000\u0000"+
-		"\u0164\u03ed\u0005p\u0000\u0000\u0165\u0166\u0005e\u0000\u0000\u0166\u0167"+
-		"\u0005n\u0000\u0000\u0167\u0168\u0005t\u0000\u0000\u0168\u0169\u0005_"+
-		"\u0000\u0000\u0169\u016a\u0005i\u0000\u0000\u016a\u016b\u0005s\u0000\u0000"+
-		"\u016b\u016c\u0005_\u0000\u0000\u016c\u016d\u0005b\u0000\u0000\u016d\u016e"+
-		"\u0005e\u0000\u0000\u016e\u016f\u0005t\u0000\u0000\u016f\u0170\u0005w"+
-		"\u0000\u0000\u0170\u0171\u0005e\u0000\u0000\u0171\u0172\u0005e\u0000\u0000"+
-		"\u0172\u0173\u0005n\u0000\u0000\u0173\u0174\u0005_\u0000\u0000\u0174\u0175"+
-		"\u0005i\u0000\u0000\u0175\u0176\u0005d\u0000\u0000\u0176\u03ed\u0005s"+
-		"\u0000\u0000\u0177\u0178\u0005e\u0000\u0000\u0178\u0179\u0005n\u0000\u0000"+
-		"\u0179\u017a\u0005t\u0000\u0000\u017a\u017b\u0005_\u0000\u0000\u017b\u017c"+
-		"\u0005i\u0000\u0000\u017c\u017d\u0005s\u0000\u0000\u017d\u017e\u0005_"+
-		"\u0000\u0000\u017e\u017f\u0005b\u0000\u0000\u017f\u0180\u0005e\u0000\u0000"+
-		"\u0180\u0181\u0005t\u0000\u0000\u0181\u0182\u0005w\u0000\u0000\u0182\u0183"+
-		"\u0005e\u0000\u0000\u0183\u0184\u0005e\u0000\u0000\u0184\u0185\u0005n"+
-		"\u0000\u0000\u0185\u0186\u0005_\u0000\u0000\u0186\u0187\u0005g\u0000\u0000"+
-		"\u0187\u0188\u0005r\u0000\u0000\u0188\u0189\u0005o\u0000\u0000\u0189\u018a"+
-		"\u0005u\u0000\u0000\u018a\u018b\u0005p\u0000\u0000\u018b\u03ed\u0005s"+
-		"\u0000\u0000\u018c\u018d\u0005m\u0000\u0000\u018d\u018e\u0005d\u0000\u0000"+
-		"\u018e\u018f\u0005l\u0000\u0000\u018f\u0190\u0005_\u0000\u0000\u0190\u0191"+
-		"\u0005i\u0000\u0000\u0191\u03ed\u0005d\u0000\u0000\u0192\u0193\u0005m"+
-		"\u0000\u0000\u0193\u0194\u0005d\u0000\u0000\u0194\u0195\u0005l\u0000\u0000"+
-		"\u0195\u0196\u0005_\u0000\u0000\u0196\u0197\u0005n\u0000\u0000\u0197\u0198"+
-		"\u0005a\u0000\u0000\u0198\u0199\u0005m\u0000\u0000\u0199\u03ed\u0005e"+
-		"\u0000\u0000\u019a\u019b\u0005m\u0000\u0000\u019b\u019c\u0005d\u0000\u0000"+
-		"\u019c\u019d\u0005l\u0000\u0000\u019d\u019e\u0005_\u0000\u0000\u019e\u019f"+
-		"\u0005v\u0000\u0000\u019f\u01a0\u0005e\u0000\u0000\u01a0\u03ed\u0005r"+
-		"\u0000\u0000\u01a1\u01a2\u0005m\u0000\u0000\u01a2\u01a3\u0005d\u0000\u0000"+
-		"\u01a3\u01a4\u0005l\u0000\u0000\u01a4\u01a5\u0005_\u0000\u0000\u01a5\u01a6"+
-		"\u0005o\u0000\u0000\u01a6\u01a7\u0005r\u0000\u0000\u01a7\u01a8\u0005i"+
-		"\u0000\u0000\u01a8\u01a9\u0005g\u0000\u0000\u01a9\u01aa\u0005i\u0000\u0000"+
-		"\u01aa\u03ed\u0005n\u0000\u0000\u01ab\u01ac\u0005r\u0000\u0000\u01ac\u01ad"+
-		"\u0005e\u0000\u0000\u01ad\u01ae\u0005q\u0000\u0000\u01ae\u01af\u0005_"+
-		"\u0000\u0000\u01af\u01b0\u0005i\u0000\u0000\u01b0\u03ed\u0005d\u0000\u0000"+
-		"\u01b1\u01b2\u0005r\u0000\u0000\u01b2\u01b3\u0005e\u0000\u0000\u01b3\u01b4"+
-		"\u0005q\u0000\u0000\u01b4\u01b5\u0005_\u0000\u0000\u01b5\u01b6\u0005t"+
-		"\u0000\u0000\u01b6\u01b7\u0005e\u0000\u0000\u01b7\u01b8\u0005x\u0000\u0000"+
-		"\u01b8\u03ed\u0005t\u0000\u0000\u01b9\u01ba\u0005r\u0000\u0000\u01ba\u01bb"+
-		"\u0005e\u0000\u0000\u01bb\u01bc\u0005q\u0000\u0000\u01bc\u01bd\u0005_"+
-		"\u0000\u0000\u01bd\u01be\u0005t\u0000\u0000\u01be\u01bf\u0005s\u0000\u0000"+
-		"\u01bf\u01c0\u0005t\u0000\u0000\u01c0\u01c1\u0005a\u0000\u0000\u01c1\u01c2"+
-		"\u0005m\u0000\u0000\u01c2\u03ed\u0005p\u0000\u0000\u01c3\u01c4\u0005u"+
-		"\u0000\u0000\u01c4\u01c5\u0005s\u0000\u0000\u01c5\u01c6\u0005e\u0000\u0000"+
-		"\u01c6\u01c7\u0005r\u0000\u0000\u01c7\u01c8\u0005_\u0000\u0000\u01c8\u01c9"+
-		"\u0005i\u0000\u0000\u01c9\u03ed\u0005d\u0000\u0000\u01ca\u01cb\u0005t"+
-		"\u0000\u0000\u01cb\u01cc\u0005r\u0000\u0000\u01cc\u01cd\u0005i\u0000\u0000"+
-		"\u01cd\u03ed\u0005m\u0000\u0000\u01ce\u01cf\u0005r\u0000\u0000\u01cf\u01d0"+
-		"\u0005e\u0000\u0000\u01d0\u01d1\u0005g\u0000\u0000\u01d1\u01d2\u0005e"+
-		"\u0000\u0000\u01d2\u03ed\u0005x\u0000\u0000\u01d3\u01d4\u0005s\u0000\u0000"+
-		"\u01d4\u01d5\u0005t\u0000\u0000\u01d5\u01d6\u0005r\u0000\u0000\u01d6\u01d7"+
-		"\u0005i\u0000\u0000\u01d7\u03ed\u0005p\u0000\u0000\u01d8\u01d9\u0005u"+
-		"\u0000\u0000\u01d9\u01da\u0005p\u0000\u0000\u01da\u01db\u0005p\u0000\u0000"+
-		"\u01db\u01dc\u0005e\u0000\u0000\u01dc\u01dd\u0005r\u0000\u0000\u01dd\u01de"+
-		"\u0005c\u0000\u0000\u01de\u01df\u0005a\u0000\u0000\u01df\u01e0\u0005s"+
-		"\u0000\u0000\u01e0\u03ed\u0005e\u0000\u0000\u01e1\u01e2\u0005l\u0000\u0000"+
-		"\u01e2\u01e3\u0005o\u0000\u0000\u01e3\u01e4\u0005w\u0000\u0000\u01e4\u01e5"+
-		"\u0005e\u0000\u0000\u01e5\u01e6\u0005r\u0000\u0000\u01e6\u01e7\u0005c"+
-		"\u0000\u0000\u01e7\u01e8\u0005a\u0000\u0000\u01e8\u01e9\u0005s\u0000\u0000"+
-		"\u01e9\u03ed\u0005e\u0000\u0000\u01ea\u01eb\u0005i\u0000\u0000\u01eb\u01ec"+
-		"\u0005s\u0000\u0000\u01ec\u01ed\u0005_\u0000\u0000\u01ed\u01ee\u0005a"+
-		"\u0000\u0000\u01ee\u01ef\u0005l\u0000\u0000\u01ef\u01f0\u0005p\u0000\u0000"+
-		"\u01f0\u01f1\u0005h\u0000\u0000\u01f1\u03ed\u0005a\u0000\u0000\u01f2\u01f3"+
-		"\u0005i\u0000\u0000\u01f3\u01f4\u0005s\u0000\u0000\u01f4\u01f5\u0005_"+
-		"\u0000\u0000\u01f5\u01f6\u0005a\u0000\u0000\u01f6\u01f7\u0005l\u0000\u0000"+
-		"\u01f7\u01f8\u0005p\u0000\u0000\u01f8\u01f9\u0005h\u0000\u0000\u01f9\u01fa"+
-		"\u0005a\u0000\u0000\u01fa\u01fb\u0005n\u0000\u0000\u01fb\u01fc\u0005u"+
-		"\u0000\u0000\u01fc\u03ed\u0005m\u0000\u0000\u01fd\u01fe\u0005i\u0000\u0000"+
-		"\u01fe\u01ff\u0005s\u0000\u0000\u01ff\u0200\u0005_\u0000\u0000\u0200\u0201"+
-		"\u0005w\u0000\u0000\u0201\u0202\u0005h\u0000\u0000\u0202\u0203\u0005i"+
-		"\u0000\u0000\u0203\u0204\u0005t\u0000\u0000\u0204\u0205\u0005e\u0000\u0000"+
-		"\u0205\u0206\u0005s\u0000\u0000\u0206\u0207\u0005p\u0000\u0000\u0207\u0208"+
-		"\u0005a\u0000\u0000\u0208\u0209\u0005c\u0000\u0000\u0209\u03ed\u0005e"+
-		"\u0000\u0000\u020a\u020b\u0005i\u0000\u0000\u020b\u020c\u0005s\u0000\u0000"+
-		"\u020c\u020d\u0005_\u0000\u0000\u020d\u020e\u0005n\u0000\u0000\u020e\u020f"+
-		"\u0005u\u0000\u0000\u020f\u03ed\u0005m\u0000\u0000\u0210\u0211\u0005i"+
-		"\u0000\u0000\u0211\u0212\u0005s\u0000\u0000\u0212\u0213\u0005_\u0000\u0000"+
-		"\u0213\u0214\u0005n\u0000\u0000\u0214\u0215\u0005u\u0000\u0000\u0215\u0216"+
-		"\u0005m\u0000\u0000\u0216\u0217\u0005s\u0000\u0000\u0217\u0218\u0005p"+
-		"\u0000\u0000\u0218\u0219\u0005a\u0000\u0000\u0219\u021a\u0005c\u0000\u0000"+
-		"\u021a\u03ed\u0005e\u0000\u0000\u021b\u021c\u0005i\u0000\u0000\u021c\u021d"+
-		"\u0005s\u0000\u0000\u021d\u021e\u0005_\u0000\u0000\u021e\u021f\u0005a"+
-		"\u0000\u0000\u021f\u0220\u0005l\u0000\u0000\u0220\u0221\u0005p\u0000\u0000"+
-		"\u0221\u0222\u0005h\u0000\u0000\u0222\u0223\u0005a\u0000\u0000\u0223\u0224"+
-		"\u0005s\u0000\u0000\u0224\u0225\u0005p\u0000\u0000\u0225\u0226\u0005a"+
-		"\u0000\u0000\u0226\u0227\u0005c\u0000\u0000\u0227\u03ed\u0005e\u0000\u0000"+
-		"\u0228\u0229\u0005i\u0000\u0000\u0229\u022a\u0005s\u0000\u0000\u022a\u022b"+
-		"\u0005_\u0000\u0000\u022b\u022c\u0005a\u0000\u0000\u022c\u022d\u0005l"+
-		"\u0000\u0000\u022d\u022e\u0005p\u0000\u0000\u022e\u022f\u0005h\u0000\u0000"+
-		"\u022f\u0230\u0005a\u0000\u0000\u0230\u0231\u0005n\u0000\u0000\u0231\u0232"+
-		"\u0005u\u0000\u0000\u0232\u0233\u0005m\u0000\u0000\u0233\u0234\u0005s"+
-		"\u0000\u0000\u0234\u0235\u0005p\u0000\u0000\u0235\u0236\u0005a\u0000\u0000"+
-		"\u0236\u0237\u0005c\u0000\u0000\u0237\u03ed\u0005e\u0000\u0000\u0238\u0239"+
-		"\u0005s\u0000\u0000\u0239\u023a\u0005p\u0000\u0000\u023a\u023b\u0005l"+
-		"\u0000\u0000\u023b\u023c\u0005i\u0000\u0000\u023c\u03ed\u0005t\u0000\u0000"+
-		"\u023d\u023e\u0005s\u0000\u0000\u023e\u023f\u0005p\u0000\u0000\u023f\u0240"+
-		"\u0005l\u0000\u0000\u0240\u0241\u0005i\u0000\u0000\u0241\u0242\u0005t"+
-		"\u0000\u0000\u0242\u0243\u0005_\u0000\u0000\u0243\u0244\u0005t\u0000\u0000"+
-		"\u0244\u0245\u0005r\u0000\u0000\u0245\u0246\u0005i\u0000\u0000\u0246\u03ed"+
-		"\u0005m\u0000\u0000\u0247\u0248\u0005s\u0000\u0000\u0248\u0249\u0005t"+
-		"\u0000\u0000\u0249\u024a\u0005a\u0000\u0000\u024a\u024b\u0005r\u0000\u0000"+
-		"\u024b\u024c\u0005t\u0000\u0000\u024c\u024d\u0005s\u0000\u0000\u024d\u024e"+
-		"\u0005_\u0000\u0000\u024e\u024f\u0005w\u0000\u0000\u024f\u0250\u0005i"+
-		"\u0000\u0000\u0250\u0251\u0005t\u0000\u0000\u0251\u03ed\u0005h\u0000\u0000"+
-		"\u0252\u0253\u0005e\u0000\u0000\u0253\u0254\u0005n\u0000\u0000\u0254\u0255"+
-		"\u0005d\u0000\u0000\u0255\u0256\u0005s\u0000\u0000\u0256\u0257\u0005_"+
-		"\u0000\u0000\u0257\u0258\u0005w\u0000\u0000\u0258\u0259\u0005i\u0000\u0000"+
-		"\u0259\u025a\u0005t\u0000\u0000\u025a\u03ed\u0005h\u0000\u0000\u025b\u025c"+
-		"\u0005i\u0000\u0000\u025c\u025d\u0005n\u0000\u0000\u025d\u025e\u0005d"+
-		"\u0000\u0000\u025e\u025f\u0005e\u0000\u0000\u025f\u0260\u0005x\u0000\u0000"+
-		"\u0260\u0261\u0005_\u0000\u0000\u0261\u0262\u0005o\u0000\u0000\u0262\u03ed"+
-		"\u0005f\u0000\u0000\u0263\u0264\u0005c\u0000\u0000\u0264\u0265\u0005o"+
-		"\u0000\u0000\u0265\u0266\u0005n\u0000\u0000\u0266\u0267\u0005t\u0000\u0000"+
-		"\u0267\u0268\u0005a\u0000\u0000\u0268\u0269\u0005i\u0000\u0000\u0269\u026a"+
-		"\u0005n\u0000\u0000\u026a\u03ed\u0005s\u0000\u0000\u026b\u026c\u0005s"+
-		"\u0000\u0000\u026c\u026d\u0005u\u0000\u0000\u026d\u026e\u0005b\u0000\u0000"+
-		"\u026e\u026f\u0005s\u0000\u0000\u026f\u0270\u0005t\u0000\u0000\u0270\u03ed"+
-		"\u0005r\u0000\u0000\u0271\u0272\u0005r\u0000\u0000\u0272\u0273\u0005e"+
-		"\u0000\u0000\u0273\u0274\u0005p\u0000\u0000\u0274\u0275\u0005l\u0000\u0000"+
-		"\u0275\u0276\u0005a\u0000\u0000\u0276\u0277\u0005c\u0000\u0000\u0277\u03ed"+
-		"\u0005e\u0000\u0000\u0278\u0279\u0005a\u0000\u0000\u0279\u027a\u0005b"+
-		"\u0000\u0000\u027a\u03ed\u0005s\u0000\u0000\u027b\u027c\u0005c\u0000\u0000"+
-		"\u027c\u027d\u0005e\u0000\u0000\u027d\u027e\u0005i\u0000\u0000\u027e\u03ed"+
-		"\u0005l\u0000\u0000\u027f\u0280\u0005f\u0000\u0000\u0280\u0281\u0005l"+
-		"\u0000\u0000\u0281\u0282\u0005o\u0000\u0000\u0282\u0283\u0005o\u0000\u0000"+
-		"\u0283\u03ed\u0005r\u0000\u0000\u0284\u0285\u0005r\u0000\u0000\u0285\u0286"+
-		"\u0005i\u0000\u0000\u0286\u0287\u0005n\u0000\u0000\u0287\u03ed\u0005t"+
-		"\u0000\u0000\u0288\u0289\u0005r\u0000\u0000\u0289\u028a\u0005o\u0000\u0000"+
-		"\u028a\u028b\u0005u\u0000\u0000\u028b\u028c\u0005n\u0000\u0000\u028c\u03ed"+
-		"\u0005d\u0000\u0000\u028d\u028e\u0005s\u0000\u0000\u028e\u028f\u0005i"+
-		"\u0000\u0000\u028f\u0290\u0005g\u0000\u0000\u0290\u0291\u0005n\u0000\u0000"+
-		"\u0291\u0292\u0005u\u0000\u0000\u0292\u03ed\u0005m\u0000\u0000\u0293\u0294"+
-		"\u0005s\u0000\u0000\u0294\u0295\u0005q\u0000\u0000\u0295\u0296\u0005r"+
-		"\u0000\u0000\u0296\u03ed\u0005t\u0000\u0000\u0297\u0298\u0005c\u0000\u0000"+
-		"\u0298\u0299\u0005b\u0000\u0000\u0299\u029a\u0005r\u0000\u0000\u029a\u03ed"+
-		"\u0005t\u0000\u0000\u029b\u029c\u0005p\u0000\u0000\u029c\u03ed\u0005i"+
-		"\u0000\u0000\u029d\u029e\u0005t\u0000\u0000\u029e\u029f\u0005o\u0000\u0000"+
-		"\u029f\u02a0\u0005_\u0000\u0000\u02a0\u02a1\u0005d\u0000\u0000\u02a1\u02a2"+
-		"\u0005o\u0000\u0000\u02a2\u02a3\u0005u\u0000\u0000\u02a3\u02a4\u0005b"+
-		"\u0000\u0000\u02a4\u02a5\u0005l\u0000\u0000\u02a5\u03ed\u0005e\u0000\u0000"+
-		"\u02a6\u02a7\u0005t\u0000\u0000\u02a7\u02a8\u0005o\u0000\u0000\u02a8\u02a9"+
-		"\u0005_\u0000\u0000\u02a9\u02aa\u0005i\u0000\u0000\u02aa\u02ab\u0005n"+
-		"\u0000\u0000\u02ab\u03ed\u0005t\u0000\u0000\u02ac\u02ad\u0005e\u0000\u0000"+
-		"\u02ad\u02ae\u0005u\u0000\u0000\u02ae\u02af\u0005l\u0000\u0000\u02af\u02b0"+
-		"\u0005e\u0000\u0000\u02b0\u03ed\u0005r\u0000\u0000\u02b1\u02b2\u0005a"+
-		"\u0000\u0000\u02b2\u02b3\u0005c\u0000\u0000\u02b3\u02b4\u0005o\u0000\u0000"+
-		"\u02b4\u03ed\u0005s\u0000\u0000\u02b5\u02b6\u0005a\u0000\u0000\u02b6\u02b7"+
-		"\u0005s\u0000\u0000\u02b7\u02b8\u0005i\u0000\u0000\u02b8\u03ed\u0005n"+
-		"\u0000\u0000\u02b9\u02ba\u0005a\u0000\u0000\u02ba\u02bb\u0005t\u0000\u0000"+
-		"\u02bb\u02bc\u0005a\u0000\u0000\u02bc\u03ed\u0005n\u0000\u0000\u02bd\u02be"+
-		"\u0005c\u0000\u0000\u02be\u02bf\u0005o\u0000\u0000\u02bf\u03ed\u0005s"+
-		"\u0000\u0000\u02c0\u02c1\u0005s\u0000\u0000\u02c1\u02c2\u0005i\u0000\u0000"+
-		"\u02c2\u03ed\u0005n\u0000\u0000\u02c3\u02c4\u0005t\u0000\u0000\u02c4\u02c5"+
-		"\u0005a\u0000\u0000\u02c5\u03ed\u0005n\u0000\u0000\u02c6\u02c7\u0005c"+
-		"\u0000\u0000\u02c7\u02c8\u0005o\u0000\u0000\u02c8\u02c9\u0005s\u0000\u0000"+
-		"\u02c9\u03ed\u0005h\u0000\u0000\u02ca\u02cb\u0005s\u0000\u0000\u02cb\u02cc"+
-		"\u0005i\u0000\u0000\u02cc\u02cd\u0005n\u0000\u0000\u02cd\u03ed\u0005h"+
-		"\u0000\u0000\u02ce\u02cf\u0005t\u0000\u0000\u02cf\u02d0\u0005a\u0000\u0000"+
-		"\u02d0\u02d1\u0005n\u0000\u0000\u02d1\u03ed\u0005h\u0000\u0000\u02d2\u02d3"+
-		"\u0005a\u0000\u0000\u02d3\u02d4\u0005t\u0000\u0000\u02d4\u02d5\u0005a"+
-		"\u0000\u0000\u02d5\u02d6\u0005n\u0000\u0000\u02d6\u03ed\u00052\u0000\u0000"+
-		"\u02d7\u02d8\u0005d\u0000\u0000\u02d8\u02d9\u0005e\u0000\u0000\u02d9\u02da"+
-		"\u0005g\u0000\u0000\u02da\u02db\u0005r\u0000\u0000\u02db\u02dc\u0005e"+
-		"\u0000\u0000\u02dc\u02dd\u0005e\u0000\u0000\u02dd\u03ed\u0005s\u0000\u0000"+
-		"\u02de\u02df\u0005r\u0000\u0000\u02df\u02e0\u0005a\u0000\u0000\u02e0\u02e1"+
-		"\u0005d\u0000\u0000\u02e1\u02e2\u0005i\u0000\u0000\u02e2\u02e3\u0005a"+
-		"\u0000\u0000\u02e3\u02e4\u0005n\u0000\u0000\u02e4\u03ed\u0005s\u0000\u0000"+
-		"\u02e5\u02e6\u0005e\u0000\u0000\u02e6\u02e7\u0005x\u0000\u0000\u02e7\u03ed"+
-		"\u0005p\u0000\u0000\u02e8\u02e9\u0005e\u0000\u0000\u02e9\u02ea\u0005x"+
-		"\u0000\u0000\u02ea\u02eb\u0005p\u0000\u0000\u02eb\u02ec\u0005m\u0000\u0000"+
-		"\u02ec\u03ed\u00051\u0000\u0000\u02ed\u02ee\u0005h\u0000\u0000\u02ee\u02ef"+
-		"\u0005y\u0000\u0000\u02ef\u02f0\u0005p\u0000\u0000\u02f0\u02f1\u0005o"+
-		"\u0000\u0000\u02f1\u03ed\u0005t\u0000\u0000\u02f2\u02f3\u0005l\u0000\u0000"+
-		"\u02f3\u02f4\u0005o\u0000\u0000\u02f4\u03ed\u0005g\u0000\u0000\u02f5\u02f6"+
-		"\u0005l\u0000\u0000\u02f6\u02f7\u0005o\u0000\u0000\u02f7\u02f8\u0005g"+
-		"\u0000\u0000\u02f8\u02f9\u00051\u0000\u0000\u02f9\u03ed\u00050\u0000\u0000"+
-		"\u02fa\u02fb\u0005l\u0000\u0000\u02fb\u02fc\u0005o\u0000\u0000\u02fc\u02fd"+
-		"\u0005g\u0000\u0000\u02fd\u02fe\u00051\u0000\u0000\u02fe\u03ed\u0005p"+
-		"\u0000\u0000\u02ff\u0300\u0005p\u0000\u0000\u0300\u0301\u0005o\u0000\u0000"+
-		"\u0301\u03ed\u0005w\u0000\u0000\u0302\u0303\u0005r\u0000\u0000\u0303\u0304"+
-		"\u0005a\u0000\u0000\u0304\u0305\u0005n\u0000\u0000\u0305\u03ed\u0005d"+
-		"\u0000\u0000\u0306\u0307\u0005s\u0000\u0000\u0307\u0308\u0005q\u0000\u0000"+
-		"\u0308\u0309\u0005u\u0000\u0000\u0309\u030a\u0005a\u0000\u0000\u030a\u030b"+
-		"\u0005r\u0000\u0000\u030b\u03ed\u0005e\u0000\u0000\u030c\u030d\u0005l"+
-		"\u0000\u0000\u030d\u030e\u0005i\u0000\u0000\u030e\u030f\u0005s\u0000\u0000"+
-		"\u030f\u03ed\u0005t\u0000\u0000\u0310\u0311\u0005g\u0000\u0000\u0311\u0312"+
-		"\u0005e\u0000\u0000\u0312\u03ed\u0005t\u0000\u0000\u0313\u0314\u0005h"+
-		"\u0000\u0000\u0314\u0315\u0005a\u0000\u0000\u0315\u03ed\u0005s\u0000\u0000"+
-		"\u0316\u0317\u0005h\u0000\u0000\u0317\u0318\u0005a\u0000\u0000\u0318\u0319"+
-		"\u0005s\u0000\u0000\u0319\u031a\u0005_\u0000\u0000\u031a\u031b\u0005a"+
-		"\u0000\u0000\u031b\u031c\u0005n\u0000\u0000\u031c\u03ed\u0005y\u0000\u0000"+
-		"\u031d\u031e\u0005h\u0000\u0000\u031e\u031f\u0005a\u0000\u0000\u031f\u0320"+
-		"\u0005s\u0000\u0000\u0320\u0321\u0005_\u0000\u0000\u0321\u0322\u0005a"+
-		"\u0000\u0000\u0322\u0323\u0005l\u0000\u0000\u0323\u03ed\u0005l\u0000\u0000"+
-		"\u0324\u0325\u0005f\u0000\u0000\u0325\u0326\u0005i\u0000\u0000\u0326\u0327"+
-		"\u0005r\u0000\u0000\u0327\u0328\u0005s\u0000\u0000\u0328\u03ed\u0005t"+
-		"\u0000\u0000\u0329\u032a\u0005l\u0000\u0000\u032a\u032b\u0005a\u0000\u0000"+
-		"\u032b\u032c\u0005s\u0000\u0000\u032c\u03ed\u0005t\u0000\u0000\u032d\u032e"+
-		"\u0005k\u0000\u0000\u032e\u032f\u0005e\u0000\u0000\u032f\u0330\u0005y"+
-		"\u0000\u0000\u0330\u03ed\u0005s\u0000\u0000\u0331\u0332\u0005v\u0000\u0000"+
-		"\u0332\u0333\u0005a\u0000\u0000\u0333\u0334\u0005l\u0000\u0000\u0334\u0335"+
-		"\u0005u\u0000\u0000\u0335\u0336\u0005e\u0000\u0000\u0336\u03ed\u0005s"+
-		"\u0000\u0000\u0337\u0338\u0005l\u0000\u0000\u0338\u0339\u0005e\u0000\u0000"+
-		"\u0339\u033a\u0005n\u0000\u0000\u033a\u033b\u0005g\u0000\u0000\u033b\u033c"+
-		"\u0005t\u0000\u0000\u033c\u03ed\u0005h\u0000\u0000\u033d\u033e\u0005c"+
-		"\u0000\u0000\u033e\u033f\u0005o\u0000\u0000\u033f\u0340\u0005u\u0000\u0000"+
-		"\u0340\u0341\u0005n\u0000\u0000\u0341\u03ed\u0005t\u0000\u0000\u0342\u0343"+
-		"\u0005s\u0000\u0000\u0343\u0344\u0005i\u0000\u0000\u0344\u0345\u0005z"+
-		"\u0000\u0000\u0345\u03ed\u0005e\u0000\u0000\u0346\u0347\u0005s\u0000\u0000"+
-		"\u0347\u0348\u0005o\u0000\u0000\u0348\u0349\u0005r\u0000\u0000\u0349\u03ed"+
-		"\u0005t\u0000\u0000\u034a\u034b\u0005r\u0000\u0000\u034b\u034c\u0005e"+
-		"\u0000\u0000\u034c\u034d\u0005v\u0000\u0000\u034d\u034e\u0005e\u0000\u0000"+
-		"\u034e\u034f\u0005r\u0000\u0000\u034f\u0350\u0005s\u0000\u0000\u0350\u03ed"+
-		"\u0005e\u0000\u0000\u0351\u0352\u0005i\u0000\u0000\u0352\u0353\u0005s"+
-		"\u0000\u0000\u0353\u0354\u0005_\u0000\u0000\u0354\u0355\u0005e\u0000\u0000"+
-		"\u0355\u0356\u0005m\u0000\u0000\u0356\u0357\u0005p\u0000\u0000\u0357\u0358"+
-		"\u0005t\u0000\u0000\u0358\u03ed\u0005y\u0000\u0000\u0359\u035a\u0005n"+
-		"\u0000\u0000\u035a\u035b\u0005o\u0000\u0000\u035b\u035c\u0005n\u0000\u0000"+
-		"\u035c\u035d\u0005_\u0000\u0000\u035d\u035e\u0005e\u0000\u0000\u035e\u035f"+
-		"\u0005m\u0000\u0000\u035f\u0360\u0005p\u0000\u0000\u0360\u0361\u0005t"+
-		"\u0000\u0000\u0361\u03ed\u0005y\u0000\u0000\u0362\u0363\u0005d\u0000\u0000"+
-		"\u0363\u0364\u0005i\u0000\u0000\u0364\u0365\u0005s\u0000\u0000\u0365\u0366"+
-		"\u0005t\u0000\u0000\u0366\u0367\u0005i\u0000\u0000\u0367\u0368\u0005n"+
-		"\u0000\u0000\u0368\u0369\u0005c\u0000\u0000\u0369\u03ed\u0005t\u0000\u0000"+
-		"\u036a\u036b\u0005c\u0000\u0000\u036b\u036c\u0005o\u0000\u0000\u036c\u036d"+
-		"\u0005n\u0000\u0000\u036d\u036e\u0005c\u0000\u0000\u036e\u036f\u0005a"+
-		"\u0000\u0000\u036f\u03ed\u0005t\u0000\u0000\u0370\u0371\u0005t\u0000\u0000"+
-		"\u0371\u0372\u0005o\u0000\u0000\u0372\u0373\u0005_\u0000\u0000\u0373\u0374"+
-		"\u0005s\u0000\u0000\u0374\u0375\u0005t\u0000\u0000\u0375\u0376\u0005r"+
-		"\u0000\u0000\u0376\u0377\u0005i\u0000\u0000\u0377\u0378\u0005n\u0000\u0000"+
-		"\u0378\u03ed\u0005g\u0000\u0000\u0379\u037a\u0005m\u0000\u0000\u037a\u037b"+
-		"\u0005a\u0000\u0000\u037b\u03ed\u0005x\u0000\u0000\u037c\u037d\u0005m"+
-		"\u0000\u0000\u037d\u037e\u0005i\u0000\u0000\u037e\u03ed\u0005n\u0000\u0000"+
-		"\u037f\u0380\u0005a\u0000\u0000\u0380\u0381\u0005v\u0000\u0000\u0381\u03ed"+
-		"\u0005g\u0000\u0000\u0382\u0383\u0005s\u0000\u0000\u0383\u0384\u0005t"+
-		"\u0000\u0000\u0384\u0385\u0005d\u0000\u0000\u0385\u0386\u0005e\u0000\u0000"+
-		"\u0386\u03ed\u0005v\u0000\u0000\u0387\u0388\u0005y\u0000\u0000\u0388\u0389"+
-		"\u0005e\u0000\u0000\u0389\u038a\u0005a\u0000\u0000\u038a\u03ed\u0005r"+
-		"\u0000\u0000\u038b\u038c\u0005m\u0000\u0000\u038c\u038d\u0005o\u0000\u0000"+
-		"\u038d\u038e\u0005n\u0000\u0000\u038e\u038f\u0005t\u0000\u0000\u038f\u03ed"+
-		"\u0005h\u0000\u0000\u0390\u0391\u0005d\u0000\u0000\u0391\u0392\u0005a"+
-		"\u0000\u0000\u0392\u0393\u0005y\u0000\u0000\u0393\u0394\u0005_\u0000\u0000"+
-		"\u0394\u0395\u0005o\u0000\u0000\u0395\u0396\u0005f\u0000\u0000\u0396\u0397"+
-		"\u0005_\u0000\u0000\u0397\u0398\u0005m\u0000\u0000\u0398\u0399\u0005o"+
-		"\u0000\u0000\u0399\u039a\u0005n\u0000\u0000\u039a\u039b\u0005t\u0000\u0000"+
-		"\u039b\u03ed\u0005h\u0000\u0000\u039c\u039d\u0005d\u0000\u0000\u039d\u039e"+
-		"\u0005a\u0000\u0000\u039e\u039f\u0005y\u0000\u0000\u039f\u03a0\u0005_"+
-		"\u0000\u0000\u03a0\u03a1\u0005o\u0000\u0000\u03a1\u03a2\u0005f\u0000\u0000"+
-		"\u03a2\u03a3\u0005_\u0000\u0000\u03a3\u03a4\u0005w\u0000\u0000\u03a4\u03a5"+
-		"\u0005e\u0000\u0000\u03a5\u03a6\u0005e\u0000\u0000\u03a6\u03ed\u0005k"+
-		"\u0000\u0000\u03a7\u03a8\u0005d\u0000\u0000\u03a8\u03a9\u0005a\u0000\u0000"+
-		"\u03a9\u03aa\u0005y\u0000\u0000\u03aa\u03ab\u0005_\u0000\u0000\u03ab\u03ac"+
-		"\u0005o\u0000\u0000\u03ac\u03ad\u0005f\u0000\u0000\u03ad\u03ae\u0005_"+
-		"\u0000\u0000\u03ae\u03af\u0005y\u0000\u0000\u03af\u03b0\u0005e\u0000\u0000"+
-		"\u03b0\u03b1\u0005a\u0000\u0000\u03b1\u03ed\u0005r\u0000\u0000\u03b2\u03b3"+
-		"\u0005h\u0000\u0000\u03b3\u03b4\u0005o\u0000\u0000\u03b4\u03b5\u0005u"+
-		"\u0000\u0000\u03b5\u03ed\u0005r\u0000\u0000\u03b6\u03b7\u0005m\u0000\u0000"+
-		"\u03b7\u03b8\u0005i\u0000\u0000\u03b8\u03b9\u0005n\u0000\u0000\u03b9\u03ba"+
-		"\u0005u\u0000\u0000\u03ba\u03bb\u0005t\u0000\u0000\u03bb\u03ed\u0005e"+
-		"\u0000\u0000\u03bc\u03bd\u0005s\u0000\u0000\u03bd\u03be\u0005e\u0000\u0000"+
-		"\u03be\u03bf\u0005c\u0000\u0000\u03bf\u03c0\u0005o\u0000\u0000\u03c0\u03c1"+
-		"\u0005n\u0000\u0000\u03c1\u03ed\u0005d\u0000\u0000\u03c2\u03c3\u0005w"+
-		"\u0000\u0000\u03c3\u03c4\u0005e\u0000\u0000\u03c4\u03c5\u0005e\u0000\u0000"+
-		"\u03c5\u03c6\u0005k\u0000\u0000\u03c6\u03c7\u0005_\u0000\u0000\u03c7\u03c8"+
-		"\u0005o\u0000\u0000\u03c8\u03c9\u0005f\u0000\u0000\u03c9\u03ca\u0005_"+
-		"\u0000\u0000\u03ca\u03cb\u0005m\u0000\u0000\u03cb\u03cc\u0005o\u0000\u0000"+
-		"\u03cc\u03cd\u0005n\u0000\u0000\u03cd\u03ce\u0005t\u0000\u0000\u03ce\u03ed"+
-		"\u0005h\u0000\u0000\u03cf\u03d0\u0005w\u0000\u0000\u03d0\u03d1\u0005e"+
-		"\u0000\u0000\u03d1\u03d2\u0005e\u0000\u0000\u03d2\u03d3\u0005k\u0000\u0000"+
-		"\u03d3\u03d4\u0005_\u0000\u0000\u03d4\u03d5\u0005o\u0000\u0000\u03d5\u03d6"+
-		"\u0005f\u0000\u0000\u03d6\u03d7\u0005_\u0000\u0000\u03d7\u03d8\u0005y"+
-		"\u0000\u0000\u03d8\u03d9\u0005e\u0000\u0000\u03d9\u03da\u0005a\u0000\u0000"+
-		"\u03da\u03ed\u0005r\u0000\u0000\u03db\u03dc\u0005q\u0000\u0000\u03dc\u03dd"+
-		"\u0005u\u0000\u0000\u03dd\u03de\u0005a\u0000\u0000\u03de\u03df\u0005r"+
-		"\u0000\u0000\u03df\u03e0\u0005t\u0000\u0000\u03e0\u03e1\u0005e\u0000\u0000"+
-		"\u03e1\u03ed\u0005r\u0000\u0000\u03e2\u03e3\u0005n\u0000\u0000\u03e3\u03e4"+
-		"\u0005o\u0000\u0000\u03e4\u03ed\u0005w\u0000\u0000\u03e5\u03e6\u0005o"+
-		"\u0000\u0000\u03e6\u03e7\u0005r\u0000\u0000\u03e7\u03e8\u0005_\u0000\u0000"+
-		"\u03e8\u03e9\u0005e\u0000\u0000\u03e9\u03ea\u0005l\u0000\u0000\u03ea\u03eb"+
-		"\u0005s\u0000\u0000\u03eb\u03ed\u0005e\u0000\u0000\u03ecm\u0001\u0000"+
-		"\u0000\u0000\u03ecu\u0001\u0000\u0000\u0000\u03ec}\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0088\u0001\u0000\u0000\u0000\u03ec\u0090\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0098\u0001\u0000\u0000\u0000\u03ec\u00a1\u0001\u0000\u0000\u0000"+
-		"\u03ec\u00aa\u0001\u0000\u0000\u0000\u03ec\u00ae\u0001\u0000\u0000\u0000"+
-		"\u03ec\u00b0\u0001\u0000\u0000\u0000\u03ec\u00b8\u0001\u0000\u0000\u0000"+
-		"\u03ec\u00c1\u0001\u0000\u0000\u0000\u03ec\u00c9\u0001\u0000\u0000\u0000"+
-		"\u03ec\u00d3\u0001\u0000\u0000\u0000\u03ec\u00dc\u0001\u0000\u0000\u0000"+
-		"\u03ec\u00e3\u0001\u0000\u0000\u0000\u03ec\u00f1\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0102\u0001\u0000\u0000\u0000\u03ec\u010a\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0115\u0001\u0000\u0000\u0000\u03ec\u0121\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0131\u0001\u0000\u0000\u0000\u03ec\u0144\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0153\u0001\u0000\u0000\u0000\u03ec\u0165\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0177\u0001\u0000\u0000\u0000\u03ec\u018c\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0192\u0001\u0000\u0000\u0000\u03ec\u019a\u0001\u0000\u0000\u0000"+
-		"\u03ec\u01a1\u0001\u0000\u0000\u0000\u03ec\u01ab\u0001\u0000\u0000\u0000"+
-		"\u03ec\u01b1\u0001\u0000\u0000\u0000\u03ec\u01b9\u0001\u0000\u0000\u0000"+
-		"\u03ec\u01c3\u0001\u0000\u0000\u0000\u03ec\u01ca\u0001\u0000\u0000\u0000"+
-		"\u03ec\u01ce\u0001\u0000\u0000\u0000\u03ec\u01d3\u0001\u0000\u0000\u0000"+
-		"\u03ec\u01d8\u0001\u0000\u0000\u0000\u03ec\u01e1\u0001\u0000\u0000\u0000"+
-		"\u03ec\u01ea\u0001\u0000\u0000\u0000\u03ec\u01f2\u0001\u0000\u0000\u0000"+
-		"\u03ec\u01fd\u0001\u0000\u0000\u0000\u03ec\u020a\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0210\u0001\u0000\u0000\u0000\u03ec\u021b\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0228\u0001\u0000\u0000\u0000\u03ec\u0238\u0001\u0000\u0000\u0000"+
-		"\u03ec\u023d\u0001\u0000\u0000\u0000\u03ec\u0247\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0252\u0001\u0000\u0000\u0000\u03ec\u025b\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0263\u0001\u0000\u0000\u0000\u03ec\u026b\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0271\u0001\u0000\u0000\u0000\u03ec\u0278\u0001\u0000\u0000\u0000"+
-		"\u03ec\u027b\u0001\u0000\u0000\u0000\u03ec\u027f\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0284\u0001\u0000\u0000\u0000\u03ec\u0288\u0001\u0000\u0000\u0000"+
-		"\u03ec\u028d\u0001\u0000\u0000\u0000\u03ec\u0293\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0297\u0001\u0000\u0000\u0000\u03ec\u029b\u0001\u0000\u0000\u0000"+
-		"\u03ec\u029d\u0001\u0000\u0000\u0000\u03ec\u02a6\u0001\u0000\u0000\u0000"+
-		"\u03ec\u02ac\u0001\u0000\u0000\u0000\u03ec\u02b1\u0001\u0000\u0000\u0000"+
-		"\u03ec\u02b5\u0001\u0000\u0000\u0000\u03ec\u02b9\u0001\u0000\u0000\u0000"+
-		"\u03ec\u02bd\u0001\u0000\u0000\u0000\u03ec\u02c0\u0001\u0000\u0000\u0000"+
-		"\u03ec\u02c3\u0001\u0000\u0000\u0000\u03ec\u02c6\u0001\u0000\u0000\u0000"+
-		"\u03ec\u02ca\u0001\u0000\u0000\u0000\u03ec\u02ce\u0001\u0000\u0000\u0000"+
-		"\u03ec\u02d2\u0001\u0000\u0000\u0000\u03ec\u02d7\u0001\u0000\u0000\u0000"+
-		"\u03ec\u02de\u0001\u0000\u0000\u0000\u03ec\u02e5\u0001\u0000\u0000\u0000"+
-		"\u03ec\u02e8\u0001\u0000\u0000\u0000\u03ec\u02ed\u0001\u0000\u0000\u0000"+
-		"\u03ec\u02f2\u0001\u0000\u0000\u0000\u03ec\u02f5\u0001\u0000\u0000\u0000"+
-		"\u03ec\u02fa\u0001\u0000\u0000\u0000\u03ec\u02ff\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0302\u0001\u0000\u0000\u0000\u03ec\u0306\u0001\u0000\u0000\u0000"+
-		"\u03ec\u030c\u0001\u0000\u0000\u0000\u03ec\u0310\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0313\u0001\u0000\u0000\u0000\u03ec\u0316\u0001\u0000\u0000\u0000"+
-		"\u03ec\u031d\u0001\u0000\u0000\u0000\u03ec\u0324\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0329\u0001\u0000\u0000\u0000\u03ec\u032d\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0331\u0001\u0000\u0000\u0000\u03ec\u0337\u0001\u0000\u0000\u0000"+
-		"\u03ec\u033d\u0001\u0000\u0000\u0000\u03ec\u0342\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0346\u0001\u0000\u0000\u0000\u03ec\u034a\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0351\u0001\u0000\u0000\u0000\u03ec\u0359\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0362\u0001\u0000\u0000\u0000\u03ec\u036a\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0370\u0001\u0000\u0000\u0000\u03ec\u0379\u0001\u0000\u0000\u0000"+
-		"\u03ec\u037c\u0001\u0000\u0000\u0000\u03ec\u037f\u0001\u0000\u0000\u0000"+
-		"\u03ec\u0382\u0001\u0000\u0000\u0000\u03ec\u0387\u0001\u0000\u0000\u0000"+
-		"\u03ec\u038b\u0001\u0000\u0000\u0000\u03ec\u0390\u0001\u0000\u0000\u0000"+
-		"\u03ec\u039c\u0001\u0000\u0000\u0000\u03ec\u03a7\u0001\u0000\u0000\u0000"+
-		"\u03ec\u03b2\u0001\u0000\u0000\u0000\u03ec\u03b6\u0001\u0000\u0000\u0000"+
-		"\u03ec\u03bc\u0001\u0000\u0000\u0000\u03ec\u03c2\u0001\u0000\u0000\u0000"+
-		"\u03ec\u03cf\u0001\u0000\u0000\u0000\u03ec\u03db\u0001\u0000\u0000\u0000"+
-		"\u03ec\u03e2\u0001\u0000\u0000\u0000\u03ec\u03e5\u0001\u0000\u0000\u0000"+
-		"\u03ed\u0002\u0001\u0000\u0000\u0000\u03ee\u03ef\u0005i\u0000\u0000\u03ef"+
-		"\u03f0\u0005m\u0000\u0000\u03f0\u03f1\u0005p\u0000\u0000\u03f1\u03f2\u0005"+
-		"o\u0000\u0000\u03f2\u03f3\u0005r\u0000\u0000\u03f3\u03f4\u0005t\u0000"+
-		"\u0000\u03f4\u0004\u0001\u0000\u0000\u0000\u03f5\u03f6\u0005i\u0000\u0000"+
-		"\u03f6\u03f7\u0005n\u0000\u0000\u03f7\u03f8\u0005t\u0000\u0000\u03f8\u03f9"+
-		"\u0005e\u0000\u0000\u03f9\u03fa\u0005n\u0000\u0000\u03fa\u03fb\u0005t"+
-		"\u0000\u0000\u03fb\u0006\u0001\u0000\u0000\u0000\u03fc\u03fd\u0005o\u0000"+
-		"\u0000\u03fd\u03fe\u0005p\u0000\u0000\u03fe\u03ff\u0005t\u0000\u0000\u03ff"+
-		"\u0400\u0005i\u0000\u0000\u0400\u0401\u0005o\u0000\u0000\u0401\u0402\u0005"+
-		"n\u0000\u0000\u0402\u0403\u0005s\u0000\u0000\u0403\b\u0001\u0000\u0000"+
-		"\u0000\u0404\u0405\u0005f\u0000\u0000\u0405\u0406\u0005l\u0000\u0000\u0406"+
-		"\u0407\u0005o\u0000\u0000\u0407\u0408\u0005w\u0000\u0000\u0408\n\u0001"+
-		"\u0000\u0000\u0000\u0409\u040a\u0005m\u0000\u0000\u040a\u040b\u0005e\u0000"+
-		"\u0000\u040b\u040c\u0005t\u0000\u0000\u040c\u040d\u0005a\u0000\u0000\u040d"+
-		"\f\u0001\u0000\u0000\u0000\u040e\u040f\u0005t\u0000\u0000\u040f\u0410"+
-		"\u0005e\u0000\u0000\u0410\u0411\u0005r\u0000\u0000\u0411\u0412\u0005m"+
-		"\u0000\u0000\u0412\u000e\u0001\u0000\u0000\u0000\u0413\u0414\u0005f\u0000"+
-		"\u0000\u0414\u0415\u0005r\u0000\u0000\u0415\u0416\u0005a\u0000\u0000\u0416"+
-		"\u0417\u0005g\u0000\u0000\u0417\u0418\u0005m\u0000\u0000\u0418\u0419\u0005"+
-		"e\u0000\u0000\u0419\u041a\u0005n\u0000\u0000\u041a\u041b\u0005t\u0000"+
-		"\u0000\u041b\u0010\u0001\u0000\u0000\u0000\u041c\u0422\u00035\u001a\u0000"+
-		"\u041d\u0421\b\u0000\u0000\u0000\u041e\u041f\u0005\\\u0000\u0000\u041f"+
-		"\u0421\u0005\'\u0000\u0000\u0420\u041d\u0001\u0000\u0000\u0000\u0420\u041e"+
-		"\u0001\u0000\u0000\u0000\u0421\u0424\u0001\u0000\u0000\u0000\u0422\u0420"+
-		"\u0001\u0000\u0000\u0000\u0422\u0423\u0001\u0000\u0000\u0000\u0423\u0425"+
-		"\u0001\u0000\u0000\u0000\u0424\u0422\u0001\u0000\u0000\u0000\u0425\u0426"+
-		"\u00035\u001a\u0000\u0426\u0012\u0001\u0000\u0000\u0000\u0427\u042d\u0003"+
-		"7\u001b\u0000\u0428\u042c\b\u0001\u0000\u0000\u0429\u042a\u0005\\\u0000"+
-		"\u0000\u042a\u042c\u0005\"\u0000\u0000\u042b\u0428\u0001\u0000\u0000\u0000"+
-		"\u042b\u0429\u0001\u0000\u0000\u0000\u042c\u042f\u0001\u0000\u0000\u0000"+
-		"\u042d\u042b\u0001\u0000\u0000\u0000\u042d\u042e\u0001\u0000\u0000\u0000"+
-		"\u042e\u0430\u0001\u0000\u0000\u0000\u042f\u042d\u0001\u0000\u0000\u0000"+
-		"\u0430\u0431\u00037\u001b\u0000\u0431\u0014\u0001\u0000\u0000\u0000\u0432"+
-		"\u0433\u0005t\u0000\u0000\u0433\u0434\u0005r\u0000\u0000\u0434\u0435\u0005"+
-		"u\u0000\u0000\u0435\u043c\u0005e\u0000\u0000\u0436\u0437\u0005f\u0000"+
-		"\u0000\u0437\u0438\u0005a\u0000\u0000\u0438\u0439\u0005l\u0000\u0000\u0439"+
-		"\u043a\u0005s\u0000\u0000\u043a\u043c\u0005e\u0000\u0000\u043b\u0432\u0001"+
-		"\u0000\u0000\u0000\u043b\u0436\u0001\u0000\u0000\u0000\u043c\u0016\u0001"+
-		"\u0000\u0000\u0000\u043d\u043e\u0005n\u0000\u0000\u043e\u043f\u0005u\u0000"+
-		"\u0000\u043f\u0440\u0005l\u0000\u0000\u0440\u0441\u0005l\u0000\u0000\u0441"+
-		"\u0018\u0001\u0000\u0000\u0000\u0442\u0443\u0005=\u0000\u0000\u0443\u0444"+
-		"\u0005=\u0000\u0000\u0444\u001a\u0001\u0000\u0000\u0000\u0445\u0446\u0005"+
-		"!\u0000\u0000\u0446\u0447\u0005=\u0000\u0000\u0447\u001c\u0001\u0000\u0000"+
-		"\u0000\u0448\u0449\u0005>\u0000\u0000\u0449\u044a\u0005=\u0000\u0000\u044a"+
-		"\u001e\u0001\u0000\u0000\u0000\u044b\u044c\u0005<\u0000\u0000\u044c\u044d"+
-		"\u0005=\u0000\u0000\u044d \u0001\u0000\u0000\u0000\u044e\u044f\u0005>"+
-		"\u0000\u0000\u044f\"\u0001\u0000\u0000\u0000\u0450\u0451\u0005<\u0000"+
-		"\u0000\u0451$\u0001\u0000\u0000\u0000\u0452\u0453\u0005&\u0000\u0000\u0453"+
-		"\u0454\u0005&\u0000\u0000\u0454&\u0001\u0000\u0000\u0000\u0455\u0456\u0005"+
-		"|\u0000\u0000\u0456\u0457\u0005|\u0000\u0000\u0457(\u0001\u0000\u0000"+
-		"\u0000\u0458\u0459\u0005|\u0000\u0000\u0459*\u0001\u0000\u0000\u0000\u045a"+
-		"\u045b\u0005!\u0000\u0000\u045b,\u0001\u0000\u0000\u0000\u045c\u045d\u0005"+
-		"(\u0000\u0000\u045d.\u0001\u0000\u0000\u0000\u045e\u045f\u0005)\u0000"+
-		"\u0000\u045f0\u0001\u0000\u0000\u0000\u0460\u0461\u0005{\u0000\u0000\u0461"+
-		"2\u0001\u0000\u0000\u0000\u0462\u0463\u0005}\u0000\u0000\u04634\u0001"+
-		"\u0000\u0000\u0000\u0464\u0465\u0005\'\u0000\u0000\u04656\u0001\u0000"+
-		"\u0000\u0000\u0466\u0467\u0005\"\u0000\u0000\u04678\u0001\u0000\u0000"+
-		"\u0000\u0468\u0469\u0005~\u0000\u0000\u0469:\u0001\u0000\u0000\u0000\u046a"+
-		"\u046b\u0005[\u0000\u0000\u046b<\u0001\u0000\u0000\u0000\u046c\u046d\u0005"+
-		"]\u0000\u0000\u046d>\u0001\u0000\u0000\u0000\u046e\u046f\u0005#\u0000"+
-		"\u0000\u046f@\u0001\u0000\u0000\u0000\u0470\u0471\u0005,\u0000\u0000\u0471"+
-		"B\u0001\u0000\u0000\u0000\u0472\u0473\u0005:\u0000\u0000\u0473D\u0001"+
-		"\u0000\u0000\u0000\u0474\u0475\u0005-\u0000\u0000\u0475F\u0001\u0000\u0000"+
-		"\u0000\u0476\u0477\u0005.\u0000\u0000\u0477H\u0001\u0000\u0000\u0000\u0478"+
-		"\u0479\u0005_\u0000\u0000\u0479J\u0001\u0000\u0000\u0000\u047a\u047b\u0005"+
-		"=\u0000\u0000\u047bL\u0001\u0000\u0000\u0000\u047c\u047d\u0005+\u0000"+
-		"\u0000\u047dN\u0001\u0000\u0000\u0000\u047e\u047f\u0005?\u0000\u0000\u047f"+
-		"P\u0001\u0000\u0000\u0000\u0480\u0481\u0005*\u0000\u0000\u0481R\u0001"+
-		"\u0000\u0000\u0000\u0482\u0483\u0005/\u0000\u0000\u0483T\u0001\u0000\u0000"+
-		"\u0000\u0484\u0485\u0005%\u0000\u0000\u0485V\u0001\u0000\u0000\u0000\u0486"+
-		"\u0487\u0005@\u0000\u0000\u0487X\u0001\u0000\u0000\u0000\u0488\u0489\u0005"+
-		"$\u0000\u0000\u0489Z\u0001\u0000\u0000\u0000\u048a\u0493\u00050\u0000"+
-		"\u0000\u048b\u048f\u0007\u0002\u0000\u0000\u048c\u048e\u0007\u0003\u0000"+
-		"\u0000\u048d\u048c\u0001\u0000\u0000\u0000\u048e\u0491\u0001\u0000\u0000"+
-		"\u0000\u048f\u048d\u0001\u0000\u0000\u0000\u048f\u0490\u0001\u0000\u0000"+
-		"\u0000\u0490\u0493\u0001\u0000\u0000\u0000\u0491\u048f\u0001\u0000\u0000"+
-		"\u0000\u0492\u048a\u0001\u0000\u0000\u0000\u0492\u048b\u0001\u0000\u0000"+
-		"\u0000\u0493\\\u0001\u0000\u0000\u0000\u0494\u0496\u0003G#\u0000\u0495"+
-		"\u0497\u0007\u0004\u0000\u0000\u0496\u0495\u0001\u0000\u0000\u0000\u0497"+
-		"\u0498\u0001\u0000\u0000\u0000\u0498\u0496\u0001\u0000\u0000\u0000\u0498"+
-		"\u0499\u0001\u0000\u0000\u0000\u0499^\u0001\u0000\u0000\u0000\u049a\u049c"+
-		"\u0007\u0005\u0000\u0000\u049b\u049d\u0007\u0006\u0000\u0000\u049c\u049b"+
-		"\u0001\u0000\u0000\u0000\u049c\u049d\u0001\u0000\u0000\u0000\u049d\u049e"+
-		"\u0001\u0000\u0000\u0000\u049e\u049f\u0003[-\u0000\u049f`\u0001\u0000"+
-		"\u0000\u0000\u04a0\u04a4\b\u0007\u0000\u0000\u04a1\u04a2\u0007\b\u0000"+
-		"\u0000\u04a2\u04a4\u0007\t\u0000\u0000\u04a3\u04a0\u0001\u0000\u0000\u0000"+
-		"\u04a3\u04a1\u0001\u0000\u0000\u0000\u04a4b\u0001\u0000\u0000\u0000\u04a5"+
-		"\u04a6\u0007\n\u0000\u0000\u04a6d\u0001\u0000\u0000\u0000\u04a7\u04ac"+
-		"\u0003a0\u0000\u04a8\u04ac\u0003I$\u0000\u04a9\u04ac\u0003c1\u0000\u04aa"+
-		"\u04ac\u0003Y,\u0000\u04ab\u04a7\u0001\u0000\u0000\u0000\u04ab\u04a8\u0001"+
-		"\u0000\u0000\u0000\u04ab\u04a9\u0001\u0000\u0000\u0000\u04ab\u04aa\u0001"+
-		"\u0000\u0000\u0000\u04ac\u04ad\u0001\u0000\u0000\u0000\u04ad\u04ab\u0001"+
-		"\u0000\u0000\u0000\u04ad\u04ae\u0001\u0000\u0000\u0000\u04ae\u04b8\u0001"+
-		"\u0000\u0000\u0000\u04af\u04b7\u0003a0\u0000\u04b0\u04b7\u0003Y,\u0000"+
-		"\u04b1\u04b7\u0003c1\u0000\u04b2\u04b7\u0007\u0004\u0000\u0000\u04b3\u04b7"+
-		"\u0003C!\u0000\u04b4\u04b7\u0003E\"\u0000\u04b5\u04b7\u0003I$\u0000\u04b6"+
-		"\u04af\u0001\u0000\u0000\u0000\u04b6\u04b0\u0001\u0000\u0000\u0000\u04b6"+
-		"\u04b1\u0001\u0000\u0000\u0000\u04b6\u04b2\u0001\u0000\u0000\u0000\u04b6"+
-		"\u04b3\u0001\u0000\u0000\u0000\u04b6\u04b4\u0001\u0000\u0000\u0000\u04b6"+
-		"\u04b5\u0001\u0000\u0000\u0000\u04b7\u04ba\u0001\u0000\u0000\u0000\u04b8"+
-		"\u04b6\u0001\u0000\u0000\u0000\u04b8\u04b9\u0001\u0000\u0000\u0000\u04b9"+
-		"f\u0001\u0000\u0000\u0000\u04ba\u04b8\u0001\u0000\u0000\u0000\u04bb\u04bc"+
-		"\u0005/\u0000\u0000\u04bc\u04bd\u0005/\u0000\u0000\u04bd\u04c1\u0001\u0000"+
-		"\u0000\u0000\u04be\u04c0\b\u000b\u0000\u0000\u04bf\u04be\u0001\u0000\u0000"+
-		"\u0000\u04c0\u04c3\u0001\u0000\u0000\u0000\u04c1\u04bf\u0001\u0000\u0000"+
-		"\u0000\u04c1\u04c2\u0001\u0000\u0000\u0000\u04c2\u04c5\u0001\u0000\u0000"+
-		"\u0000\u04c3\u04c1\u0001\u0000\u0000\u0000\u04c4\u04c6\u0005\r\u0000\u0000"+
-		"\u04c5\u04c4\u0001\u0000\u0000\u0000\u04c5\u04c6\u0001\u0000\u0000\u0000"+
-		"\u04c6\u04c8\u0001\u0000\u0000\u0000\u04c7\u04c9\u0007\f\u0000\u0000\u04c8"+
-		"\u04c7\u0001\u0000\u0000\u0000\u04c9\u04d6\u0001\u0000\u0000\u0000\u04ca"+
-		"\u04cb\u0005/\u0000\u0000\u04cb\u04cc\u0005*\u0000\u0000\u04cc\u04d0\u0001"+
-		"\u0000\u0000\u0000\u04cd\u04cf\t\u0000\u0000\u0000\u04ce\u04cd\u0001\u0000"+
-		"\u0000\u0000\u04cf\u04d2\u0001\u0000\u0000\u0000\u04d0\u04d1\u0001\u0000"+
-		"\u0000\u0000\u04d0\u04ce\u0001\u0000\u0000\u0000\u04d1\u04d3\u0001\u0000"+
-		"\u0000\u0000\u04d2\u04d0\u0001\u0000\u0000\u0000\u04d3\u04d4\u0005*\u0000"+
-		"\u0000\u04d4\u04d6\u0005/\u0000\u0000\u04d5\u04bb\u0001\u0000\u0000\u0000"+
-		"\u04d5\u04ca\u0001\u0000\u0000\u0000\u04d6\u04d7\u0001\u0000\u0000\u0000"+
-		"\u04d7\u04d8\u00063\u0000\u0000\u04d8h\u0001\u0000\u0000\u0000\u04d9\u04db"+
-		"\u0007\r\u0000\u0000\u04da\u04d9\u0001\u0000\u0000\u0000\u04db\u04dc\u0001"+
-		"\u0000\u0000\u0000\u04dc\u04da\u0001\u0000\u0000\u0000\u04dc\u04dd\u0001"+
-		"\u0000\u0000\u0000\u04dd\u04de\u0001\u0000\u0000\u0000\u04de\u04df\u0006"+
-		"4\u0000\u0000\u04dfj\u0001\u0000\u0000\u0000\u04e0\u04e1\t\u0000\u0000"+
-		"\u0000\u04e1l\u0001\u0000\u0000\u0000\u0016\u0000\u03ec\u0420\u0422\u042b"+
-		"\u042d\u043b\u048f\u0492\u0498\u049c\u04a3\u04ab\u04ad\u04b6\u04b8\u04c1"+
-		"\u04c5\u04c8\u04d0\u04d5\u04dc\u0001\u0006\u0000\u0000";
+		"\u0001\u0007\u0001\u0007\u0001\u0007\u0001\b\u0001\b\u0001\b\u0001\b\u0005"+
+		"\b\u0429\b\b\n\b\f\b\u042c\t\b\u0001\b\u0001\b\u0001\t\u0001\t\u0001\t"+
+		"\u0001\t\u0005\t\u0434\b\t\n\t\f\t\u0437\t\t\u0001\t\u0001\t\u0001\n\u0001"+
+		"\n\u0001\n\u0001\n\u0001\n\u0001\n\u0001\n\u0001\n\u0001\n\u0003\n\u0444"+
+		"\b\n\u0001\u000b\u0001\u000b\u0001\u000b\u0001\u000b\u0001\u000b\u0001"+
+		"\f\u0001\f\u0001\f\u0001\r\u0001\r\u0001\r\u0001\u000e\u0001\u000e\u0001"+
+		"\u000e\u0001\u000f\u0001\u000f\u0001\u000f\u0001\u0010\u0001\u0010\u0001"+
+		"\u0011\u0001\u0011\u0001\u0012\u0001\u0012\u0001\u0012\u0001\u0013\u0001"+
+		"\u0013\u0001\u0013\u0001\u0014\u0001\u0014\u0001\u0015\u0001\u0015\u0001"+
+		"\u0016\u0001\u0016\u0001\u0017\u0001\u0017\u0001\u0018\u0001\u0018\u0001"+
+		"\u0019\u0001\u0019\u0001\u001a\u0001\u001a\u0001\u001b\u0001\u001b\u0001"+
+		"\u001c\u0001\u001c\u0001\u001d\u0001\u001d\u0001\u001e\u0001\u001e\u0001"+
+		"\u001f\u0001\u001f\u0001 \u0001 \u0001!\u0001!\u0001\"\u0001\"\u0001#"+
+		"\u0001#\u0001$\u0001$\u0001%\u0001%\u0001&\u0001&\u0001\'\u0001\'\u0001"+
+		"(\u0001(\u0001)\u0001)\u0001*\u0001*\u0001+\u0001+\u0001,\u0001,\u0001"+
+		"-\u0001-\u0001-\u0005-\u0496\b-\n-\f-\u0499\t-\u0003-\u049b\b-\u0001."+
+		"\u0001.\u0004.\u049f\b.\u000b.\f.\u04a0\u0001/\u0001/\u0003/\u04a5\b/"+
+		"\u0001/\u0001/\u00010\u00010\u00010\u00030\u04ac\b0\u00011\u00011\u0001"+
+		"2\u00012\u00012\u00012\u00042\u04b4\b2\u000b2\f2\u04b5\u00012\u00012\u0001"+
+		"2\u00012\u00012\u00012\u00012\u00052\u04bf\b2\n2\f2\u04c2\t2\u00013\u0001"+
+		"3\u00013\u00013\u00053\u04c8\b3\n3\f3\u04cb\t3\u00013\u00033\u04ce\b3"+
+		"\u00013\u00033\u04d1\b3\u00013\u00013\u00013\u00013\u00053\u04d7\b3\n"+
+		"3\f3\u04da\t3\u00013\u00013\u00033\u04de\b3\u00013\u00013\u00014\u0004"+
+		"4\u04e3\b4\u000b4\f4\u04e4\u00014\u00014\u00015\u00015\u0001\u04d8\u0000"+
+		"6\u0001\u0001\u0003\u0002\u0005\u0003\u0007\u0004\t\u0005\u000b\u0006"+
+		"\r\u0007\u000f\b\u0011\t\u0013\n\u0015\u000b\u0017\f\u0019\r\u001b\u000e"+
+		"\u001d\u000f\u001f\u0010!\u0011#\u0012%\u0013\'\u0014)\u0015+\u0016-\u0017"+
+		"/\u00181\u00193\u001a5\u001b7\u001c9\u001d;\u001e=\u001f? A!C\"E#G$I%"+
+		"K&M\'O(Q)S*U+W,Y-[.]/_0a\u0000c\u0000e1g2i3k4\u0001\u0000\u000e\u0001"+
+		"\u0000\'\'\u0001\u0000\"\"\u0001\u000019\u0002\u000009__\u0001\u00000"+
+		"9\u0002\u0000EEee\u0002\u0000++--\u0002\u0000\u0000\u007f\u8000\ud800"+
+		"\u8000\udbff\u0001\u0000\u8000\ud800\u8000\udbff\u0001\u0000\u8000\udc00"+
+		"\u8000\udfff\u0002\u0000AZaz\u0002\u0000\n\n\r\r\u0001\u0001\n\n\u0003"+
+		"\u0000\t\n\f\r  \u057b\u0000\u0001\u0001\u0000\u0000\u0000\u0000\u0003"+
+		"\u0001\u0000\u0000\u0000\u0000\u0005\u0001\u0000\u0000\u0000\u0000\u0007"+
+		"\u0001\u0000\u0000\u0000\u0000\t\u0001\u0000\u0000\u0000\u0000\u000b\u0001"+
+		"\u0000\u0000\u0000\u0000\r\u0001\u0000\u0000\u0000\u0000\u000f\u0001\u0000"+
+		"\u0000\u0000\u0000\u0011\u0001\u0000\u0000\u0000\u0000\u0013\u0001\u0000"+
+		"\u0000\u0000\u0000\u0015\u0001\u0000\u0000\u0000\u0000\u0017\u0001\u0000"+
+		"\u0000\u0000\u0000\u0019\u0001\u0000\u0000\u0000\u0000\u001b\u0001\u0000"+
+		"\u0000\u0000\u0000\u001d\u0001\u0000\u0000\u0000\u0000\u001f\u0001\u0000"+
+		"\u0000\u0000\u0000!\u0001\u0000\u0000\u0000\u0000#\u0001\u0000\u0000\u0000"+
+		"\u0000%\u0001\u0000\u0000\u0000\u0000\'\u0001\u0000\u0000\u0000\u0000"+
+		")\u0001\u0000\u0000\u0000\u0000+\u0001\u0000\u0000\u0000\u0000-\u0001"+
+		"\u0000\u0000\u0000\u0000/\u0001\u0000\u0000\u0000\u00001\u0001\u0000\u0000"+
+		"\u0000\u00003\u0001\u0000\u0000\u0000\u00005\u0001\u0000\u0000\u0000\u0000"+
+		"7\u0001\u0000\u0000\u0000\u00009\u0001\u0000\u0000\u0000\u0000;\u0001"+
+		"\u0000\u0000\u0000\u0000=\u0001\u0000\u0000\u0000\u0000?\u0001\u0000\u0000"+
+		"\u0000\u0000A\u0001\u0000\u0000\u0000\u0000C\u0001\u0000\u0000\u0000\u0000"+
+		"E\u0001\u0000\u0000\u0000\u0000G\u0001\u0000\u0000\u0000\u0000I\u0001"+
+		"\u0000\u0000\u0000\u0000K\u0001\u0000\u0000\u0000\u0000M\u0001\u0000\u0000"+
+		"\u0000\u0000O\u0001\u0000\u0000\u0000\u0000Q\u0001\u0000\u0000\u0000\u0000"+
+		"S\u0001\u0000\u0000\u0000\u0000U\u0001\u0000\u0000\u0000\u0000W\u0001"+
+		"\u0000\u0000\u0000\u0000Y\u0001\u0000\u0000\u0000\u0000[\u0001\u0000\u0000"+
+		"\u0000\u0000]\u0001\u0000\u0000\u0000\u0000_\u0001\u0000\u0000\u0000\u0000"+
+		"e\u0001\u0000\u0000\u0000\u0000g\u0001\u0000\u0000\u0000\u0000i\u0001"+
+		"\u0000\u0000\u0000\u0000k\u0001\u0000\u0000\u0000\u0001\u03f4\u0001\u0000"+
+		"\u0000\u0000\u0003\u03f6\u0001\u0000\u0000\u0000\u0005\u03fd\u0001\u0000"+
+		"\u0000\u0000\u0007\u0404\u0001\u0000\u0000\u0000\t\u040c\u0001\u0000\u0000"+
+		"\u0000\u000b\u0411\u0001\u0000\u0000\u0000\r\u0416\u0001\u0000\u0000\u0000"+
+		"\u000f\u041b\u0001\u0000\u0000\u0000\u0011\u0424\u0001\u0000\u0000\u0000"+
+		"\u0013\u042f\u0001\u0000\u0000\u0000\u0015\u0443\u0001\u0000\u0000\u0000"+
+		"\u0017\u0445\u0001\u0000\u0000\u0000\u0019\u044a\u0001\u0000\u0000\u0000"+
+		"\u001b\u044d\u0001\u0000\u0000\u0000\u001d\u0450\u0001\u0000\u0000\u0000"+
+		"\u001f\u0453\u0001\u0000\u0000\u0000!\u0456\u0001\u0000\u0000\u0000#\u0458"+
+		"\u0001\u0000\u0000\u0000%\u045a\u0001\u0000\u0000\u0000\'\u045d\u0001"+
+		"\u0000\u0000\u0000)\u0460\u0001\u0000\u0000\u0000+\u0462\u0001\u0000\u0000"+
+		"\u0000-\u0464\u0001\u0000\u0000\u0000/\u0466\u0001\u0000\u0000\u00001"+
+		"\u0468\u0001\u0000\u0000\u00003\u046a\u0001\u0000\u0000\u00005\u046c\u0001"+
+		"\u0000\u0000\u00007\u046e\u0001\u0000\u0000\u00009\u0470\u0001\u0000\u0000"+
+		"\u0000;\u0472\u0001\u0000\u0000\u0000=\u0474\u0001\u0000\u0000\u0000?"+
+		"\u0476\u0001\u0000\u0000\u0000A\u0478\u0001\u0000\u0000\u0000C\u047a\u0001"+
+		"\u0000\u0000\u0000E\u047c\u0001\u0000\u0000\u0000G\u047e\u0001\u0000\u0000"+
+		"\u0000I\u0480\u0001\u0000\u0000\u0000K\u0482\u0001\u0000\u0000\u0000M"+
+		"\u0484\u0001\u0000\u0000\u0000O\u0486\u0001\u0000\u0000\u0000Q\u0488\u0001"+
+		"\u0000\u0000\u0000S\u048a\u0001\u0000\u0000\u0000U\u048c\u0001\u0000\u0000"+
+		"\u0000W\u048e\u0001\u0000\u0000\u0000Y\u0490\u0001\u0000\u0000\u0000["+
+		"\u049a\u0001\u0000\u0000\u0000]\u049c\u0001\u0000\u0000\u0000_\u04a2\u0001"+
+		"\u0000\u0000\u0000a\u04ab\u0001\u0000\u0000\u0000c\u04ad\u0001\u0000\u0000"+
+		"\u0000e\u04b3\u0001\u0000\u0000\u0000g\u04dd\u0001\u0000\u0000\u0000i"+
+		"\u04e2\u0001\u0000\u0000\u0000k\u04e8\u0001\u0000\u0000\u0000mn\u0005"+
+		"m\u0000\u0000no\u0005e\u0000\u0000op\u0005t\u0000\u0000pq\u0005a\u0000"+
+		"\u0000qr\u0005_\u0000\u0000rs\u0005e\u0000\u0000st\u0005n\u0000\u0000"+
+		"t\u03f5\u0005t\u0000\u0000uv\u0005m\u0000\u0000vw\u0005e\u0000\u0000w"+
+		"x\u0005t\u0000\u0000xy\u0005a\u0000\u0000yz\u0005_\u0000\u0000z{\u0005"+
+		"c\u0000\u0000{|\u0005f\u0000\u0000|\u03f5\u0005g\u0000\u0000}~\u0005m"+
+		"\u0000\u0000~\u007f\u0005e\u0000\u0000\u007f\u0080\u0005t\u0000\u0000"+
+		"\u0080\u0081\u0005a\u0000\u0000\u0081\u0082\u0005_\u0000\u0000\u0082\u0083"+
+		"\u0005i\u0000\u0000\u0083\u0084\u0005n\u0000\u0000\u0084\u0085\u0005t"+
+		"\u0000\u0000\u0085\u0086\u0005e\u0000\u0000\u0086\u0087\u0005n\u0000\u0000"+
+		"\u0087\u03f5\u0005t\u0000\u0000\u0088\u0089\u0005m\u0000\u0000\u0089\u008a"+
+		"\u0005e\u0000\u0000\u008a\u008b\u0005t\u0000\u0000\u008b\u008c\u0005a"+
+		"\u0000\u0000\u008c\u008d\u0005_\u0000\u0000\u008d\u008e\u0005r\u0000\u0000"+
+		"\u008e\u008f\u0005e\u0000\u0000\u008f\u03f5\u0005q\u0000\u0000\u0090\u0091"+
+		"\u0005m\u0000\u0000\u0091\u0092\u0005e\u0000\u0000\u0092\u0093\u0005t"+
+		"\u0000\u0000\u0093\u0094\u0005a\u0000\u0000\u0094\u0095\u0005_\u0000\u0000"+
+		"\u0095\u0096\u0005s\u0000\u0000\u0096\u0097\u0005y\u0000\u0000\u0097\u03f5"+
+		"\u0005s\u0000\u0000\u0098\u0099\u0005m\u0000\u0000\u0099\u009a\u0005e"+
+		"\u0000\u0000\u009a\u009b\u0005t\u0000\u0000\u009b\u009c\u0005a\u0000\u0000"+
+		"\u009c\u009d\u0005_\u0000\u0000\u009d\u009e\u0005c\u0000\u0000\u009e\u009f"+
+		"\u0005o\u0000\u0000\u009f\u00a0\u0005n\u0000\u0000\u00a0\u03f5\u0005v"+
+		"\u0000\u0000\u00a1\u00a2\u0005m\u0000\u0000\u00a2\u00a3\u0005e\u0000\u0000"+
+		"\u00a3\u00a4\u0005t\u0000\u0000\u00a4\u00a5\u0005a\u0000\u0000\u00a5\u00a6"+
+		"\u0005_\u0000\u0000\u00a6\u00a7\u0005f\u0000\u0000\u00a7\u00a8\u0005r"+
+		"\u0000\u0000\u00a8\u00a9\u0005a\u0000\u0000\u00a9\u03f5\u0005g\u0000\u0000"+
+		"\u00aa\u00ab\u0005j\u0000\u0000\u00ab\u00ac\u0005s\u0000\u0000\u00ac\u00ad"+
+		"\u0005o\u0000\u0000\u00ad\u03f5\u0005n\u0000\u0000\u00ae\u00af\u0005i"+
+		"\u0000\u0000\u00af\u03f5\u0005f\u0000\u0000\u00b0\u00b1\u0005e\u0000\u0000"+
+		"\u00b1\u00b2\u0005n\u0000\u0000\u00b2\u00b3\u0005t\u0000\u0000\u00b3\u00b4"+
+		"\u0005_\u0000\u0000\u00b4\u00b5\u0005t\u0000\u0000\u00b5\u00b6\u0005y"+
+		"\u0000\u0000\u00b6\u00b7\u0005p\u0000\u0000\u00b7\u03f5\u0005e\u0000\u0000"+
+		"\u00b8\u00b9\u0005e\u0000\u0000\u00b9\u00ba\u0005n\u0000\u0000\u00ba\u00bb"+
+		"\u0005t\u0000\u0000\u00bb\u00bc\u0005_\u0000\u0000\u00bc\u00bd\u0005i"+
+		"\u0000\u0000\u00bd\u00be\u0005n\u0000\u0000\u00be\u00bf\u0005d\u0000\u0000"+
+		"\u00bf\u00c0\u0005e\u0000\u0000\u00c0\u03f5\u0005x\u0000\u0000\u00c1\u00c2"+
+		"\u0005e\u0000\u0000\u00c2\u00c3\u0005n\u0000\u0000\u00c3\u00c4\u0005t"+
+		"\u0000\u0000\u00c4\u00c5\u0005_\u0000\u0000\u00c5\u00c6\u0005t\u0000\u0000"+
+		"\u00c6\u00c7\u0005e\u0000\u0000\u00c7\u00c8\u0005x\u0000\u0000\u00c8\u03f5"+
+		"\u0005t\u0000\u0000\u00c9\u00ca\u0005e\u0000\u0000\u00ca\u00cb\u0005n"+
+		"\u0000\u0000\u00cb\u00cc\u0005t\u0000\u0000\u00cc\u00cd\u0005_\u0000\u0000"+
+		"\u00cd\u00ce\u0005g\u0000\u0000\u00ce\u00cf\u0005r\u0000\u0000\u00cf\u00d0"+
+		"\u0005o\u0000\u0000\u00d0\u00d1\u0005u\u0000\u0000\u00d1\u00d2\u0005p"+
+		"\u0000\u0000\u00d2\u03f5\u0005s\u0000\u0000\u00d3\u00d4\u0005e\u0000\u0000"+
+		"\u00d4\u00d5\u0005n\u0000\u0000\u00d5\u00d6\u0005t\u0000\u0000\u00d6\u00d7"+
+		"\u0005_\u0000\u0000\u00d7\u00d8\u0005c\u0000\u0000\u00d8\u00d9\u0005o"+
+		"\u0000\u0000\u00d9\u00da\u0005u\u0000\u0000\u00da\u00db\u0005n\u0000\u0000"+
+		"\u00db\u03f5\u0005t\u0000\u0000\u00dc\u00dd\u0005e\u0000\u0000\u00dd\u00de"+
+		"\u0005n\u0000\u0000\u00de\u00df\u0005t\u0000\u0000\u00df\u00e0\u0005_"+
+		"\u0000\u0000\u00e0\u00e1\u0005a\u0000\u0000\u00e1\u00e2\u0005l\u0000\u0000"+
+		"\u00e2\u03f5\u0005l\u0000\u0000\u00e3\u00e4\u0005e\u0000\u0000\u00e4\u00e5"+
+		"\u0005n\u0000\u0000\u00e5\u00e6\u0005t\u0000\u0000\u00e6\u00e7\u0005_"+
+		"\u0000\u0000\u00e7\u00e8\u0005a\u0000\u0000\u00e8\u00e9\u0005l\u0000\u0000"+
+		"\u00e9\u00ea\u0005l\u0000\u0000\u00ea\u00eb\u0005_\u0000\u0000\u00eb\u00ec"+
+		"\u0005f\u0000\u0000\u00ec\u00ed\u0005o\u0000\u0000\u00ed\u00ee\u0005r"+
+		"\u0000\u0000\u00ee\u00ef\u0005_\u0000\u0000\u00ef\u00f0\u0005t\u0000\u0000"+
+		"\u00f0\u00f1\u0005y\u0000\u0000\u00f1\u00f2\u0005p\u0000\u0000\u00f2\u03f5"+
+		"\u0005e\u0000\u0000\u00f3\u00f4\u0005e\u0000\u0000\u00f4\u00f5\u0005n"+
+		"\u0000\u0000\u00f5\u00f6\u0005t\u0000\u0000\u00f6\u00f7\u0005_\u0000\u0000"+
+		"\u00f7\u00f8\u0005a\u0000\u0000\u00f8\u00f9\u0005l\u0000\u0000\u00f9\u00fa"+
+		"\u0005l\u0000\u0000\u00fa\u00fb\u0005_\u0000\u0000\u00fb\u00fc\u0005f"+
+		"\u0000\u0000\u00fc\u00fd\u0005o\u0000\u0000\u00fd\u00fe\u0005r\u0000\u0000"+
+		"\u00fe\u00ff\u0005_\u0000\u0000\u00ff\u0100\u0005g\u0000\u0000\u0100\u0101"+
+		"\u0005r\u0000\u0000\u0101\u0102\u0005o\u0000\u0000\u0102\u0103\u0005u"+
+		"\u0000\u0000\u0103\u03f5\u0005p\u0000\u0000\u0104\u0105\u0005e\u0000\u0000"+
+		"\u0105\u0106\u0005n\u0000\u0000\u0106\u0107\u0005t\u0000\u0000\u0107\u0108"+
+		"\u0005_\u0000\u0000\u0108\u0109\u0005t\u0000\u0000\u0109\u010a\u0005h"+
+		"\u0000\u0000\u010a\u010b\u0005i\u0000\u0000\u010b\u03f5\u0005s\u0000\u0000"+
+		"\u010c\u010d\u0005e\u0000\u0000\u010d\u010e\u0005n\u0000\u0000\u010e\u010f"+
+		"\u0005t\u0000\u0000\u010f\u0110\u0005_\u0000\u0000\u0110\u0111\u0005i"+
+		"\u0000\u0000\u0111\u0112\u0005s\u0000\u0000\u0112\u0113\u0005_\u0000\u0000"+
+		"\u0113\u0114\u0005l\u0000\u0000\u0114\u0115\u0005a\u0000\u0000\u0115\u0116"+
+		"\u0005s\u0000\u0000\u0116\u03f5\u0005t\u0000\u0000\u0117\u0118\u0005e"+
+		"\u0000\u0000\u0118\u0119\u0005n\u0000\u0000\u0119\u011a\u0005t\u0000\u0000"+
+		"\u011a\u011b\u0005_\u0000\u0000\u011b\u011c\u0005i\u0000\u0000\u011c\u011d"+
+		"\u0005s\u0000\u0000\u011d\u011e\u0005_\u0000\u0000\u011e\u011f\u0005f"+
+		"\u0000\u0000\u011f\u0120\u0005i\u0000\u0000\u0120\u0121\u0005r\u0000\u0000"+
+		"\u0121\u0122\u0005s\u0000\u0000\u0122\u03f5\u0005t\u0000\u0000\u0123\u0124"+
+		"\u0005e\u0000\u0000\u0124\u0125\u0005n\u0000\u0000\u0125\u0126\u0005t"+
+		"\u0000\u0000\u0126\u0127\u0005_\u0000\u0000\u0127\u0128\u0005i\u0000\u0000"+
+		"\u0128\u0129\u0005s\u0000\u0000\u0129\u012a\u0005_\u0000\u0000\u012a\u012b"+
+		"\u0005b\u0000\u0000\u012b\u012c\u0005e\u0000\u0000\u012c\u012d\u0005f"+
+		"\u0000\u0000\u012d\u012e\u0005o\u0000\u0000\u012e\u012f\u0005r\u0000\u0000"+
+		"\u012f\u0130\u0005e\u0000\u0000\u0130\u0131\u0005_\u0000\u0000\u0131\u0132"+
+		"\u0005t\u0000\u0000\u0132\u0133\u0005y\u0000\u0000\u0133\u0134\u0005p"+
+		"\u0000\u0000\u0134\u03f5\u0005e\u0000\u0000\u0135\u0136\u0005e\u0000\u0000"+
+		"\u0136\u0137\u0005n\u0000\u0000\u0137\u0138\u0005t\u0000\u0000\u0138\u0139"+
+		"\u0005_\u0000\u0000\u0139\u013a\u0005i\u0000\u0000\u013a\u013b\u0005s"+
+		"\u0000\u0000\u013b\u013c\u0005_\u0000\u0000\u013c\u013d\u0005b\u0000\u0000"+
+		"\u013d\u013e\u0005e\u0000\u0000\u013e\u013f\u0005f\u0000\u0000\u013f\u0140"+
+		"\u0005o\u0000\u0000\u0140\u0141\u0005r\u0000\u0000\u0141\u0142\u0005e"+
+		"\u0000\u0000\u0142\u0143\u0005_\u0000\u0000\u0143\u0144\u0005g\u0000\u0000"+
+		"\u0144\u0145\u0005r\u0000\u0000\u0145\u0146\u0005o\u0000\u0000\u0146\u0147"+
+		"\u0005u\u0000\u0000\u0147\u03f5\u0005p\u0000\u0000\u0148\u0149\u0005e"+
+		"\u0000\u0000\u0149\u014a\u0005n\u0000\u0000\u014a\u014b\u0005t\u0000\u0000"+
+		"\u014b\u014c\u0005_\u0000\u0000\u014c\u014d\u0005i\u0000\u0000\u014d\u014e"+
+		"\u0005s\u0000\u0000\u014e\u014f\u0005_\u0000\u0000\u014f\u0150\u0005a"+
+		"\u0000\u0000\u0150\u0151\u0005f\u0000\u0000\u0151\u0152\u0005t\u0000\u0000"+
+		"\u0152\u0153\u0005e\u0000\u0000\u0153\u0154\u0005r\u0000\u0000\u0154\u0155"+
+		"\u0005_\u0000\u0000\u0155\u0156\u0005t\u0000\u0000\u0156\u0157\u0005y"+
+		"\u0000\u0000\u0157\u0158\u0005p\u0000\u0000\u0158\u03f5\u0005e\u0000\u0000"+
+		"\u0159\u015a\u0005e\u0000\u0000\u015a\u015b\u0005n\u0000\u0000\u015b\u015c"+
+		"\u0005t\u0000\u0000\u015c\u015d\u0005_\u0000\u0000\u015d\u015e\u0005i"+
+		"\u0000\u0000\u015e\u015f\u0005s\u0000\u0000\u015f\u0160\u0005_\u0000\u0000"+
+		"\u0160\u0161\u0005a\u0000\u0000\u0161\u0162\u0005f\u0000\u0000\u0162\u0163"+
+		"\u0005t\u0000\u0000\u0163\u0164\u0005e\u0000\u0000\u0164\u0165\u0005r"+
+		"\u0000\u0000\u0165\u0166\u0005_\u0000\u0000\u0166\u0167\u0005g\u0000\u0000"+
+		"\u0167\u0168\u0005r\u0000\u0000\u0168\u0169\u0005o\u0000\u0000\u0169\u016a"+
+		"\u0005u\u0000\u0000\u016a\u03f5\u0005p\u0000\u0000\u016b\u016c\u0005e"+
+		"\u0000\u0000\u016c\u016d\u0005n\u0000\u0000\u016d\u016e\u0005t\u0000\u0000"+
+		"\u016e\u016f\u0005_\u0000\u0000\u016f\u0170\u0005i\u0000\u0000\u0170\u0171"+
+		"\u0005s\u0000\u0000\u0171\u0172\u0005_\u0000\u0000\u0172\u0173\u0005b"+
+		"\u0000\u0000\u0173\u0174\u0005e\u0000\u0000\u0174\u0175\u0005t\u0000\u0000"+
+		"\u0175\u0176\u0005w\u0000\u0000\u0176\u0177\u0005e\u0000\u0000\u0177\u0178"+
+		"\u0005e\u0000\u0000\u0178\u0179\u0005n\u0000\u0000\u0179\u017a\u0005_"+
+		"\u0000\u0000\u017a\u017b\u0005t\u0000\u0000\u017b\u017c\u0005y\u0000\u0000"+
+		"\u017c\u017d\u0005p\u0000\u0000\u017d\u017e\u0005e\u0000\u0000\u017e\u03f5"+
+		"\u0005s\u0000\u0000\u017f\u0180\u0005e\u0000\u0000\u0180\u0181\u0005n"+
+		"\u0000\u0000\u0181\u0182\u0005t\u0000\u0000\u0182\u0183\u0005_\u0000\u0000"+
+		"\u0183\u0184\u0005i\u0000\u0000\u0184\u0185\u0005s\u0000\u0000\u0185\u0186"+
+		"\u0005_\u0000\u0000\u0186\u0187\u0005b\u0000\u0000\u0187\u0188\u0005e"+
+		"\u0000\u0000\u0188\u0189\u0005t\u0000\u0000\u0189\u018a\u0005w\u0000\u0000"+
+		"\u018a\u018b\u0005e\u0000\u0000\u018b\u018c\u0005e\u0000\u0000\u018c\u018d"+
+		"\u0005n\u0000\u0000\u018d\u018e\u0005_\u0000\u0000\u018e\u018f\u0005g"+
+		"\u0000\u0000\u018f\u0190\u0005r\u0000\u0000\u0190\u0191\u0005o\u0000\u0000"+
+		"\u0191\u0192\u0005u\u0000\u0000\u0192\u0193\u0005p\u0000\u0000\u0193\u03f5"+
+		"\u0005s\u0000\u0000\u0194\u0195\u0005m\u0000\u0000\u0195\u0196\u0005d"+
+		"\u0000\u0000\u0196\u0197\u0005l\u0000\u0000\u0197\u0198\u0005_\u0000\u0000"+
+		"\u0198\u0199\u0005i\u0000\u0000\u0199\u03f5\u0005d\u0000\u0000\u019a\u019b"+
+		"\u0005m\u0000\u0000\u019b\u019c\u0005d\u0000\u0000\u019c\u019d\u0005l"+
+		"\u0000\u0000\u019d\u019e\u0005_\u0000\u0000\u019e\u019f\u0005n\u0000\u0000"+
+		"\u019f\u01a0\u0005a\u0000\u0000\u01a0\u01a1\u0005m\u0000\u0000\u01a1\u03f5"+
+		"\u0005e\u0000\u0000\u01a2\u01a3\u0005m\u0000\u0000\u01a3\u01a4\u0005d"+
+		"\u0000\u0000\u01a4\u01a5\u0005l\u0000\u0000\u01a5\u01a6\u0005_\u0000\u0000"+
+		"\u01a6\u01a7\u0005v\u0000\u0000\u01a7\u01a8\u0005e\u0000\u0000\u01a8\u03f5"+
+		"\u0005r\u0000\u0000\u01a9\u01aa\u0005m\u0000\u0000\u01aa\u01ab\u0005d"+
+		"\u0000\u0000\u01ab\u01ac\u0005l\u0000\u0000\u01ac\u01ad\u0005_\u0000\u0000"+
+		"\u01ad\u01ae\u0005o\u0000\u0000\u01ae\u01af\u0005r\u0000\u0000\u01af\u01b0"+
+		"\u0005i\u0000\u0000\u01b0\u01b1\u0005g\u0000\u0000\u01b1\u01b2\u0005i"+
+		"\u0000\u0000\u01b2\u03f5\u0005n\u0000\u0000\u01b3\u01b4\u0005r\u0000\u0000"+
+		"\u01b4\u01b5\u0005e\u0000\u0000\u01b5\u01b6\u0005q\u0000\u0000\u01b6\u01b7"+
+		"\u0005_\u0000\u0000\u01b7\u01b8\u0005i\u0000\u0000\u01b8\u03f5\u0005d"+
+		"\u0000\u0000\u01b9\u01ba\u0005r\u0000\u0000\u01ba\u01bb\u0005e\u0000\u0000"+
+		"\u01bb\u01bc\u0005q\u0000\u0000\u01bc\u01bd\u0005_\u0000\u0000\u01bd\u01be"+
+		"\u0005t\u0000\u0000\u01be\u01bf\u0005e\u0000\u0000\u01bf\u01c0\u0005x"+
+		"\u0000\u0000\u01c0\u03f5\u0005t\u0000\u0000\u01c1\u01c2\u0005r\u0000\u0000"+
+		"\u01c2\u01c3\u0005e\u0000\u0000\u01c3\u01c4\u0005q\u0000\u0000\u01c4\u01c5"+
+		"\u0005_\u0000\u0000\u01c5\u01c6\u0005t\u0000\u0000\u01c6\u01c7\u0005s"+
+		"\u0000\u0000\u01c7\u01c8\u0005t\u0000\u0000\u01c8\u01c9\u0005a\u0000\u0000"+
+		"\u01c9\u01ca\u0005m\u0000\u0000\u01ca\u03f5\u0005p\u0000\u0000\u01cb\u01cc"+
+		"\u0005u\u0000\u0000\u01cc\u01cd\u0005s\u0000\u0000\u01cd\u01ce\u0005e"+
+		"\u0000\u0000\u01ce\u01cf\u0005r\u0000\u0000\u01cf\u01d0\u0005_\u0000\u0000"+
+		"\u01d0\u01d1\u0005i\u0000\u0000\u01d1\u03f5\u0005d\u0000\u0000\u01d2\u01d3"+
+		"\u0005t\u0000\u0000\u01d3\u01d4\u0005r\u0000\u0000\u01d4\u01d5\u0005i"+
+		"\u0000\u0000\u01d5\u03f5\u0005m\u0000\u0000\u01d6\u01d7\u0005r\u0000\u0000"+
+		"\u01d7\u01d8\u0005e\u0000\u0000\u01d8\u01d9\u0005g\u0000\u0000\u01d9\u01da"+
+		"\u0005e\u0000\u0000\u01da\u03f5\u0005x\u0000\u0000\u01db\u01dc\u0005s"+
+		"\u0000\u0000\u01dc\u01dd\u0005t\u0000\u0000\u01dd\u01de\u0005r\u0000\u0000"+
+		"\u01de\u01df\u0005i\u0000\u0000\u01df\u03f5\u0005p\u0000\u0000\u01e0\u01e1"+
+		"\u0005u\u0000\u0000\u01e1\u01e2\u0005p\u0000\u0000\u01e2\u01e3\u0005p"+
+		"\u0000\u0000\u01e3\u01e4\u0005e\u0000\u0000\u01e4\u01e5\u0005r\u0000\u0000"+
+		"\u01e5\u01e6\u0005c\u0000\u0000\u01e6\u01e7\u0005a\u0000\u0000\u01e7\u01e8"+
+		"\u0005s\u0000\u0000\u01e8\u03f5\u0005e\u0000\u0000\u01e9\u01ea\u0005l"+
+		"\u0000\u0000\u01ea\u01eb\u0005o\u0000\u0000\u01eb\u01ec\u0005w\u0000\u0000"+
+		"\u01ec\u01ed\u0005e\u0000\u0000\u01ed\u01ee\u0005r\u0000\u0000\u01ee\u01ef"+
+		"\u0005c\u0000\u0000\u01ef\u01f0\u0005a\u0000\u0000\u01f0\u01f1\u0005s"+
+		"\u0000\u0000\u01f1\u03f5\u0005e\u0000\u0000\u01f2\u01f3\u0005i\u0000\u0000"+
+		"\u01f3\u01f4\u0005s\u0000\u0000\u01f4\u01f5\u0005_\u0000\u0000\u01f5\u01f6"+
+		"\u0005a\u0000\u0000\u01f6\u01f7\u0005l\u0000\u0000\u01f7\u01f8\u0005p"+
+		"\u0000\u0000\u01f8\u01f9\u0005h\u0000\u0000\u01f9\u03f5\u0005a\u0000\u0000"+
+		"\u01fa\u01fb\u0005i\u0000\u0000\u01fb\u01fc\u0005s\u0000\u0000\u01fc\u01fd"+
+		"\u0005_\u0000\u0000\u01fd\u01fe\u0005a\u0000\u0000\u01fe\u01ff\u0005l"+
+		"\u0000\u0000\u01ff\u0200\u0005p\u0000\u0000\u0200\u0201\u0005h\u0000\u0000"+
+		"\u0201\u0202\u0005a\u0000\u0000\u0202\u0203\u0005n\u0000\u0000\u0203\u0204"+
+		"\u0005u\u0000\u0000\u0204\u03f5\u0005m\u0000\u0000\u0205\u0206\u0005i"+
+		"\u0000\u0000\u0206\u0207\u0005s\u0000\u0000\u0207\u0208\u0005_\u0000\u0000"+
+		"\u0208\u0209\u0005w\u0000\u0000\u0209\u020a\u0005h\u0000\u0000\u020a\u020b"+
+		"\u0005i\u0000\u0000\u020b\u020c\u0005t\u0000\u0000\u020c\u020d\u0005e"+
+		"\u0000\u0000\u020d\u020e\u0005s\u0000\u0000\u020e\u020f\u0005p\u0000\u0000"+
+		"\u020f\u0210\u0005a\u0000\u0000\u0210\u0211\u0005c\u0000\u0000\u0211\u03f5"+
+		"\u0005e\u0000\u0000\u0212\u0213\u0005i\u0000\u0000\u0213\u0214\u0005s"+
+		"\u0000\u0000\u0214\u0215\u0005_\u0000\u0000\u0215\u0216\u0005n\u0000\u0000"+
+		"\u0216\u0217\u0005u\u0000\u0000\u0217\u03f5\u0005m\u0000\u0000\u0218\u0219"+
+		"\u0005i\u0000\u0000\u0219\u021a\u0005s\u0000\u0000\u021a\u021b\u0005_"+
+		"\u0000\u0000\u021b\u021c\u0005n\u0000\u0000\u021c\u021d\u0005u\u0000\u0000"+
+		"\u021d\u021e\u0005m\u0000\u0000\u021e\u021f\u0005s\u0000\u0000\u021f\u0220"+
+		"\u0005p\u0000\u0000\u0220\u0221\u0005a\u0000\u0000\u0221\u0222\u0005c"+
+		"\u0000\u0000\u0222\u03f5\u0005e\u0000\u0000\u0223\u0224\u0005i\u0000\u0000"+
+		"\u0224\u0225\u0005s\u0000\u0000\u0225\u0226\u0005_\u0000\u0000\u0226\u0227"+
+		"\u0005a\u0000\u0000\u0227\u0228\u0005l\u0000\u0000\u0228\u0229\u0005p"+
+		"\u0000\u0000\u0229\u022a\u0005h\u0000\u0000\u022a\u022b\u0005a\u0000\u0000"+
+		"\u022b\u022c\u0005s\u0000\u0000\u022c\u022d\u0005p\u0000\u0000\u022d\u022e"+
+		"\u0005a\u0000\u0000\u022e\u022f\u0005c\u0000\u0000\u022f\u03f5\u0005e"+
+		"\u0000\u0000\u0230\u0231\u0005i\u0000\u0000\u0231\u0232\u0005s\u0000\u0000"+
+		"\u0232\u0233\u0005_\u0000\u0000\u0233\u0234\u0005a\u0000\u0000\u0234\u0235"+
+		"\u0005l\u0000\u0000\u0235\u0236\u0005p\u0000\u0000\u0236\u0237\u0005h"+
+		"\u0000\u0000\u0237\u0238\u0005a\u0000\u0000\u0238\u0239\u0005n\u0000\u0000"+
+		"\u0239\u023a\u0005u\u0000\u0000\u023a\u023b\u0005m\u0000\u0000\u023b\u023c"+
+		"\u0005s\u0000\u0000\u023c\u023d\u0005p\u0000\u0000\u023d\u023e\u0005a"+
+		"\u0000\u0000\u023e\u023f\u0005c\u0000\u0000\u023f\u03f5\u0005e\u0000\u0000"+
+		"\u0240\u0241\u0005s\u0000\u0000\u0241\u0242\u0005p\u0000\u0000\u0242\u0243"+
+		"\u0005l\u0000\u0000\u0243\u0244\u0005i\u0000\u0000\u0244\u03f5\u0005t"+
+		"\u0000\u0000\u0245\u0246\u0005s\u0000\u0000\u0246\u0247\u0005p\u0000\u0000"+
+		"\u0247\u0248\u0005l\u0000\u0000\u0248\u0249\u0005i\u0000\u0000\u0249\u024a"+
+		"\u0005t\u0000\u0000\u024a\u024b\u0005_\u0000\u0000\u024b\u024c\u0005t"+
+		"\u0000\u0000\u024c\u024d\u0005r\u0000\u0000\u024d\u024e\u0005i\u0000\u0000"+
+		"\u024e\u03f5\u0005m\u0000\u0000\u024f\u0250\u0005s\u0000\u0000\u0250\u0251"+
+		"\u0005t\u0000\u0000\u0251\u0252\u0005a\u0000\u0000\u0252\u0253\u0005r"+
+		"\u0000\u0000\u0253\u0254\u0005t\u0000\u0000\u0254\u0255\u0005s\u0000\u0000"+
+		"\u0255\u0256\u0005_\u0000\u0000\u0256\u0257\u0005w\u0000\u0000\u0257\u0258"+
+		"\u0005i\u0000\u0000\u0258\u0259\u0005t\u0000\u0000\u0259\u03f5\u0005h"+
+		"\u0000\u0000\u025a\u025b\u0005e\u0000\u0000\u025b\u025c\u0005n\u0000\u0000"+
+		"\u025c\u025d\u0005d\u0000\u0000\u025d\u025e\u0005s\u0000\u0000\u025e\u025f"+
+		"\u0005_\u0000\u0000\u025f\u0260\u0005w\u0000\u0000\u0260\u0261\u0005i"+
+		"\u0000\u0000\u0261\u0262\u0005t\u0000\u0000\u0262\u03f5\u0005h\u0000\u0000"+
+		"\u0263\u0264\u0005i\u0000\u0000\u0264\u0265\u0005n\u0000\u0000\u0265\u0266"+
+		"\u0005d\u0000\u0000\u0266\u0267\u0005e\u0000\u0000\u0267\u0268\u0005x"+
+		"\u0000\u0000\u0268\u0269\u0005_\u0000\u0000\u0269\u026a\u0005o\u0000\u0000"+
+		"\u026a\u03f5\u0005f\u0000\u0000\u026b\u026c\u0005c\u0000\u0000\u026c\u026d"+
+		"\u0005o\u0000\u0000\u026d\u026e\u0005n\u0000\u0000\u026e\u026f\u0005t"+
+		"\u0000\u0000\u026f\u0270\u0005a\u0000\u0000\u0270\u0271\u0005i\u0000\u0000"+
+		"\u0271\u0272\u0005n\u0000\u0000\u0272\u03f5\u0005s\u0000\u0000\u0273\u0274"+
+		"\u0005s\u0000\u0000\u0274\u0275\u0005u\u0000\u0000\u0275\u0276\u0005b"+
+		"\u0000\u0000\u0276\u0277\u0005s\u0000\u0000\u0277\u0278\u0005t\u0000\u0000"+
+		"\u0278\u03f5\u0005r\u0000\u0000\u0279\u027a\u0005r\u0000\u0000\u027a\u027b"+
+		"\u0005e\u0000\u0000\u027b\u027c\u0005p\u0000\u0000\u027c\u027d\u0005l"+
+		"\u0000\u0000\u027d\u027e\u0005a\u0000\u0000\u027e\u027f\u0005c\u0000\u0000"+
+		"\u027f\u03f5\u0005e\u0000\u0000\u0280\u0281\u0005a\u0000\u0000\u0281\u0282"+
+		"\u0005b\u0000\u0000\u0282\u03f5\u0005s\u0000\u0000\u0283\u0284\u0005c"+
+		"\u0000\u0000\u0284\u0285\u0005e\u0000\u0000\u0285\u0286\u0005i\u0000\u0000"+
+		"\u0286\u03f5\u0005l\u0000\u0000\u0287\u0288\u0005f\u0000\u0000\u0288\u0289"+
+		"\u0005l\u0000\u0000\u0289\u028a\u0005o\u0000\u0000\u028a\u028b\u0005o"+
+		"\u0000\u0000\u028b\u03f5\u0005r\u0000\u0000\u028c\u028d\u0005r\u0000\u0000"+
+		"\u028d\u028e\u0005i\u0000\u0000\u028e\u028f\u0005n\u0000\u0000\u028f\u03f5"+
+		"\u0005t\u0000\u0000\u0290\u0291\u0005r\u0000\u0000\u0291\u0292\u0005o"+
+		"\u0000\u0000\u0292\u0293\u0005u\u0000\u0000\u0293\u0294\u0005n\u0000\u0000"+
+		"\u0294\u03f5\u0005d\u0000\u0000\u0295\u0296\u0005s\u0000\u0000\u0296\u0297"+
+		"\u0005i\u0000\u0000\u0297\u0298\u0005g\u0000\u0000\u0298\u0299\u0005n"+
+		"\u0000\u0000\u0299\u029a\u0005u\u0000\u0000\u029a\u03f5\u0005m\u0000\u0000"+
+		"\u029b\u029c\u0005s\u0000\u0000\u029c\u029d\u0005q\u0000\u0000\u029d\u029e"+
+		"\u0005r\u0000\u0000\u029e\u03f5\u0005t\u0000\u0000\u029f\u02a0\u0005c"+
+		"\u0000\u0000\u02a0\u02a1\u0005b\u0000\u0000\u02a1\u02a2\u0005r\u0000\u0000"+
+		"\u02a2\u03f5\u0005t\u0000\u0000\u02a3\u02a4\u0005p\u0000\u0000\u02a4\u03f5"+
+		"\u0005i\u0000\u0000\u02a5\u02a6\u0005t\u0000\u0000\u02a6\u02a7\u0005o"+
+		"\u0000\u0000\u02a7\u02a8\u0005_\u0000\u0000\u02a8\u02a9\u0005d\u0000\u0000"+
+		"\u02a9\u02aa\u0005o\u0000\u0000\u02aa\u02ab\u0005u\u0000\u0000\u02ab\u02ac"+
+		"\u0005b\u0000\u0000\u02ac\u02ad\u0005l\u0000\u0000\u02ad\u03f5\u0005e"+
+		"\u0000\u0000\u02ae\u02af\u0005t\u0000\u0000\u02af\u02b0\u0005o\u0000\u0000"+
+		"\u02b0\u02b1\u0005_\u0000\u0000\u02b1\u02b2\u0005i\u0000\u0000\u02b2\u02b3"+
+		"\u0005n\u0000\u0000\u02b3\u03f5\u0005t\u0000\u0000\u02b4\u02b5\u0005e"+
+		"\u0000\u0000\u02b5\u02b6\u0005u\u0000\u0000\u02b6\u02b7\u0005l\u0000\u0000"+
+		"\u02b7\u02b8\u0005e\u0000\u0000\u02b8\u03f5\u0005r\u0000\u0000\u02b9\u02ba"+
+		"\u0005a\u0000\u0000\u02ba\u02bb\u0005c\u0000\u0000\u02bb\u02bc\u0005o"+
+		"\u0000\u0000\u02bc\u03f5\u0005s\u0000\u0000\u02bd\u02be\u0005a\u0000\u0000"+
+		"\u02be\u02bf\u0005s\u0000\u0000\u02bf\u02c0\u0005i\u0000\u0000\u02c0\u03f5"+
+		"\u0005n\u0000\u0000\u02c1\u02c2\u0005a\u0000\u0000\u02c2\u02c3\u0005t"+
+		"\u0000\u0000\u02c3\u02c4\u0005a\u0000\u0000\u02c4\u03f5\u0005n\u0000\u0000"+
+		"\u02c5\u02c6\u0005c\u0000\u0000\u02c6\u02c7\u0005o\u0000\u0000\u02c7\u03f5"+
+		"\u0005s\u0000\u0000\u02c8\u02c9\u0005s\u0000\u0000\u02c9\u02ca\u0005i"+
+		"\u0000\u0000\u02ca\u03f5\u0005n\u0000\u0000\u02cb\u02cc\u0005t\u0000\u0000"+
+		"\u02cc\u02cd\u0005a\u0000\u0000\u02cd\u03f5\u0005n\u0000\u0000\u02ce\u02cf"+
+		"\u0005c\u0000\u0000\u02cf\u02d0\u0005o\u0000\u0000\u02d0\u02d1\u0005s"+
+		"\u0000\u0000\u02d1\u03f5\u0005h\u0000\u0000\u02d2\u02d3\u0005s\u0000\u0000"+
+		"\u02d3\u02d4\u0005i\u0000\u0000\u02d4\u02d5\u0005n\u0000\u0000\u02d5\u03f5"+
+		"\u0005h\u0000\u0000\u02d6\u02d7\u0005t\u0000\u0000\u02d7\u02d8\u0005a"+
+		"\u0000\u0000\u02d8\u02d9\u0005n\u0000\u0000\u02d9\u03f5\u0005h\u0000\u0000"+
+		"\u02da\u02db\u0005a\u0000\u0000\u02db\u02dc\u0005t\u0000\u0000\u02dc\u02dd"+
+		"\u0005a\u0000\u0000\u02dd\u02de\u0005n\u0000\u0000\u02de\u03f5\u00052"+
+		"\u0000\u0000\u02df\u02e0\u0005d\u0000\u0000\u02e0\u02e1\u0005e\u0000\u0000"+
+		"\u02e1\u02e2\u0005g\u0000\u0000\u02e2\u02e3\u0005r\u0000\u0000\u02e3\u02e4"+
+		"\u0005e\u0000\u0000\u02e4\u02e5\u0005e\u0000\u0000\u02e5\u03f5\u0005s"+
+		"\u0000\u0000\u02e6\u02e7\u0005r\u0000\u0000\u02e7\u02e8\u0005a\u0000\u0000"+
+		"\u02e8\u02e9\u0005d\u0000\u0000\u02e9\u02ea\u0005i\u0000\u0000\u02ea\u02eb"+
+		"\u0005a\u0000\u0000\u02eb\u02ec\u0005n\u0000\u0000\u02ec\u03f5\u0005s"+
+		"\u0000\u0000\u02ed\u02ee\u0005e\u0000\u0000\u02ee\u02ef\u0005x\u0000\u0000"+
+		"\u02ef\u03f5\u0005p\u0000\u0000\u02f0\u02f1\u0005e\u0000\u0000\u02f1\u02f2"+
+		"\u0005x\u0000\u0000\u02f2\u02f3\u0005p\u0000\u0000\u02f3\u02f4\u0005m"+
+		"\u0000\u0000\u02f4\u03f5\u00051\u0000\u0000\u02f5\u02f6\u0005h\u0000\u0000"+
+		"\u02f6\u02f7\u0005y\u0000\u0000\u02f7\u02f8\u0005p\u0000\u0000\u02f8\u02f9"+
+		"\u0005o\u0000\u0000\u02f9\u03f5\u0005t\u0000\u0000\u02fa\u02fb\u0005l"+
+		"\u0000\u0000\u02fb\u02fc\u0005o\u0000\u0000\u02fc\u03f5\u0005g\u0000\u0000"+
+		"\u02fd\u02fe\u0005l\u0000\u0000\u02fe\u02ff\u0005o\u0000\u0000\u02ff\u0300"+
+		"\u0005g\u0000\u0000\u0300\u0301\u00051\u0000\u0000\u0301\u03f5\u00050"+
+		"\u0000\u0000\u0302\u0303\u0005l\u0000\u0000\u0303\u0304\u0005o\u0000\u0000"+
+		"\u0304\u0305\u0005g\u0000\u0000\u0305\u0306\u00051\u0000\u0000\u0306\u03f5"+
+		"\u0005p\u0000\u0000\u0307\u0308\u0005p\u0000\u0000\u0308\u0309\u0005o"+
+		"\u0000\u0000\u0309\u03f5\u0005w\u0000\u0000\u030a\u030b\u0005r\u0000\u0000"+
+		"\u030b\u030c\u0005a\u0000\u0000\u030c\u030d\u0005n\u0000\u0000\u030d\u03f5"+
+		"\u0005d\u0000\u0000\u030e\u030f\u0005s\u0000\u0000\u030f\u0310\u0005q"+
+		"\u0000\u0000\u0310\u0311\u0005u\u0000\u0000\u0311\u0312\u0005a\u0000\u0000"+
+		"\u0312\u0313\u0005r\u0000\u0000\u0313\u03f5\u0005e\u0000\u0000\u0314\u0315"+
+		"\u0005l\u0000\u0000\u0315\u0316\u0005i\u0000\u0000\u0316\u0317\u0005s"+
+		"\u0000\u0000\u0317\u03f5\u0005t\u0000\u0000\u0318\u0319\u0005g\u0000\u0000"+
+		"\u0319\u031a\u0005e\u0000\u0000\u031a\u03f5\u0005t\u0000\u0000\u031b\u031c"+
+		"\u0005h\u0000\u0000\u031c\u031d\u0005a\u0000\u0000\u031d\u03f5\u0005s"+
+		"\u0000\u0000\u031e\u031f\u0005h\u0000\u0000\u031f\u0320\u0005a\u0000\u0000"+
+		"\u0320\u0321\u0005s\u0000\u0000\u0321\u0322\u0005_\u0000\u0000\u0322\u0323"+
+		"\u0005a\u0000\u0000\u0323\u0324\u0005n\u0000\u0000\u0324\u03f5\u0005y"+
+		"\u0000\u0000\u0325\u0326\u0005h\u0000\u0000\u0326\u0327\u0005a\u0000\u0000"+
+		"\u0327\u0328\u0005s\u0000\u0000\u0328\u0329\u0005_\u0000\u0000\u0329\u032a"+
+		"\u0005a\u0000\u0000\u032a\u032b\u0005l\u0000\u0000\u032b\u03f5\u0005l"+
+		"\u0000\u0000\u032c\u032d\u0005f\u0000\u0000\u032d\u032e\u0005i\u0000\u0000"+
+		"\u032e\u032f\u0005r\u0000\u0000\u032f\u0330\u0005s\u0000\u0000\u0330\u03f5"+
+		"\u0005t\u0000\u0000\u0331\u0332\u0005l\u0000\u0000\u0332\u0333\u0005a"+
+		"\u0000\u0000\u0333\u0334\u0005s\u0000\u0000\u0334\u03f5\u0005t\u0000\u0000"+
+		"\u0335\u0336\u0005k\u0000\u0000\u0336\u0337\u0005e\u0000\u0000\u0337\u0338"+
+		"\u0005y\u0000\u0000\u0338\u03f5\u0005s\u0000\u0000\u0339\u033a\u0005v"+
+		"\u0000\u0000\u033a\u033b\u0005a\u0000\u0000\u033b\u033c\u0005l\u0000\u0000"+
+		"\u033c\u033d\u0005u\u0000\u0000\u033d\u033e\u0005e\u0000\u0000\u033e\u03f5"+
+		"\u0005s\u0000\u0000\u033f\u0340\u0005l\u0000\u0000\u0340\u0341\u0005e"+
+		"\u0000\u0000\u0341\u0342\u0005n\u0000\u0000\u0342\u0343\u0005g\u0000\u0000"+
+		"\u0343\u0344\u0005t\u0000\u0000\u0344\u03f5\u0005h\u0000\u0000\u0345\u0346"+
+		"\u0005c\u0000\u0000\u0346\u0347\u0005o\u0000\u0000\u0347\u0348\u0005u"+
+		"\u0000\u0000\u0348\u0349\u0005n\u0000\u0000\u0349\u03f5\u0005t\u0000\u0000"+
+		"\u034a\u034b\u0005s\u0000\u0000\u034b\u034c\u0005i\u0000\u0000\u034c\u034d"+
+		"\u0005z\u0000\u0000\u034d\u03f5\u0005e\u0000\u0000\u034e\u034f\u0005s"+
+		"\u0000\u0000\u034f\u0350\u0005o\u0000\u0000\u0350\u0351\u0005r\u0000\u0000"+
+		"\u0351\u03f5\u0005t\u0000\u0000\u0352\u0353\u0005r\u0000\u0000\u0353\u0354"+
+		"\u0005e\u0000\u0000\u0354\u0355\u0005v\u0000\u0000\u0355\u0356\u0005e"+
+		"\u0000\u0000\u0356\u0357\u0005r\u0000\u0000\u0357\u0358\u0005s\u0000\u0000"+
+		"\u0358\u03f5\u0005e\u0000\u0000\u0359\u035a\u0005i\u0000\u0000\u035a\u035b"+
+		"\u0005s\u0000\u0000\u035b\u035c\u0005_\u0000\u0000\u035c\u035d\u0005e"+
+		"\u0000\u0000\u035d\u035e\u0005m\u0000\u0000\u035e\u035f\u0005p\u0000\u0000"+
+		"\u035f\u0360\u0005t\u0000\u0000\u0360\u03f5\u0005y\u0000\u0000\u0361\u0362"+
+		"\u0005n\u0000\u0000\u0362\u0363\u0005o\u0000\u0000\u0363\u0364\u0005n"+
+		"\u0000\u0000\u0364\u0365\u0005_\u0000\u0000\u0365\u0366\u0005e\u0000\u0000"+
+		"\u0366\u0367\u0005m\u0000\u0000\u0367\u0368\u0005p\u0000\u0000\u0368\u0369"+
+		"\u0005t\u0000\u0000\u0369\u03f5\u0005y\u0000\u0000\u036a\u036b\u0005d"+
+		"\u0000\u0000\u036b\u036c\u0005i\u0000\u0000\u036c\u036d\u0005s\u0000\u0000"+
+		"\u036d\u036e\u0005t\u0000\u0000\u036e\u036f\u0005i\u0000\u0000\u036f\u0370"+
+		"\u0005n\u0000\u0000\u0370\u0371\u0005c\u0000\u0000\u0371\u03f5\u0005t"+
+		"\u0000\u0000\u0372\u0373\u0005c\u0000\u0000\u0373\u0374\u0005o\u0000\u0000"+
+		"\u0374\u0375\u0005n\u0000\u0000\u0375\u0376\u0005c\u0000\u0000\u0376\u0377"+
+		"\u0005a\u0000\u0000\u0377\u03f5\u0005t\u0000\u0000\u0378\u0379\u0005t"+
+		"\u0000\u0000\u0379\u037a\u0005o\u0000\u0000\u037a\u037b\u0005_\u0000\u0000"+
+		"\u037b\u037c\u0005s\u0000\u0000\u037c\u037d\u0005t\u0000\u0000\u037d\u037e"+
+		"\u0005r\u0000\u0000\u037e\u037f\u0005i\u0000\u0000\u037f\u0380\u0005n"+
+		"\u0000\u0000\u0380\u03f5\u0005g\u0000\u0000\u0381\u0382\u0005m\u0000\u0000"+
+		"\u0382\u0383\u0005a\u0000\u0000\u0383\u03f5\u0005x\u0000\u0000\u0384\u0385"+
+		"\u0005m\u0000\u0000\u0385\u0386\u0005i\u0000\u0000\u0386\u03f5\u0005n"+
+		"\u0000\u0000\u0387\u0388\u0005a\u0000\u0000\u0388\u0389\u0005v\u0000\u0000"+
+		"\u0389\u03f5\u0005g\u0000\u0000\u038a\u038b\u0005s\u0000\u0000\u038b\u038c"+
+		"\u0005t\u0000\u0000\u038c\u038d\u0005d\u0000\u0000\u038d\u038e\u0005e"+
+		"\u0000\u0000\u038e\u03f5\u0005v\u0000\u0000\u038f\u0390\u0005y\u0000\u0000"+
+		"\u0390\u0391\u0005e\u0000\u0000\u0391\u0392\u0005a\u0000\u0000\u0392\u03f5"+
+		"\u0005r\u0000\u0000\u0393\u0394\u0005m\u0000\u0000\u0394\u0395\u0005o"+
+		"\u0000\u0000\u0395\u0396\u0005n\u0000\u0000\u0396\u0397\u0005t\u0000\u0000"+
+		"\u0397\u03f5\u0005h\u0000\u0000\u0398\u0399\u0005d\u0000\u0000\u0399\u039a"+
+		"\u0005a\u0000\u0000\u039a\u039b\u0005y\u0000\u0000\u039b\u039c\u0005_"+
+		"\u0000\u0000\u039c\u039d\u0005o\u0000\u0000\u039d\u039e\u0005f\u0000\u0000"+
+		"\u039e\u039f\u0005_\u0000\u0000\u039f\u03a0\u0005m\u0000\u0000\u03a0\u03a1"+
+		"\u0005o\u0000\u0000\u03a1\u03a2\u0005n\u0000\u0000\u03a2\u03a3\u0005t"+
+		"\u0000\u0000\u03a3\u03f5\u0005h\u0000\u0000\u03a4\u03a5\u0005d\u0000\u0000"+
+		"\u03a5\u03a6\u0005a\u0000\u0000\u03a6\u03a7\u0005y\u0000\u0000\u03a7\u03a8"+
+		"\u0005_\u0000\u0000\u03a8\u03a9\u0005o\u0000\u0000\u03a9\u03aa\u0005f"+
+		"\u0000\u0000\u03aa\u03ab\u0005_\u0000\u0000\u03ab\u03ac\u0005w\u0000\u0000"+
+		"\u03ac\u03ad\u0005e\u0000\u0000\u03ad\u03ae\u0005e\u0000\u0000\u03ae\u03f5"+
+		"\u0005k\u0000\u0000\u03af\u03b0\u0005d\u0000\u0000\u03b0\u03b1\u0005a"+
+		"\u0000\u0000\u03b1\u03b2\u0005y\u0000\u0000\u03b2\u03b3\u0005_\u0000\u0000"+
+		"\u03b3\u03b4\u0005o\u0000\u0000\u03b4\u03b5\u0005f\u0000\u0000\u03b5\u03b6"+
+		"\u0005_\u0000\u0000\u03b6\u03b7\u0005y\u0000\u0000\u03b7\u03b8\u0005e"+
+		"\u0000\u0000\u03b8\u03b9\u0005a\u0000\u0000\u03b9\u03f5\u0005r\u0000\u0000"+
+		"\u03ba\u03bb\u0005h\u0000\u0000\u03bb\u03bc\u0005o\u0000\u0000\u03bc\u03bd"+
+		"\u0005u\u0000\u0000\u03bd\u03f5\u0005r\u0000\u0000\u03be\u03bf\u0005m"+
+		"\u0000\u0000\u03bf\u03c0\u0005i\u0000\u0000\u03c0\u03c1\u0005n\u0000\u0000"+
+		"\u03c1\u03c2\u0005u\u0000\u0000\u03c2\u03c3\u0005t\u0000\u0000\u03c3\u03f5"+
+		"\u0005e\u0000\u0000\u03c4\u03c5\u0005s\u0000\u0000\u03c5\u03c6\u0005e"+
+		"\u0000\u0000\u03c6\u03c7\u0005c\u0000\u0000\u03c7\u03c8\u0005o\u0000\u0000"+
+		"\u03c8\u03c9\u0005n\u0000\u0000\u03c9\u03f5\u0005d\u0000\u0000\u03ca\u03cb"+
+		"\u0005w\u0000\u0000\u03cb\u03cc\u0005e\u0000\u0000\u03cc\u03cd\u0005e"+
+		"\u0000\u0000\u03cd\u03ce\u0005k\u0000\u0000\u03ce\u03cf\u0005_\u0000\u0000"+
+		"\u03cf\u03d0\u0005o\u0000\u0000\u03d0\u03d1\u0005f\u0000\u0000\u03d1\u03d2"+
+		"\u0005_\u0000\u0000\u03d2\u03d3\u0005m\u0000\u0000\u03d3\u03d4\u0005o"+
+		"\u0000\u0000\u03d4\u03d5\u0005n\u0000\u0000\u03d5\u03d6\u0005t\u0000\u0000"+
+		"\u03d6\u03f5\u0005h\u0000\u0000\u03d7\u03d8\u0005w\u0000\u0000\u03d8\u03d9"+
+		"\u0005e\u0000\u0000\u03d9\u03da\u0005e\u0000\u0000\u03da\u03db\u0005k"+
+		"\u0000\u0000\u03db\u03dc\u0005_\u0000\u0000\u03dc\u03dd\u0005o\u0000\u0000"+
+		"\u03dd\u03de\u0005f\u0000\u0000\u03de\u03df\u0005_\u0000\u0000\u03df\u03e0"+
+		"\u0005y\u0000\u0000\u03e0\u03e1\u0005e\u0000\u0000\u03e1\u03e2\u0005a"+
+		"\u0000\u0000\u03e2\u03f5\u0005r\u0000\u0000\u03e3\u03e4\u0005q\u0000\u0000"+
+		"\u03e4\u03e5\u0005u\u0000\u0000\u03e5\u03e6\u0005a\u0000\u0000\u03e6\u03e7"+
+		"\u0005r\u0000\u0000\u03e7\u03e8\u0005t\u0000\u0000\u03e8\u03e9\u0005e"+
+		"\u0000\u0000\u03e9\u03f5\u0005r\u0000\u0000\u03ea\u03eb\u0005n\u0000\u0000"+
+		"\u03eb\u03ec\u0005o\u0000\u0000\u03ec\u03f5\u0005w\u0000\u0000\u03ed\u03ee"+
+		"\u0005o\u0000\u0000\u03ee\u03ef\u0005r\u0000\u0000\u03ef\u03f0\u0005_"+
+		"\u0000\u0000\u03f0\u03f1\u0005e\u0000\u0000\u03f1\u03f2\u0005l\u0000\u0000"+
+		"\u03f2\u03f3\u0005s\u0000\u0000\u03f3\u03f5\u0005e\u0000\u0000\u03f4m"+
+		"\u0001\u0000\u0000\u0000\u03f4u\u0001\u0000\u0000\u0000\u03f4}\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0088\u0001\u0000\u0000\u0000\u03f4\u0090\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0098\u0001\u0000\u0000\u0000\u03f4\u00a1\u0001\u0000"+
+		"\u0000\u0000\u03f4\u00aa\u0001\u0000\u0000\u0000\u03f4\u00ae\u0001\u0000"+
+		"\u0000\u0000\u03f4\u00b0\u0001\u0000\u0000\u0000\u03f4\u00b8\u0001\u0000"+
+		"\u0000\u0000\u03f4\u00c1\u0001\u0000\u0000\u0000\u03f4\u00c9\u0001\u0000"+
+		"\u0000\u0000\u03f4\u00d3\u0001\u0000\u0000\u0000\u03f4\u00dc\u0001\u0000"+
+		"\u0000\u0000\u03f4\u00e3\u0001\u0000\u0000\u0000\u03f4\u00f3\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0104\u0001\u0000\u0000\u0000\u03f4\u010c\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0117\u0001\u0000\u0000\u0000\u03f4\u0123\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0135\u0001\u0000\u0000\u0000\u03f4\u0148\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0159\u0001\u0000\u0000\u0000\u03f4\u016b\u0001\u0000"+
+		"\u0000\u0000\u03f4\u017f\u0001\u0000\u0000\u0000\u03f4\u0194\u0001\u0000"+
+		"\u0000\u0000\u03f4\u019a\u0001\u0000\u0000\u0000\u03f4\u01a2\u0001\u0000"+
+		"\u0000\u0000\u03f4\u01a9\u0001\u0000\u0000\u0000\u03f4\u01b3\u0001\u0000"+
+		"\u0000\u0000\u03f4\u01b9\u0001\u0000\u0000\u0000\u03f4\u01c1\u0001\u0000"+
+		"\u0000\u0000\u03f4\u01cb\u0001\u0000\u0000\u0000\u03f4\u01d2\u0001\u0000"+
+		"\u0000\u0000\u03f4\u01d6\u0001\u0000\u0000\u0000\u03f4\u01db\u0001\u0000"+
+		"\u0000\u0000\u03f4\u01e0\u0001\u0000\u0000\u0000\u03f4\u01e9\u0001\u0000"+
+		"\u0000\u0000\u03f4\u01f2\u0001\u0000\u0000\u0000\u03f4\u01fa\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0205\u0001\u0000\u0000\u0000\u03f4\u0212\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0218\u0001\u0000\u0000\u0000\u03f4\u0223\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0230\u0001\u0000\u0000\u0000\u03f4\u0240\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0245\u0001\u0000\u0000\u0000\u03f4\u024f\u0001\u0000"+
+		"\u0000\u0000\u03f4\u025a\u0001\u0000\u0000\u0000\u03f4\u0263\u0001\u0000"+
+		"\u0000\u0000\u03f4\u026b\u0001\u0000\u0000\u0000\u03f4\u0273\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0279\u0001\u0000\u0000\u0000\u03f4\u0280\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0283\u0001\u0000\u0000\u0000\u03f4\u0287\u0001\u0000"+
+		"\u0000\u0000\u03f4\u028c\u0001\u0000\u0000\u0000\u03f4\u0290\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0295\u0001\u0000\u0000\u0000\u03f4\u029b\u0001\u0000"+
+		"\u0000\u0000\u03f4\u029f\u0001\u0000\u0000\u0000\u03f4\u02a3\u0001\u0000"+
+		"\u0000\u0000\u03f4\u02a5\u0001\u0000\u0000\u0000\u03f4\u02ae\u0001\u0000"+
+		"\u0000\u0000\u03f4\u02b4\u0001\u0000\u0000\u0000\u03f4\u02b9\u0001\u0000"+
+		"\u0000\u0000\u03f4\u02bd\u0001\u0000\u0000\u0000\u03f4\u02c1\u0001\u0000"+
+		"\u0000\u0000\u03f4\u02c5\u0001\u0000\u0000\u0000\u03f4\u02c8\u0001\u0000"+
+		"\u0000\u0000\u03f4\u02cb\u0001\u0000\u0000\u0000\u03f4\u02ce\u0001\u0000"+
+		"\u0000\u0000\u03f4\u02d2\u0001\u0000\u0000\u0000\u03f4\u02d6\u0001\u0000"+
+		"\u0000\u0000\u03f4\u02da\u0001\u0000\u0000\u0000\u03f4\u02df\u0001\u0000"+
+		"\u0000\u0000\u03f4\u02e6\u0001\u0000\u0000\u0000\u03f4\u02ed\u0001\u0000"+
+		"\u0000\u0000\u03f4\u02f0\u0001\u0000\u0000\u0000\u03f4\u02f5\u0001\u0000"+
+		"\u0000\u0000\u03f4\u02fa\u0001\u0000\u0000\u0000\u03f4\u02fd\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0302\u0001\u0000\u0000\u0000\u03f4\u0307\u0001\u0000"+
+		"\u0000\u0000\u03f4\u030a\u0001\u0000\u0000\u0000\u03f4\u030e\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0314\u0001\u0000\u0000\u0000\u03f4\u0318\u0001\u0000"+
+		"\u0000\u0000\u03f4\u031b\u0001\u0000\u0000\u0000\u03f4\u031e\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0325\u0001\u0000\u0000\u0000\u03f4\u032c\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0331\u0001\u0000\u0000\u0000\u03f4\u0335\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0339\u0001\u0000\u0000\u0000\u03f4\u033f\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0345\u0001\u0000\u0000\u0000\u03f4\u034a\u0001\u0000"+
+		"\u0000\u0000\u03f4\u034e\u0001\u0000\u0000\u0000\u03f4\u0352\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0359\u0001\u0000\u0000\u0000\u03f4\u0361\u0001\u0000"+
+		"\u0000\u0000\u03f4\u036a\u0001\u0000\u0000\u0000\u03f4\u0372\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0378\u0001\u0000\u0000\u0000\u03f4\u0381\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0384\u0001\u0000\u0000\u0000\u03f4\u0387\u0001\u0000"+
+		"\u0000\u0000\u03f4\u038a\u0001\u0000\u0000\u0000\u03f4\u038f\u0001\u0000"+
+		"\u0000\u0000\u03f4\u0393\u0001\u0000\u0000\u0000\u03f4\u0398\u0001\u0000"+
+		"\u0000\u0000\u03f4\u03a4\u0001\u0000\u0000\u0000\u03f4\u03af\u0001\u0000"+
+		"\u0000\u0000\u03f4\u03ba\u0001\u0000\u0000\u0000\u03f4\u03be\u0001\u0000"+
+		"\u0000\u0000\u03f4\u03c4\u0001\u0000\u0000\u0000\u03f4\u03ca\u0001\u0000"+
+		"\u0000\u0000\u03f4\u03d7\u0001\u0000\u0000\u0000\u03f4\u03e3\u0001\u0000"+
+		"\u0000\u0000\u03f4\u03ea\u0001\u0000\u0000\u0000\u03f4\u03ed\u0001\u0000"+
+		"\u0000\u0000\u03f5\u0002\u0001\u0000\u0000\u0000\u03f6\u03f7\u0005i\u0000"+
+		"\u0000\u03f7\u03f8\u0005m\u0000\u0000\u03f8\u03f9\u0005p\u0000\u0000\u03f9"+
+		"\u03fa\u0005o\u0000\u0000\u03fa\u03fb\u0005r\u0000\u0000\u03fb\u03fc\u0005"+
+		"t\u0000\u0000\u03fc\u0004\u0001\u0000\u0000\u0000\u03fd\u03fe\u0005i\u0000"+
+		"\u0000\u03fe\u03ff\u0005n\u0000\u0000\u03ff\u0400\u0005t\u0000\u0000\u0400"+
+		"\u0401\u0005e\u0000\u0000\u0401\u0402\u0005n\u0000\u0000\u0402\u0403\u0005"+
+		"t\u0000\u0000\u0403\u0006\u0001\u0000\u0000\u0000\u0404\u0405\u0005o\u0000"+
+		"\u0000\u0405\u0406\u0005p\u0000\u0000\u0406\u0407\u0005t\u0000\u0000\u0407"+
+		"\u0408\u0005i\u0000\u0000\u0408\u0409\u0005o\u0000\u0000\u0409\u040a\u0005"+
+		"n\u0000\u0000\u040a\u040b\u0005s\u0000\u0000\u040b\b\u0001\u0000\u0000"+
+		"\u0000\u040c\u040d\u0005f\u0000\u0000\u040d\u040e\u0005l\u0000\u0000\u040e"+
+		"\u040f\u0005o\u0000\u0000\u040f\u0410\u0005w\u0000\u0000\u0410\n\u0001"+
+		"\u0000\u0000\u0000\u0411\u0412\u0005m\u0000\u0000\u0412\u0413\u0005e\u0000"+
+		"\u0000\u0413\u0414\u0005t\u0000\u0000\u0414\u0415\u0005a\u0000\u0000\u0415"+
+		"\f\u0001\u0000\u0000\u0000\u0416\u0417\u0005t\u0000\u0000\u0417\u0418"+
+		"\u0005e\u0000\u0000\u0418\u0419\u0005r\u0000\u0000\u0419\u041a\u0005m"+
+		"\u0000\u0000\u041a\u000e\u0001\u0000\u0000\u0000\u041b\u041c\u0005f\u0000"+
+		"\u0000\u041c\u041d\u0005r\u0000\u0000\u041d\u041e\u0005a\u0000\u0000\u041e"+
+		"\u041f\u0005g\u0000\u0000\u041f\u0420\u0005m\u0000\u0000\u0420\u0421\u0005"+
+		"e\u0000\u0000\u0421\u0422\u0005n\u0000\u0000\u0422\u0423\u0005t\u0000"+
+		"\u0000\u0423\u0010\u0001\u0000\u0000\u0000\u0424\u042a\u00035\u001a\u0000"+
+		"\u0425\u0429\b\u0000\u0000\u0000\u0426\u0427\u0005\\\u0000\u0000\u0427"+
+		"\u0429\u0005\'\u0000\u0000\u0428\u0425\u0001\u0000\u0000\u0000\u0428\u0426"+
+		"\u0001\u0000\u0000\u0000\u0429\u042c\u0001\u0000\u0000\u0000\u042a\u0428"+
+		"\u0001\u0000\u0000\u0000\u042a\u042b\u0001\u0000\u0000\u0000\u042b\u042d"+
+		"\u0001\u0000\u0000\u0000\u042c\u042a\u0001\u0000\u0000\u0000\u042d\u042e"+
+		"\u00035\u001a\u0000\u042e\u0012\u0001\u0000\u0000\u0000\u042f\u0435\u0003"+
+		"7\u001b\u0000\u0430\u0434\b\u0001\u0000\u0000\u0431\u0432\u0005\\\u0000"+
+		"\u0000\u0432\u0434\u0005\"\u0000\u0000\u0433\u0430\u0001\u0000\u0000\u0000"+
+		"\u0433\u0431\u0001\u0000\u0000\u0000\u0434\u0437\u0001\u0000\u0000\u0000"+
+		"\u0435\u0433\u0001\u0000\u0000\u0000\u0435\u0436\u0001\u0000\u0000\u0000"+
+		"\u0436\u0438\u0001\u0000\u0000\u0000\u0437\u0435\u0001\u0000\u0000\u0000"+
+		"\u0438\u0439\u00037\u001b\u0000\u0439\u0014\u0001\u0000\u0000\u0000\u043a"+
+		"\u043b\u0005t\u0000\u0000\u043b\u043c\u0005r\u0000\u0000\u043c\u043d\u0005"+
+		"u\u0000\u0000\u043d\u0444\u0005e\u0000\u0000\u043e\u043f\u0005f\u0000"+
+		"\u0000\u043f\u0440\u0005a\u0000\u0000\u0440\u0441\u0005l\u0000\u0000\u0441"+
+		"\u0442\u0005s\u0000\u0000\u0442\u0444\u0005e\u0000\u0000\u0443\u043a\u0001"+
+		"\u0000\u0000\u0000\u0443\u043e\u0001\u0000\u0000\u0000\u0444\u0016\u0001"+
+		"\u0000\u0000\u0000\u0445\u0446\u0005n\u0000\u0000\u0446\u0447\u0005u\u0000"+
+		"\u0000\u0447\u0448\u0005l\u0000\u0000\u0448\u0449\u0005l\u0000\u0000\u0449"+
+		"\u0018\u0001\u0000\u0000\u0000\u044a\u044b\u0005=\u0000\u0000\u044b\u044c"+
+		"\u0005=\u0000\u0000\u044c\u001a\u0001\u0000\u0000\u0000\u044d\u044e\u0005"+
+		"!\u0000\u0000\u044e\u044f\u0005=\u0000\u0000\u044f\u001c\u0001\u0000\u0000"+
+		"\u0000\u0450\u0451\u0005>\u0000\u0000\u0451\u0452\u0005=\u0000\u0000\u0452"+
+		"\u001e\u0001\u0000\u0000\u0000\u0453\u0454\u0005<\u0000\u0000\u0454\u0455"+
+		"\u0005=\u0000\u0000\u0455 \u0001\u0000\u0000\u0000\u0456\u0457\u0005>"+
+		"\u0000\u0000\u0457\"\u0001\u0000\u0000\u0000\u0458\u0459\u0005<\u0000"+
+		"\u0000\u0459$\u0001\u0000\u0000\u0000\u045a\u045b\u0005&\u0000\u0000\u045b"+
+		"\u045c\u0005&\u0000\u0000\u045c&\u0001\u0000\u0000\u0000\u045d\u045e\u0005"+
+		"|\u0000\u0000\u045e\u045f\u0005|\u0000\u0000\u045f(\u0001\u0000\u0000"+
+		"\u0000\u0460\u0461\u0005|\u0000\u0000\u0461*\u0001\u0000\u0000\u0000\u0462"+
+		"\u0463\u0005!\u0000\u0000\u0463,\u0001\u0000\u0000\u0000\u0464\u0465\u0005"+
+		"(\u0000\u0000\u0465.\u0001\u0000\u0000\u0000\u0466\u0467\u0005)\u0000"+
+		"\u0000\u04670\u0001\u0000\u0000\u0000\u0468\u0469\u0005{\u0000\u0000\u0469"+
+		"2\u0001\u0000\u0000\u0000\u046a\u046b\u0005}\u0000\u0000\u046b4\u0001"+
+		"\u0000\u0000\u0000\u046c\u046d\u0005\'\u0000\u0000\u046d6\u0001\u0000"+
+		"\u0000\u0000\u046e\u046f\u0005\"\u0000\u0000\u046f8\u0001\u0000\u0000"+
+		"\u0000\u0470\u0471\u0005~\u0000\u0000\u0471:\u0001\u0000\u0000\u0000\u0472"+
+		"\u0473\u0005[\u0000\u0000\u0473<\u0001\u0000\u0000\u0000\u0474\u0475\u0005"+
+		"]\u0000\u0000\u0475>\u0001\u0000\u0000\u0000\u0476\u0477\u0005#\u0000"+
+		"\u0000\u0477@\u0001\u0000\u0000\u0000\u0478\u0479\u0005,\u0000\u0000\u0479"+
+		"B\u0001\u0000\u0000\u0000\u047a\u047b\u0005:\u0000\u0000\u047bD\u0001"+
+		"\u0000\u0000\u0000\u047c\u047d\u0005-\u0000\u0000\u047dF\u0001\u0000\u0000"+
+		"\u0000\u047e\u047f\u0005.\u0000\u0000\u047fH\u0001\u0000\u0000\u0000\u0480"+
+		"\u0481\u0005_\u0000\u0000\u0481J\u0001\u0000\u0000\u0000\u0482\u0483\u0005"+
+		"=\u0000\u0000\u0483L\u0001\u0000\u0000\u0000\u0484\u0485\u0005+\u0000"+
+		"\u0000\u0485N\u0001\u0000\u0000\u0000\u0486\u0487\u0005?\u0000\u0000\u0487"+
+		"P\u0001\u0000\u0000\u0000\u0488\u0489\u0005*\u0000\u0000\u0489R\u0001"+
+		"\u0000\u0000\u0000\u048a\u048b\u0005/\u0000\u0000\u048bT\u0001\u0000\u0000"+
+		"\u0000\u048c\u048d\u0005%\u0000\u0000\u048dV\u0001\u0000\u0000\u0000\u048e"+
+		"\u048f\u0005@\u0000\u0000\u048fX\u0001\u0000\u0000\u0000\u0490\u0491\u0005"+
+		"$\u0000\u0000\u0491Z\u0001\u0000\u0000\u0000\u0492\u049b\u00050\u0000"+
+		"\u0000\u0493\u0497\u0007\u0002\u0000\u0000\u0494\u0496\u0007\u0003\u0000"+
+		"\u0000\u0495\u0494\u0001\u0000\u0000\u0000\u0496\u0499\u0001\u0000\u0000"+
+		"\u0000\u0497\u0495\u0001\u0000\u0000\u0000\u0497\u0498\u0001\u0000\u0000"+
+		"\u0000\u0498\u049b\u0001\u0000\u0000\u0000\u0499\u0497\u0001\u0000\u0000"+
+		"\u0000\u049a\u0492\u0001\u0000\u0000\u0000\u049a\u0493\u0001\u0000\u0000"+
+		"\u0000\u049b\\\u0001\u0000\u0000\u0000\u049c\u049e\u0003G#\u0000\u049d"+
+		"\u049f\u0007\u0004\u0000\u0000\u049e\u049d\u0001\u0000\u0000\u0000\u049f"+
+		"\u04a0\u0001\u0000\u0000\u0000\u04a0\u049e\u0001\u0000\u0000\u0000\u04a0"+
+		"\u04a1\u0001\u0000\u0000\u0000\u04a1^\u0001\u0000\u0000\u0000\u04a2\u04a4"+
+		"\u0007\u0005\u0000\u0000\u04a3\u04a5\u0007\u0006\u0000\u0000\u04a4\u04a3"+
+		"\u0001\u0000\u0000\u0000\u04a4\u04a5\u0001\u0000\u0000\u0000\u04a5\u04a6"+
+		"\u0001\u0000\u0000\u0000\u04a6\u04a7\u0003[-\u0000\u04a7`\u0001\u0000"+
+		"\u0000\u0000\u04a8\u04ac\b\u0007\u0000\u0000\u04a9\u04aa\u0007\b\u0000"+
+		"\u0000\u04aa\u04ac\u0007\t\u0000\u0000\u04ab\u04a8\u0001\u0000\u0000\u0000"+
+		"\u04ab\u04a9\u0001\u0000\u0000\u0000\u04acb\u0001\u0000\u0000\u0000\u04ad"+
+		"\u04ae\u0007\n\u0000\u0000\u04aed\u0001\u0000\u0000\u0000\u04af\u04b4"+
+		"\u0003a0\u0000\u04b0\u04b4\u0003I$\u0000\u04b1\u04b4\u0003c1\u0000\u04b2"+
+		"\u04b4\u0003Y,\u0000\u04b3\u04af\u0001\u0000\u0000\u0000\u04b3\u04b0\u0001"+
+		"\u0000\u0000\u0000\u04b3\u04b1\u0001\u0000\u0000\u0000\u04b3\u04b2\u0001"+
+		"\u0000\u0000\u0000\u04b4\u04b5\u0001\u0000\u0000\u0000\u04b5\u04b3\u0001"+
+		"\u0000\u0000\u0000\u04b5\u04b6\u0001\u0000\u0000\u0000\u04b6\u04c0\u0001"+
+		"\u0000\u0000\u0000\u04b7\u04bf\u0003a0\u0000\u04b8\u04bf\u0003Y,\u0000"+
+		"\u04b9\u04bf\u0003c1\u0000\u04ba\u04bf\u0007\u0004\u0000\u0000\u04bb\u04bf"+
+		"\u0003C!\u0000\u04bc\u04bf\u0003E\"\u0000\u04bd\u04bf\u0003I$\u0000\u04be"+
+		"\u04b7\u0001\u0000\u0000\u0000\u04be\u04b8\u0001\u0000\u0000\u0000\u04be"+
+		"\u04b9\u0001\u0000\u0000\u0000\u04be\u04ba\u0001\u0000\u0000\u0000\u04be"+
+		"\u04bb\u0001\u0000\u0000\u0000\u04be\u04bc\u0001\u0000\u0000\u0000\u04be"+
+		"\u04bd\u0001\u0000\u0000\u0000\u04bf\u04c2\u0001\u0000\u0000\u0000\u04c0"+
+		"\u04be\u0001\u0000\u0000\u0000\u04c0\u04c1\u0001\u0000\u0000\u0000\u04c1"+
+		"f\u0001\u0000\u0000\u0000\u04c2\u04c0\u0001\u0000\u0000\u0000\u04c3\u04c4"+
+		"\u0005/\u0000\u0000\u04c4\u04c5\u0005/\u0000\u0000\u04c5\u04c9\u0001\u0000"+
+		"\u0000\u0000\u04c6\u04c8\b\u000b\u0000\u0000\u04c7\u04c6\u0001\u0000\u0000"+
+		"\u0000\u04c8\u04cb\u0001\u0000\u0000\u0000\u04c9\u04c7\u0001\u0000\u0000"+
+		"\u0000\u04c9\u04ca\u0001\u0000\u0000\u0000\u04ca\u04cd\u0001\u0000\u0000"+
+		"\u0000\u04cb\u04c9\u0001\u0000\u0000\u0000\u04cc\u04ce\u0005\r\u0000\u0000"+
+		"\u04cd\u04cc\u0001\u0000\u0000\u0000\u04cd\u04ce\u0001\u0000\u0000\u0000"+
+		"\u04ce\u04d0\u0001\u0000\u0000\u0000\u04cf\u04d1\u0007\f\u0000\u0000\u04d0"+
+		"\u04cf\u0001\u0000\u0000\u0000\u04d1\u04de\u0001\u0000\u0000\u0000\u04d2"+
+		"\u04d3\u0005/\u0000\u0000\u04d3\u04d4\u0005*\u0000\u0000\u04d4\u04d8\u0001"+
+		"\u0000\u0000\u0000\u04d5\u04d7\t\u0000\u0000\u0000\u04d6\u04d5\u0001\u0000"+
+		"\u0000\u0000\u04d7\u04da\u0001\u0000\u0000\u0000\u04d8\u04d9\u0001\u0000"+
+		"\u0000\u0000\u04d8\u04d6\u0001\u0000\u0000\u0000\u04d9\u04db\u0001\u0000"+
+		"\u0000\u0000\u04da\u04d8\u0001\u0000\u0000\u0000\u04db\u04dc\u0005*\u0000"+
+		"\u0000\u04dc\u04de\u0005/\u0000\u0000\u04dd\u04c3\u0001\u0000\u0000\u0000"+
+		"\u04dd\u04d2\u0001\u0000\u0000\u0000\u04de\u04df\u0001\u0000\u0000\u0000"+
+		"\u04df\u04e0\u00063\u0000\u0000\u04e0h\u0001\u0000\u0000\u0000\u04e1\u04e3"+
+		"\u0007\r\u0000\u0000\u04e2\u04e1\u0001\u0000\u0000\u0000\u04e3\u04e4\u0001"+
+		"\u0000\u0000\u0000\u04e4\u04e2\u0001\u0000\u0000\u0000\u04e4\u04e5\u0001"+
+		"\u0000\u0000\u0000\u04e5\u04e6\u0001\u0000\u0000\u0000\u04e6\u04e7\u0006"+
+		"4\u0000\u0000\u04e7j\u0001\u0000\u0000\u0000\u04e8\u04e9\t\u0000\u0000"+
+		"\u0000\u04e9l\u0001\u0000\u0000\u0000\u0016\u0000\u03f4\u0428\u042a\u0433"+
+		"\u0435\u0443\u0497\u049a\u04a0\u04a4\u04ab\u04b3\u04b5\u04be\u04c0\u04c9"+
+		"\u04cd\u04d0\u04d8\u04dd\u04e4\u0001\u0006\u0000\u0000";
 	public static final ATN _ATN =
 		new ATNDeserializer().deserialize(_serializedATN.toCharArray());
 	static {
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCNLPEntityParser.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCNLPEntityParser.scala
index cf1b3225..18f525b7 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCNLPEntityParser.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCNLPEntityParser.scala
@@ -26,14 +26,14 @@ import java.util.stream.Collectors
   * [[NCNLPEntityParser]] helper.
   */
 private object NCNLPEntityParser:
-    private val id: String = "nlp:entity"
+    private val entityType: String = "nlp:entity"
 
 import NCNLPEntityParser.*
 
 /**
   *  NLP data [[NCEntityParser entity parser]].
   *
-  * This parser converts list of input [[NCToken]] instances one-to-one to list of [[NCEntity]] instances with ID **nlp:entity**.
+  * This parser converts list of input [[NCToken]] instances one-to-one to list of [[NCEntity]] instances with type **nlp:entity**.
   * All [[NCEntity]] instances contain following mandatory [[NCPropertyMap metadata]] properties:
   *  - nlp:entity:text
   *  - nlp:entity:index
@@ -54,14 +54,14 @@ class NCNLPEntityParser(predicate: NCToken => Boolean = _ => true) extends NCEnt
     override def parse(req: NCRequest, cfg: NCModelConfig, toks: List[NCToken]): List[NCEntity] =
         toks.filter(predicate).map(t =>
             new NCPropertyMapAdapter with NCEntity:
-                put(s"$id:text", t.getText)
-                put(s"$id:index", t.getIndex)
-                put(s"$id:startCharIndex", t.getStartCharIndex)
-                put(s"$id:endCharIndex", t.getEndCharIndex)
+                put(s"$entityType:text", t.getText)
+                put(s"$entityType:index", t.getIndex)
+                put(s"$entityType:startCharIndex", t.getStartCharIndex)
+                put(s"$entityType:endCharIndex", t.getEndCharIndex)
 
-                t.keysSet.foreach(key => put(s"$id:$key", t(key)))
+                t.keysSet.foreach(key => put(s"$entityType:$key", t(key)))
 
                 override val getTokens: List[NCToken] = List(t)
                 override val getRequestId: String = req.getRequestId
-                override val getType: String = id
+                override val getType: String = entityType
         )
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCOpenNLPEntityParser.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCOpenNLPEntityParser.scala
index 8314c6c8..1b752478 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCOpenNLPEntityParser.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCOpenNLPEntityParser.scala
@@ -37,8 +37,8 @@ import scala.util.Using
   *  [[https://opennlp.apache.org/ OpenNLP]] **name finders** models.
   *
   * This parser prepares [[NCEntity]] instances which are detected by given models.
-  * These entities are created with ID `opennlp:modelId`, where `modelId` is [[https://opennlp.apache.org/ OpenNLP]] model ID.
-  * Also this parser adds `opennlp:modelId:probability` double [[NCPropertyMap metadata]] property to the
+  * These entities are created with type `opennlp:modelName`, where `modelName` is [[https://opennlp.apache.org/ OpenNLP]] model name.
+  * Also this parser adds `opennlp:modelName:probability` double [[NCPropertyMap metadata]] property to the
   * created entities extracted from related [[https://opennlp.apache.org/ OpenNLP]] model.
   *
   * Some of OpenNLP prepared models can be found [[https://opennlp.sourceforge.net/models-1.5/ here]].
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParser.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParser.scala
index e0b2f816..b6bc2e32 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParser.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParser.scala
@@ -248,13 +248,13 @@ class NCSemanticEntityParser private (
 
         for (piece <- getPieces(toks) if !hs.exists(_.isSuperSet(piece.baseTokens));
             variant <- Seq(piece.baseTokens) ++ piece.variants)
-            def add(elemId: String, value: Option[String]): Unit = hs += Holder(elemId, variant, value)
+            def add(elemType: String, value: Option[String]): Unit = hs += Holder(elemType, variant, value)
 
             val idxs = variant.map(_.getIndex)
             if cache.add(idxs) then
                 // Tries to search by stems.
                 synsHolder.textSynonyms.get(variant.map(stems).mkString(" ")) match
-                    case Some(elems) => elems.foreach(elem => add(elem.elementId, elem.value))
+                    case Some(elems) => elems.foreach(elem => add(elem.elementType, elem.value))
                     case None =>
                         // Combines stems(origin) and stems(lemma)
                         var found = false
@@ -263,10 +263,10 @@ class NCSemanticEntityParser private (
                                 synsHolder.textSynonyms.get(comb.mkString(" ")) match
                                     case Some(elems) =>
                                         found = true
-                                        elems.foreach(elem => add(elem.elementId, elem.value))
+                                        elems.foreach(elem => add(elem.elementType, elem.value))
                                     case None => // No-op.
                         // With regex.
-                        for ((elemId, syns) <- synsHolder.mixedSynonyms.getOrElse(variant.size, List.empty))
+                        for ((elemType, syns) <- synsHolder.mixedSynonyms.getOrElse(variant.size, List.empty))
                             found = false
 
                             for (s <- syns if !found)
@@ -280,7 +280,7 @@ class NCSemanticEntityParser private (
                                             match0(tok.getText) || match0(tok.getText.toLowerCase)
                                     }
 
-                                if found then add(elemId, Option.when(s.value != null)(s.value))
+                                if found then add(elemType, Option.when(s.value != null)(s.value))
 
         // Deletes redundant.
         hs = hs.distinct
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSynonymsProcessor.scala b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSynonymsProcessor.scala
index 0102a158..196afd7e 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSynonymsProcessor.scala
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/nlp/parsers/impl/NCSemanticSynonymsProcessor.scala
@@ -36,10 +36,10 @@ import scala.collection.mutable.ArrayBuffer
 
 /**
   *
-  * @param elementId
+  * @param elementType
   * @param value
   */
-private[parsers] case class NCSemanticSynonymsElementData(elementId: String, value: Option[String])
+private[parsers] case class NCSemanticSynonymsElementData(elementType: String, value: Option[String])
 
 /**
   *
@@ -57,7 +57,7 @@ private[parsers] case class NCSemanticSynonymsHolder(
 private[parsers] object NCSemanticSynonymsProcessor extends LazyLogging:
     private final val SUSP_SYNS_CHARS = Seq("?", "*", "+")
     private final val REGEX_FIX = "//"
-    private final val ID_REGEX = "^[_a-zA-Z]+[a-zA-Z0-9:\\-_]*$"
+    private final val TYPE_REGEX = "^[_a-zA-Z]+[a-zA-Z0-9:\\-_]*$"
 
     /**
       *
@@ -91,13 +91,13 @@ private[parsers] object NCSemanticSynonymsProcessor extends LazyLogging:
     /**
       *
       * @param syns
-      * @param elemId
+      * @param elemType
       * @param valueName
       */
-    private def checkSynonyms(syns: Set[String], elemId: String, valueName: Option[String] = None): Unit =
+    private def checkSynonyms(syns: Set[String], elemType: String, valueName: Option[String] = None): Unit =
         def mkDesc: String =
             val valuePart = if valueName.isDefined then s", value=${valueName.get}" else ""
-            s"[id=$elemId$valuePart]"
+            s"[type=$elemType$valuePart]"
 
         if syns != null then
             if hasNullOrEmpty(syns) then E(s"Some synonyms are null or empty $mkDesc")
@@ -115,40 +115,40 @@ private[parsers] object NCSemanticSynonymsProcessor extends LazyLogging:
         if elems.contains(null) then E("Some elements are null.")
 
         // Duplicates.
-        val ids = mutable.HashSet.empty[String]
+        val types = mutable.HashSet.empty[String]
 
-        for (id <- elems.map(_.getType))
-            if ids.contains(id) then E(s"Duplicate element ID [element=$id]")
-            else ids += id
+        for (typ <- elems.map(_.getType))
+            if types.contains(typ) then E(s"Duplicate element type [type=$typ]")
+            else types += typ
 
         for (e <- elems)
-            val elemId = e.getType
+            val typ = e.getType
 
-            if elemId == null || elemId.isEmpty then E(s"Some element IDs are not provided or empty.")
-            else if !elemId.matches(ID_REGEX) then E(s"Element ID does not match regex [element=$elemId, regex=$ID_REGEX]")
-            else if elemId.exists(_.isWhitespace) then E(s"Element ID cannot have whitespaces [element=$elemId]")
+            if typ == null || typ.isEmpty then E(s"Some element types are not provided or empty.")
+            else if !typ.matches(TYPE_REGEX) then E(s"Element type does not match regex [type=$typ, regex=$TYPE_REGEX]")
+            else if typ.exists(_.isWhitespace) then E(s"Element type cannot have whitespaces [type=$typ]")
 
-            checkSynonyms(e.getSynonyms, elemId)
+            checkSynonyms(e.getSynonyms, typ)
 
             val vals = e.getValues
             if vals != null then
-                if hasNullOrEmpty(vals.keySet) then E(s"Some values names are null or empty [element=$elemId]")
+                if hasNullOrEmpty(vals.keySet) then E(s"Some values names are null or empty [element=$typ]")
                 for ((name, syns) <- vals)
-                    checkSynonyms(syns, elemId, name.?)
+                    checkSynonyms(syns, typ, name.?)
 
     /**
       *
       * @param stemmer
       * @param tokParser
       * @param macroParser
-      * @param elemId
+      * @param elemType
       * @param syns
       */
     private def convertSynonyms(
         stemmer: NCStemmer,
         tokParser: NCTokenParser,
         macroParser: NCMacroParser,
-        elemId: String,
+        elemType: String,
         syns: Set[String]
     ): List[List[NCSemanticSynonymChunk]] =
         case class RegexHolder(text: String, var used: Boolean = false):
@@ -159,8 +159,8 @@ private[parsers] object NCSemanticSynonymsProcessor extends LazyLogging:
 
                 if ptrn.nonEmpty then
                     try NCSemanticSynonymChunk(REGEX, text, regex = Pattern.compile(ptrn))
-                    catch case e: PatternSyntaxException => E(s"Invalid regex synonym syntax detected [element=$elemId, chunk=$text]", e)
-                else E(s"Empty regex synonym detected [element=$elemId]")
+                    catch case e: PatternSyntaxException => E(s"Invalid regex synonym syntax detected [element=$elemType, chunk=$text]", e)
+                else E(s"Empty regex synonym detected [element=$elemType]")
 
         val regexes = mutable.HashMap.empty[Int, RegexHolder]
 
@@ -221,22 +221,22 @@ private[parsers] object NCSemanticSynonymsProcessor extends LazyLogging:
 
         if macros != null then for ((name, body) <- macros) macroParser.addMacro(name, body)
 
-        case class Holder(synonym: NCSemanticSynonym, elementId: String):
+        case class Holder(synonym: NCSemanticSynonym, elementType: String):
             lazy val root: String = synonym.chunks.map(p => if p.isText then p.stem else p.text).mkString(" ")
 
         val buf = mutable.ArrayBuffer.empty[Holder]
 
         for (e <- elements)
-            val elemId = e.getType
+            val elemType = e.getType
 
-            def add(syns: Seq[NCSemanticSynonym]): Unit = buf ++= syns.map(Holder(_, elemId))
+            def add(syns: Seq[NCSemanticSynonym]): Unit = buf ++= syns.map(Holder(_, elemType))
             def addSpec(txt: String, value: String = null): Unit =
-                buf += Holder(NCSemanticSynonym(Seq(NCSemanticSynonymChunk(TEXT, txt, stemmer.stem(txt.toLowerCase))), value), elemId)
+                buf += Holder(NCSemanticSynonym(Seq(NCSemanticSynonymChunk(TEXT, txt, stemmer.stem(txt.toLowerCase))), value), elemType)
 
-            addSpec(elemId)
+            addSpec(elemType)
 
             if e.getSynonyms != null then
-                add(convertSynonyms(stemmer, tokParser, macroParser, elemId, e.getSynonyms).map(NCSemanticSynonym(_)))
+                add(convertSynonyms(stemmer, tokParser, macroParser, elemType, e.getSynonyms).map(NCSemanticSynonym(_)))
 
             if e.getValues != null then
                 for ((name, syns) <- e.getValues)
@@ -244,16 +244,16 @@ private[parsers] object NCSemanticSynonymsProcessor extends LazyLogging:
 
                     if syns != null then
                         add(
-                            convertSynonyms(stemmer, tokParser, macroParser, elemId, syns).
+                            convertSynonyms(stemmer, tokParser, macroParser, elemType, syns).
                                 map(chunks => NCSemanticSynonym(chunks, value = name))
                         )
 
         buf.groupBy(_.root).values.foreach(hs => {
-            val elemIds = hs.map(_.elementId).toSet
+            val elemTypes = hs.map(_.elementType).toSet
 
-            if elemIds.size > 1 then
+            if elemTypes.size > 1 then
                 for (s <- hs.map(_.synonym).distinct)
-                    logger.warn(s"Synonym appears in multiple elements [synonym='${s.chunks.mkString(" ")}', elements=${elemIds.mkString("{", ",", "}")}]")
+                    logger.warn(s"Synonym appears in multiple elements [synonym='${s.chunks.mkString(" ")}', elements=${elemTypes.mkString("{", ",", "}")}]")
         })
 
         val txtBuf = buf.filter(_.synonym.isText)
@@ -262,13 +262,13 @@ private[parsers] object NCSemanticSynonymsProcessor extends LazyLogging:
             map { (stem, hs) =>
                 stem ->
                     hs.map(h =>
-                        NCSemanticSynonymsElementData(h.elementId, Option.when(h.synonym.value != null)(h.synonym.value))
+                        NCSemanticSynonymsElementData(h.elementType, Option.when(h.synonym.value != null)(h.synonym.value))
                     ).toSet
             }
 
         buf --= txtBuf
 
         val mixedSyns = buf.groupBy(_.synonym.size).
-            map { (size, hs) => size -> hs.groupBy(_.elementId).map { (id, hs) => id -> hs.map(_.synonym).toSeq } }
+            map { (size, hs) => size -> hs.groupBy(_.elementType).map { (typ, hs) => typ -> hs.map(_.synonym).toSeq } }
 
         NCSemanticSynonymsHolder(txtSyns, mixedSyns)
\ No newline at end of file
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/impl/NCModelClientSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/impl/NCModelClientSpec.scala
index 89760017..2f422821 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/impl/NCModelClientSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/impl/NCModelClientSpec.scala
@@ -34,7 +34,7 @@ class NCModelClientSpec extends AnyFunSuite:
       * @param e
       */
     private def s(e: NCEntity): String =
-        s"Entity [id=${e.getType}, text=${e.mkText}, properties={${e.keysSet.map(k => s"$k=${e(k)}")}}]"
+        s"Entity [type=${e.getType}, text=${e.mkText}, properties={${e.keysSet.map(k => s"$k=${e(k)}")}}]"
 
     /**
       *
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntity.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntity.scala
index 2c2a8766..2e0ff65b 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntity.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/internal/intent/compiler/functions/NCIDLFunctionsEntity.scala
@@ -100,7 +100,7 @@ class NCIDLFunctionsEntity extends NCIDLFunctions:
 
         test(
             TestDesc(
-                truth = "ent_is_before_id('2')",
+                truth = "ent_is_before_type('2')",
                 entity = e1,
                 idlCtx = ctx
             ),
@@ -110,7 +110,7 @@ class NCIDLFunctionsEntity extends NCIDLFunctions:
                 idlCtx = ctx
             ),
             TestDesc(
-                truth = "ent_is_after_id('1')",
+                truth = "ent_is_after_type('1')",
                 entity = e2,
                 idlCtx = ctx
             ),
@@ -131,7 +131,7 @@ class NCIDLFunctionsEntity extends NCIDLFunctions:
 
         test(
             TestDesc(
-                truth = "ent_is_between_ids('1', '3')",
+                truth = "ent_is_between_types('1', '3')",
                 entity = e2,
                 idlCtx = ctx
             ),
@@ -156,7 +156,7 @@ class NCIDLFunctionsEntity extends NCIDLFunctions:
                 idlCtx = ctx
             ),
             TestDesc(
-                truth = "size(ent_all_for_id('2')) == 2",
+                truth = "size(ent_all_for_type('2')) == 2",
                 idlCtx = ctx
             ),
             TestDesc(
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityMapperSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityMapperSpec.scala
index 9b32ab7f..b82c1600 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityMapperSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/NCEntityMapperSpec.scala
@@ -29,9 +29,9 @@ import scala.util.Using
   *
   */
 class NCEntityMapperSpec extends AnyFunSuite:
-    private case class Combiner(ids: String*) extends NCEntityMapper:
+    private case class Combiner(types: String*) extends NCEntityMapper:
         override def map(req: NCRequest, cfg: NCModelConfig, es: List[NCEntity]): List[NCEntity] =
-            val replaced = es.filter(p => ids.contains(p.getType))
+            val replaced = es.filter(p => types.contains(p.getType))
 
             if replaced.isEmpty then
                 es
@@ -39,7 +39,7 @@ class NCEntityMapperSpec extends AnyFunSuite:
                 val newEntity: NCEntity = new NCPropertyMapAdapter with NCEntity:
                     override val getTokens: List[NCToken] = replaced.flatMap(_.getTokens).sortBy(_.getIndex).toList
                     override val getRequestId: String = req.getRequestId
-                    override val getType: String = ids.mkString
+                    override val getType: String = types.mkString
 
                 val buf = collection.mutable.ArrayBuffer.empty[NCEntity]
                 buf ++= es
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserJsonSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserJsonSpec.scala
index 68ce0ed7..26b6ee44 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserJsonSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserJsonSpec.scala
@@ -35,20 +35,20 @@ class NCSemanticEntityParserJsonSpec extends AnyFunSuite:
     /**
       * 
       * @param txt
-      * @param id
+      * @param typ
       * @param elemData
       */
-    private def check(txt: String, id: String, elemData: Option[Map[String, Any]] = None): Unit =
+    private def check(txt: String, typ: String, elemData: Option[Map[String, Any]] = None): Unit =
         val req = NCTestRequest(txt)
         val ents = semParser.parse(req, CFG, EN_TOK_PARSER.tokenize(req.txt))
 
         NCTestUtils.printEntities(txt, ents)
 
         val tok = ents.head
-        
-        require(tok.getType == id)
+
+        require(tok.getType == typ)
         elemData match
-            case Some(m) => m.foreach { (k, v) => require(tok[Any](s"$id:$k") == v) }
+            case Some(m) => m.foreach { (k, v) => require(tok[Any](s"$typ:$k") == v) }
             case None => // No-op.
 
     /**
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserLemmaSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserLemmaSpec.scala
index 312c85ef..512fdeb3 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserLemmaSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserLemmaSpec.scala
@@ -36,7 +36,7 @@ class NCSemanticEntityParserLemmaSpec extends AnyFunSuite:
         new NCStemmer():
             override def stem(word: String): String = if wrapped(word) then unwrap(word) else UUID.randomUUID().toString
 
-    case class Data(text: String, elemId: String)
+    case class Data(text: String, elemType: String)
 
     private def wrap(s: String): String =
         require(s != null)
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserYamlSpec.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserYamlSpec.scala
index 5239ce1f..b3fc72ae 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserYamlSpec.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticEntityParserYamlSpec.scala
@@ -35,17 +35,17 @@ class NCSemanticEntityParserYamlSpec extends AnyFunSuite:
     /**
       * 
       * @param txt
-      * @param id
+      * @param typ
       */
-    private def check(txt: String, id: String): Unit =
+    private def check(txt: String, typ: String): Unit =
         val req = NCTestRequest(txt)
         val ents = semParser.parse(req, CFG, EN_TOK_PARSER.tokenize(req.txt))
 
         NCTestUtils.printEntities(txt, ents)
 
         val tok = ents.head
-        
-        require(tok.getType == id)
+
+        require(tok.getType == typ)
 
     /**
       * 
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticTestElement.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticTestElement.scala
index ee58ecd0..d95ad025 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticTestElement.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/parsers/NCSemanticTestElement.scala
@@ -24,19 +24,19 @@ import java.util
 
 /**
   *
-  * @param id
+  * @param typ
   * @param synonyms
   * @param values
   * @param groups
   */
 case class NCSemanticTestElement(
-    id: String,
+    typ: String,
     synonyms: Set[String] = Set.empty,
     values: Map[String, Set[String]] = Map.empty,
     groups: Seq[String] = Seq.empty,
     props: Map[String, AnyRef] = Map.empty
 ) extends NCSemanticElement:
-    override val getType: String = id
+    override val getType: String = typ
     override val getGroups: Set[String] = groups.toSet
     override val getValues: Map[String, Set[String]] = values
     override val getSynonyms: Set[String] = synonyms
@@ -46,4 +46,4 @@ case class NCSemanticTestElement(
   *
   */
 object NCSemanticTestElement:
-    def apply(id: String, synonyms: String*) = new NCSemanticTestElement(id, synonyms = synonyms.toSet)
+    def apply(typ: String, synonyms: String*) = new NCSemanticTestElement(typ, synonyms = synonyms.toSet)
diff --git a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestUtils.scala b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestUtils.scala
index 556f5e3f..6bcf56ad 100644
--- a/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestUtils.scala
+++ b/nlpcraft/src/test/scala/org/apache/nlpcraft/nlp/util/NCTestUtils.scala
@@ -66,7 +66,7 @@ object NCTestUtils:
       * @param ents
       */
     def printEntities(req: String, ents: Seq[NCEntity]): Unit =
-        val tbl = NCAsciiTable("EntityId", "Tokens", "Tokens Position", "Properties")
+        val tbl = NCAsciiTable("EntityType", "Tokens", "Tokens Position", "Properties")
 
         for (e <- ents)
             val toks = e.getTokens
@@ -88,7 +88,7 @@ object NCTestUtils:
         println(s"Request $req variants:")
 
         for ((v, idx) <- vs.zipWithIndex)
-            val tbl = NCAsciiTable("EntityId", "Tokens", "Tokens Position", "Properties")
+            val tbl = NCAsciiTable("EntityType", "Tokens", "Tokens Position", "Properties")
 
             for (e <- v.getEntities)
                 val toks = e.getTokens


[incubator-nlpcraft] 02/03: WIP.

Posted by se...@apache.org.
This is an automated email from the ASF dual-hosted git repository.

sergeykamov pushed a commit to branch NLPCRAFT-521
in repository https://gitbox.apache.org/repos/asf/incubator-nlpcraft.git

commit ef6922427e2667c3af1d3f45c34208371292f5bd
Author: Sergey Kamov <sk...@gmail.com>
AuthorDate: Fri Dec 23 12:51:00 2022 +0400

    WIP.
---
 .../intent/compiler/antlr4/NCIDLBaseListener.java  |    3 +-
 .../intent/compiler/antlr4/NCIDLLexer.interp       |    2 +-
 .../intent/compiler/antlr4/NCIDLLexer.java         | 1321 ++++++++++----------
 .../intent/compiler/antlr4/NCIDLListener.java      |    2 +-
 .../intent/compiler/antlr4/NCIDLParser.java        |   63 +-
 5 files changed, 719 insertions(+), 672 deletions(-)

diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLBaseListener.java b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLBaseListener.java
index 79359263..1a3af1f3 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLBaseListener.java
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLBaseListener.java
@@ -1,4 +1,4 @@
-// Generated from /Users/nivanov/incubator-nlpcraft/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4 by ANTLR 4.10.1
+// Generated from java-escape by ANTLR 4.11.1
 package org.apache.nlpcraft.internal.intent.compiler.antlr4;
 
 import org.antlr.v4.runtime.ParserRuleContext;
@@ -10,6 +10,7 @@ import org.antlr.v4.runtime.tree.TerminalNode;
  * which can be extended to create a listener which only needs to handle a subset
  * of the available methods.
  */
+@SuppressWarnings("CheckReturnValue")
 public class NCIDLBaseListener implements NCIDLListener {
 	/**
 	 * {@inheritDoc}
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.interp b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.interp
index 29e348b3..e70c4b41 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.interp
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.interp
@@ -172,4 +172,4 @@ mode names:
 DEFAULT_MODE
 
 atn:
-[4, 0, 52, 1248, 6, -1, 2, 0, 7, 0, 2, 1, 7, 1, 2, 2, 7, 2, 2, 3, 7, 3, 2, 4, 7, 4, 2, 5, 7, 5, 2, 6, 7, 6, 2, 7, 7, 7, 2, 8, 7, 8, 2, 9, 7, 9, 2, 10, 7, 10, 2, 11, 7, 11, 2, 12, 7, 12, 2, 13, 7, 13, 2, 14, 7, 14, 2, 15, 7, 15, 2, 16, 7, 16, 2, 17, 7, 17, 2, 18, 7, 18, 2, 19, 7, 19, 2, 20, 7, 20, 2, 21, 7, 21, 2, 22, 7, 22, 2, 23, 7, 23, 2, 24, 7, 24, 2, 25, 7, 25, 2, 26, 7, 26, 2, 27, 7, 27, 2, 28, 7, 28, 2, 29, 7, 29, 2, 30, 7, 30, 2, 31, 7, 31, 2, 32, 7, 32, 2, 33, 7, 33, 2, 34, 7, 34 [...]
\ No newline at end of file
+[4, 0, 52, 1250, 6, -1, 2, 0, 7, 0, 2, 1, 7, 1, 2, 2, 7, 2, 2, 3, 7, 3, 2, 4, 7, 4, 2, 5, 7, 5, 2, 6, 7, 6, 2, 7, 7, 7, 2, 8, 7, 8, 2, 9, 7, 9, 2, 10, 7, 10, 2, 11, 7, 11, 2, 12, 7, 12, 2, 13, 7, 13, 2, 14, 7, 14, 2, 15, 7, 15, 2, 16, 7, 16, 2, 17, 7, 17, 2, 18, 7, 18, 2, 19, 7, 19, 2, 20, 7, 20, 2, 21, 7, 21, 2, 22, 7, 22, 2, 23, 7, 23, 2, 24, 7, 24, 2, 25, 7, 25, 2, 26, 7, 26, 2, 27, 7, 27, 2, 28, 7, 28, 2, 29, 7, 29, 2, 30, 7, 30, 2, 31, 7, 31, 2, 32, 7, 32, 2, 33, 7, 33, 2, 34, 7, 34 [...]
\ No newline at end of file
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.java b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.java
index af5e6836..db05c678 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.java
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLLexer.java
@@ -1,4 +1,4 @@
-// Generated from /Users/nivanov/incubator-nlpcraft/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4 by ANTLR 4.10.1
+// Generated from java-escape by ANTLR 4.11.1
 package org.apache.nlpcraft.internal.intent.compiler.antlr4;
 import org.antlr.v4.runtime.Lexer;
 import org.antlr.v4.runtime.CharStream;
@@ -9,9 +9,9 @@ import org.antlr.v4.runtime.atn.*;
 import org.antlr.v4.runtime.dfa.DFA;
 import org.antlr.v4.runtime.misc.*;
 
-@SuppressWarnings({"all", "warnings", "unchecked", "unused", "cast"})
+@SuppressWarnings({"all", "warnings", "unchecked", "unused", "cast", "CheckReturnValue"})
 public class NCIDLLexer extends Lexer {
-	static { RuntimeMetaData.checkVersion("4.10.1", RuntimeMetaData.VERSION); }
+	static { RuntimeMetaData.checkVersion("4.11.1", RuntimeMetaData.VERSION); }
 
 	protected static final DFA[] _decisionToDFA;
 	protected static final PredictionContextCache _sharedContextCache =
@@ -125,7 +125,7 @@ public class NCIDLLexer extends Lexer {
 	public ATN getATN() { return _ATN; }
 
 	public static final String _serializedATN =
-		"\u0004\u00004\u04e0\u0006\uffff\uffff\u0002\u0000\u0007\u0000\u0002\u0001"+
+		"\u0004\u00004\u04e2\u0006\uffff\uffff\u0002\u0000\u0007\u0000\u0002\u0001"+
 		"\u0007\u0001\u0002\u0002\u0007\u0002\u0002\u0003\u0007\u0003\u0002\u0004"+
 		"\u0007\u0004\u0002\u0005\u0007\u0005\u0002\u0006\u0007\u0006\u0002\u0007"+
 		"\u0007\u0007\u0002\b\u0007\b\u0002\t\u0007\t\u0002\n\u0007\n\u0002\u000b"+
@@ -288,662 +288,663 @@ public class NCIDLLexer extends Lexer {
 		"\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000"+
 		"\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000"+
 		"\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000"+
-		"\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0003\u0000"+
-		"\u03eb\b\u0000\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001"+
-		"\u0001\u0001\u0001\u0001\u0001\u0002\u0001\u0002\u0001\u0002\u0001\u0002"+
-		"\u0001\u0002\u0001\u0002\u0001\u0002\u0001\u0003\u0001\u0003\u0001\u0003"+
-		"\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0004"+
-		"\u0001\u0004\u0001\u0004\u0001\u0004\u0001\u0004\u0001\u0005\u0001\u0005"+
-		"\u0001\u0005\u0001\u0005\u0001\u0005\u0001\u0006\u0001\u0006\u0001\u0006"+
-		"\u0001\u0006\u0001\u0006\u0001\u0007\u0001\u0007\u0001\u0007\u0001\u0007"+
-		"\u0001\u0007\u0001\u0007\u0001\u0007\u0001\u0007\u0001\u0007\u0001\b\u0001"+
-		"\b\u0001\b\u0001\b\u0005\b\u041f\b\b\n\b\f\b\u0422\t\b\u0001\b\u0001\b"+
-		"\u0001\t\u0001\t\u0001\t\u0001\t\u0005\t\u042a\b\t\n\t\f\t\u042d\t\t\u0001"+
-		"\t\u0001\t\u0001\n\u0001\n\u0001\n\u0001\n\u0001\n\u0001\n\u0001\n\u0001"+
-		"\n\u0001\n\u0003\n\u043a\b\n\u0001\u000b\u0001\u000b\u0001\u000b\u0001"+
-		"\u000b\u0001\u000b\u0001\f\u0001\f\u0001\f\u0001\r\u0001\r\u0001\r\u0001"+
-		"\u000e\u0001\u000e\u0001\u000e\u0001\u000f\u0001\u000f\u0001\u000f\u0001"+
-		"\u0010\u0001\u0010\u0001\u0011\u0001\u0011\u0001\u0012\u0001\u0012\u0001"+
-		"\u0012\u0001\u0013\u0001\u0013\u0001\u0013\u0001\u0014\u0001\u0014\u0001"+
-		"\u0015\u0001\u0015\u0001\u0016\u0001\u0016\u0001\u0017\u0001\u0017\u0001"+
-		"\u0018\u0001\u0018\u0001\u0019\u0001\u0019\u0001\u001a\u0001\u001a\u0001"+
-		"\u001b\u0001\u001b\u0001\u001c\u0001\u001c\u0001\u001d\u0001\u001d\u0001"+
-		"\u001e\u0001\u001e\u0001\u001f\u0001\u001f\u0001 \u0001 \u0001!\u0001"+
-		"!\u0001\"\u0001\"\u0001#\u0001#\u0001$\u0001$\u0001%\u0001%\u0001&\u0001"+
-		"&\u0001\'\u0001\'\u0001(\u0001(\u0001)\u0001)\u0001*\u0001*\u0001+\u0001"+
-		"+\u0001,\u0001,\u0001-\u0001-\u0001-\u0005-\u048c\b-\n-\f-\u048f\t-\u0003"+
-		"-\u0491\b-\u0001.\u0001.\u0004.\u0495\b.\u000b.\f.\u0496\u0001/\u0001"+
-		"/\u0003/\u049b\b/\u0001/\u0001/\u00010\u00010\u00010\u00030\u04a2\b0\u0001"+
-		"1\u00011\u00012\u00012\u00012\u00012\u00042\u04aa\b2\u000b2\f2\u04ab\u0001"+
-		"2\u00012\u00012\u00012\u00012\u00012\u00012\u00052\u04b5\b2\n2\f2\u04b8"+
-		"\t2\u00013\u00013\u00013\u00013\u00053\u04be\b3\n3\f3\u04c1\t3\u00013"+
-		"\u00033\u04c4\b3\u00013\u00033\u04c7\b3\u00013\u00013\u00013\u00013\u0005"+
-		"3\u04cd\b3\n3\f3\u04d0\t3\u00013\u00013\u00033\u04d4\b3\u00013\u00013"+
-		"\u00014\u00044\u04d9\b4\u000b4\f4\u04da\u00014\u00014\u00015\u00015\u0001"+
-		"\u04ce\u00006\u0001\u0001\u0003\u0002\u0005\u0003\u0007\u0004\t\u0005"+
-		"\u000b\u0006\r\u0007\u000f\b\u0011\t\u0013\n\u0015\u000b\u0017\f\u0019"+
-		"\r\u001b\u000e\u001d\u000f\u001f\u0010!\u0011#\u0012%\u0013\'\u0014)\u0015"+
-		"+\u0016-\u0017/\u00181\u00193\u001a5\u001b7\u001c9\u001d;\u001e=\u001f"+
-		"? A!C\"E#G$I%K&M\'O(Q)S*U+W,Y-[.]/_0a\u0000c\u0000e1g2i3k4\u0001\u0000"+
-		"\u000e\u0001\u0000\'\'\u0001\u0000\"\"\u0001\u000019\u0002\u000009__\u0001"+
-		"\u000009\u0002\u0000EEee\u0002\u0000++--\u0002\u0000\u0000\u007f\u8000"+
-		"\ud800\u8000\udbff\u0001\u0000\u8000\ud800\u8000\udbff\u0001\u0000\u8000"+
-		"\udc00\u8000\udfff\u0002\u0000AZaz\u0002\u0000\n\n\r\r\u0001\u0001\n\n"+
-		"\u0003\u0000\t\n\f\r  \u0571\u0000\u0001\u0001\u0000\u0000\u0000\u0000"+
-		"\u0003\u0001\u0000\u0000\u0000\u0000\u0005\u0001\u0000\u0000\u0000\u0000"+
-		"\u0007\u0001\u0000\u0000\u0000\u0000\t\u0001\u0000\u0000\u0000\u0000\u000b"+
-		"\u0001\u0000\u0000\u0000\u0000\r\u0001\u0000\u0000\u0000\u0000\u000f\u0001"+
-		"\u0000\u0000\u0000\u0000\u0011\u0001\u0000\u0000\u0000\u0000\u0013\u0001"+
-		"\u0000\u0000\u0000\u0000\u0015\u0001\u0000\u0000\u0000\u0000\u0017\u0001"+
-		"\u0000\u0000\u0000\u0000\u0019\u0001\u0000\u0000\u0000\u0000\u001b\u0001"+
-		"\u0000\u0000\u0000\u0000\u001d\u0001\u0000\u0000\u0000\u0000\u001f\u0001"+
-		"\u0000\u0000\u0000\u0000!\u0001\u0000\u0000\u0000\u0000#\u0001\u0000\u0000"+
-		"\u0000\u0000%\u0001\u0000\u0000\u0000\u0000\'\u0001\u0000\u0000\u0000"+
-		"\u0000)\u0001\u0000\u0000\u0000\u0000+\u0001\u0000\u0000\u0000\u0000-"+
-		"\u0001\u0000\u0000\u0000\u0000/\u0001\u0000\u0000\u0000\u00001\u0001\u0000"+
-		"\u0000\u0000\u00003\u0001\u0000\u0000\u0000\u00005\u0001\u0000\u0000\u0000"+
-		"\u00007\u0001\u0000\u0000\u0000\u00009\u0001\u0000\u0000\u0000\u0000;"+
-		"\u0001\u0000\u0000\u0000\u0000=\u0001\u0000\u0000\u0000\u0000?\u0001\u0000"+
-		"\u0000\u0000\u0000A\u0001\u0000\u0000\u0000\u0000C\u0001\u0000\u0000\u0000"+
-		"\u0000E\u0001\u0000\u0000\u0000\u0000G\u0001\u0000\u0000\u0000\u0000I"+
-		"\u0001\u0000\u0000\u0000\u0000K\u0001\u0000\u0000\u0000\u0000M\u0001\u0000"+
-		"\u0000\u0000\u0000O\u0001\u0000\u0000\u0000\u0000Q\u0001\u0000\u0000\u0000"+
-		"\u0000S\u0001\u0000\u0000\u0000\u0000U\u0001\u0000\u0000\u0000\u0000W"+
-		"\u0001\u0000\u0000\u0000\u0000Y\u0001\u0000\u0000\u0000\u0000[\u0001\u0000"+
-		"\u0000\u0000\u0000]\u0001\u0000\u0000\u0000\u0000_\u0001\u0000\u0000\u0000"+
-		"\u0000e\u0001\u0000\u0000\u0000\u0000g\u0001\u0000\u0000\u0000\u0000i"+
-		"\u0001\u0000\u0000\u0000\u0000k\u0001\u0000\u0000\u0000\u0001\u03ea\u0001"+
-		"\u0000\u0000\u0000\u0003\u03ec\u0001\u0000\u0000\u0000\u0005\u03f3\u0001"+
-		"\u0000\u0000\u0000\u0007\u03fa\u0001\u0000\u0000\u0000\t\u0402\u0001\u0000"+
-		"\u0000\u0000\u000b\u0407\u0001\u0000\u0000\u0000\r\u040c\u0001\u0000\u0000"+
-		"\u0000\u000f\u0411\u0001\u0000\u0000\u0000\u0011\u041a\u0001\u0000\u0000"+
-		"\u0000\u0013\u0425\u0001\u0000\u0000\u0000\u0015\u0439\u0001\u0000\u0000"+
-		"\u0000\u0017\u043b\u0001\u0000\u0000\u0000\u0019\u0440\u0001\u0000\u0000"+
-		"\u0000\u001b\u0443\u0001\u0000\u0000\u0000\u001d\u0446\u0001\u0000\u0000"+
-		"\u0000\u001f\u0449\u0001\u0000\u0000\u0000!\u044c\u0001\u0000\u0000\u0000"+
-		"#\u044e\u0001\u0000\u0000\u0000%\u0450\u0001\u0000\u0000\u0000\'\u0453"+
-		"\u0001\u0000\u0000\u0000)\u0456\u0001\u0000\u0000\u0000+\u0458\u0001\u0000"+
-		"\u0000\u0000-\u045a\u0001\u0000\u0000\u0000/\u045c\u0001\u0000\u0000\u0000"+
-		"1\u045e\u0001\u0000\u0000\u00003\u0460\u0001\u0000\u0000\u00005\u0462"+
-		"\u0001\u0000\u0000\u00007\u0464\u0001\u0000\u0000\u00009\u0466\u0001\u0000"+
-		"\u0000\u0000;\u0468\u0001\u0000\u0000\u0000=\u046a\u0001\u0000\u0000\u0000"+
-		"?\u046c\u0001\u0000\u0000\u0000A\u046e\u0001\u0000\u0000\u0000C\u0470"+
-		"\u0001\u0000\u0000\u0000E\u0472\u0001\u0000\u0000\u0000G\u0474\u0001\u0000"+
-		"\u0000\u0000I\u0476\u0001\u0000\u0000\u0000K\u0478\u0001\u0000\u0000\u0000"+
-		"M\u047a\u0001\u0000\u0000\u0000O\u047c\u0001\u0000\u0000\u0000Q\u047e"+
-		"\u0001\u0000\u0000\u0000S\u0480\u0001\u0000\u0000\u0000U\u0482\u0001\u0000"+
-		"\u0000\u0000W\u0484\u0001\u0000\u0000\u0000Y\u0486\u0001\u0000\u0000\u0000"+
-		"[\u0490\u0001\u0000\u0000\u0000]\u0492\u0001\u0000\u0000\u0000_\u0498"+
-		"\u0001\u0000\u0000\u0000a\u04a1\u0001\u0000\u0000\u0000c\u04a3\u0001\u0000"+
-		"\u0000\u0000e\u04a9\u0001\u0000\u0000\u0000g\u04d3\u0001\u0000\u0000\u0000"+
-		"i\u04d8\u0001\u0000\u0000\u0000k\u04de\u0001\u0000\u0000\u0000mn\u0005"+
-		"m\u0000\u0000no\u0005e\u0000\u0000op\u0005t\u0000\u0000pq\u0005a\u0000"+
-		"\u0000qr\u0005_\u0000\u0000rs\u0005e\u0000\u0000st\u0005n\u0000\u0000"+
-		"t\u03eb\u0005t\u0000\u0000uv\u0005m\u0000\u0000vw\u0005e\u0000\u0000w"+
-		"x\u0005t\u0000\u0000xy\u0005a\u0000\u0000yz\u0005_\u0000\u0000z{\u0005"+
-		"c\u0000\u0000{|\u0005f\u0000\u0000|\u03eb\u0005g\u0000\u0000}~\u0005m"+
-		"\u0000\u0000~\u007f\u0005e\u0000\u0000\u007f\u0080\u0005t\u0000\u0000"+
-		"\u0080\u0081\u0005a\u0000\u0000\u0081\u0082\u0005_\u0000\u0000\u0082\u0083"+
-		"\u0005i\u0000\u0000\u0083\u0084\u0005n\u0000\u0000\u0084\u0085\u0005t"+
-		"\u0000\u0000\u0085\u0086\u0005e\u0000\u0000\u0086\u0087\u0005n\u0000\u0000"+
-		"\u0087\u03eb\u0005t\u0000\u0000\u0088\u0089\u0005m\u0000\u0000\u0089\u008a"+
-		"\u0005e\u0000\u0000\u008a\u008b\u0005t\u0000\u0000\u008b\u008c\u0005a"+
-		"\u0000\u0000\u008c\u008d\u0005_\u0000\u0000\u008d\u008e\u0005r\u0000\u0000"+
-		"\u008e\u008f\u0005e\u0000\u0000\u008f\u03eb\u0005q\u0000\u0000\u0090\u0091"+
-		"\u0005m\u0000\u0000\u0091\u0092\u0005e\u0000\u0000\u0092\u0093\u0005t"+
-		"\u0000\u0000\u0093\u0094\u0005a\u0000\u0000\u0094\u0095\u0005_\u0000\u0000"+
-		"\u0095\u0096\u0005s\u0000\u0000\u0096\u0097\u0005y\u0000\u0000\u0097\u03eb"+
-		"\u0005s\u0000\u0000\u0098\u0099\u0005m\u0000\u0000\u0099\u009a\u0005e"+
-		"\u0000\u0000\u009a\u009b\u0005t\u0000\u0000\u009b\u009c\u0005a\u0000\u0000"+
-		"\u009c\u009d\u0005_\u0000\u0000\u009d\u009e\u0005c\u0000\u0000\u009e\u009f"+
-		"\u0005o\u0000\u0000\u009f\u00a0\u0005n\u0000\u0000\u00a0\u03eb\u0005v"+
-		"\u0000\u0000\u00a1\u00a2\u0005m\u0000\u0000\u00a2\u00a3\u0005e\u0000\u0000"+
-		"\u00a3\u00a4\u0005t\u0000\u0000\u00a4\u00a5\u0005a\u0000\u0000\u00a5\u00a6"+
-		"\u0005_\u0000\u0000\u00a6\u00a7\u0005f\u0000\u0000\u00a7\u00a8\u0005r"+
-		"\u0000\u0000\u00a8\u00a9\u0005a\u0000\u0000\u00a9\u03eb\u0005g\u0000\u0000"+
-		"\u00aa\u00ab\u0005j\u0000\u0000\u00ab\u00ac\u0005s\u0000\u0000\u00ac\u00ad"+
-		"\u0005o\u0000\u0000\u00ad\u03eb\u0005n\u0000\u0000\u00ae\u00af\u0005i"+
-		"\u0000\u0000\u00af\u03eb\u0005f\u0000\u0000\u00b0\u00b1\u0005e\u0000\u0000"+
-		"\u00b1\u00b2\u0005n\u0000\u0000\u00b2\u00b3\u0005t\u0000\u0000\u00b3\u00b4"+
-		"\u0005_\u0000\u0000\u00b4\u00b5\u0005i\u0000\u0000\u00b5\u03eb\u0005d"+
-		"\u0000\u0000\u00b6\u00b7\u0005e\u0000\u0000\u00b7\u00b8\u0005n\u0000\u0000"+
-		"\u00b8\u00b9\u0005t\u0000\u0000\u00b9\u00ba\u0005_\u0000\u0000\u00ba\u00bb"+
-		"\u0005i\u0000\u0000\u00bb\u00bc\u0005n\u0000\u0000\u00bc\u00bd\u0005d"+
-		"\u0000\u0000\u00bd\u00be\u0005e\u0000\u0000\u00be\u03eb\u0005x\u0000\u0000"+
-		"\u00bf\u00c0\u0005e\u0000\u0000\u00c0\u00c1\u0005n\u0000\u0000\u00c1\u00c2"+
-		"\u0005t\u0000\u0000\u00c2\u00c3\u0005_\u0000\u0000\u00c3\u00c4\u0005t"+
-		"\u0000\u0000\u00c4\u00c5\u0005e\u0000\u0000\u00c5\u00c6\u0005x\u0000\u0000"+
-		"\u00c6\u03eb\u0005t\u0000\u0000\u00c7\u00c8\u0005e\u0000\u0000\u00c8\u00c9"+
-		"\u0005n\u0000\u0000\u00c9\u00ca\u0005t\u0000\u0000\u00ca\u00cb\u0005_"+
-		"\u0000\u0000\u00cb\u00cc\u0005g\u0000\u0000\u00cc\u00cd\u0005r\u0000\u0000"+
-		"\u00cd\u00ce\u0005o\u0000\u0000\u00ce\u00cf\u0005u\u0000\u0000\u00cf\u00d0"+
-		"\u0005p\u0000\u0000\u00d0\u03eb\u0005s\u0000\u0000\u00d1\u00d2\u0005e"+
-		"\u0000\u0000\u00d2\u00d3\u0005n\u0000\u0000\u00d3\u00d4\u0005t\u0000\u0000"+
-		"\u00d4\u00d5\u0005_\u0000\u0000\u00d5\u00d6\u0005c\u0000\u0000\u00d6\u00d7"+
-		"\u0005o\u0000\u0000\u00d7\u00d8\u0005u\u0000\u0000\u00d8\u00d9\u0005n"+
-		"\u0000\u0000\u00d9\u03eb\u0005t\u0000\u0000\u00da\u00db\u0005e\u0000\u0000"+
-		"\u00db\u00dc\u0005n\u0000\u0000\u00dc\u00dd\u0005t\u0000\u0000\u00dd\u00de"+
-		"\u0005_\u0000\u0000\u00de\u00df\u0005a\u0000\u0000\u00df\u00e0\u0005l"+
-		"\u0000\u0000\u00e0\u03eb\u0005l\u0000\u0000\u00e1\u00e2\u0005e\u0000\u0000"+
-		"\u00e2\u00e3\u0005n\u0000\u0000\u00e3\u00e4\u0005t\u0000\u0000\u00e4\u00e5"+
-		"\u0005_\u0000\u0000\u00e5\u00e6\u0005a\u0000\u0000\u00e6\u00e7\u0005l"+
-		"\u0000\u0000\u00e7\u00e8\u0005l\u0000\u0000\u00e8\u00e9\u0005_\u0000\u0000"+
-		"\u00e9\u00ea\u0005f\u0000\u0000\u00ea\u00eb\u0005o\u0000\u0000\u00eb\u00ec"+
-		"\u0005r\u0000\u0000\u00ec\u00ed\u0005_\u0000\u0000\u00ed\u00ee\u0005i"+
-		"\u0000\u0000\u00ee\u03eb\u0005d\u0000\u0000\u00ef\u00f0\u0005e\u0000\u0000"+
-		"\u00f0\u00f1\u0005n\u0000\u0000\u00f1\u00f2\u0005t\u0000\u0000\u00f2\u00f3"+
-		"\u0005_\u0000\u0000\u00f3\u00f4\u0005a\u0000\u0000\u00f4\u00f5\u0005l"+
-		"\u0000\u0000\u00f5\u00f6\u0005l\u0000\u0000\u00f6\u00f7\u0005_\u0000\u0000"+
-		"\u00f7\u00f8\u0005f\u0000\u0000\u00f8\u00f9\u0005o\u0000\u0000\u00f9\u00fa"+
-		"\u0005r\u0000\u0000\u00fa\u00fb\u0005_\u0000\u0000\u00fb\u00fc\u0005g"+
-		"\u0000\u0000\u00fc\u00fd\u0005r\u0000\u0000\u00fd\u00fe\u0005o\u0000\u0000"+
-		"\u00fe\u00ff\u0005u\u0000\u0000\u00ff\u03eb\u0005p\u0000\u0000\u0100\u0101"+
-		"\u0005e\u0000\u0000\u0101\u0102\u0005n\u0000\u0000\u0102\u0103\u0005t"+
-		"\u0000\u0000\u0103\u0104\u0005_\u0000\u0000\u0104\u0105\u0005t\u0000\u0000"+
-		"\u0105\u0106\u0005h\u0000\u0000\u0106\u0107\u0005i\u0000\u0000\u0107\u03eb"+
-		"\u0005s\u0000\u0000\u0108\u0109\u0005e\u0000\u0000\u0109\u010a\u0005n"+
-		"\u0000\u0000\u010a\u010b\u0005t\u0000\u0000\u010b\u010c\u0005_\u0000\u0000"+
-		"\u010c\u010d\u0005i\u0000\u0000\u010d\u010e\u0005s\u0000\u0000\u010e\u010f"+
-		"\u0005_\u0000\u0000\u010f\u0110\u0005l\u0000\u0000\u0110\u0111\u0005a"+
-		"\u0000\u0000\u0111\u0112\u0005s\u0000\u0000\u0112\u03eb\u0005t\u0000\u0000"+
-		"\u0113\u0114\u0005e\u0000\u0000\u0114\u0115\u0005n\u0000\u0000\u0115\u0116"+
-		"\u0005t\u0000\u0000\u0116\u0117\u0005_\u0000\u0000\u0117\u0118\u0005i"+
-		"\u0000\u0000\u0118\u0119\u0005s\u0000\u0000\u0119\u011a\u0005_\u0000\u0000"+
-		"\u011a\u011b\u0005f\u0000\u0000\u011b\u011c\u0005i\u0000\u0000\u011c\u011d"+
-		"\u0005r\u0000\u0000\u011d\u011e\u0005s\u0000\u0000\u011e\u03eb\u0005t"+
-		"\u0000\u0000\u011f\u0120\u0005e\u0000\u0000\u0120\u0121\u0005n\u0000\u0000"+
-		"\u0121\u0122\u0005t\u0000\u0000\u0122\u0123\u0005_\u0000\u0000\u0123\u0124"+
-		"\u0005i\u0000\u0000\u0124\u0125\u0005s\u0000\u0000\u0125\u0126\u0005_"+
-		"\u0000\u0000\u0126\u0127\u0005b\u0000\u0000\u0127\u0128\u0005e\u0000\u0000"+
-		"\u0128\u0129\u0005f\u0000\u0000\u0129\u012a\u0005o\u0000\u0000\u012a\u012b"+
-		"\u0005r\u0000\u0000\u012b\u012c\u0005e\u0000\u0000\u012c\u012d\u0005_"+
-		"\u0000\u0000\u012d\u012e\u0005i\u0000\u0000\u012e\u03eb\u0005d\u0000\u0000"+
-		"\u012f\u0130\u0005e\u0000\u0000\u0130\u0131\u0005n\u0000\u0000\u0131\u0132"+
-		"\u0005t\u0000\u0000\u0132\u0133\u0005_\u0000\u0000\u0133\u0134\u0005i"+
-		"\u0000\u0000\u0134\u0135\u0005s\u0000\u0000\u0135\u0136\u0005_\u0000\u0000"+
-		"\u0136\u0137\u0005b\u0000\u0000\u0137\u0138\u0005e\u0000\u0000\u0138\u0139"+
-		"\u0005f\u0000\u0000\u0139\u013a\u0005o\u0000\u0000\u013a\u013b\u0005r"+
-		"\u0000\u0000\u013b\u013c\u0005e\u0000\u0000\u013c\u013d\u0005_\u0000\u0000"+
-		"\u013d\u013e\u0005g\u0000\u0000\u013e\u013f\u0005r\u0000\u0000\u013f\u0140"+
-		"\u0005o\u0000\u0000\u0140\u0141\u0005u\u0000\u0000\u0141\u03eb\u0005p"+
-		"\u0000\u0000\u0142\u0143\u0005e\u0000\u0000\u0143\u0144\u0005n\u0000\u0000"+
-		"\u0144\u0145\u0005t\u0000\u0000\u0145\u0146\u0005_\u0000\u0000\u0146\u0147"+
-		"\u0005i\u0000\u0000\u0147\u0148\u0005s\u0000\u0000\u0148\u0149\u0005_"+
-		"\u0000\u0000\u0149\u014a\u0005a\u0000\u0000\u014a\u014b\u0005f\u0000\u0000"+
-		"\u014b\u014c\u0005t\u0000\u0000\u014c\u014d\u0005e\u0000\u0000\u014d\u014e"+
-		"\u0005r\u0000\u0000\u014e\u014f\u0005_\u0000\u0000\u014f\u0150\u0005i"+
-		"\u0000\u0000\u0150\u03eb\u0005d\u0000\u0000\u0151\u0152\u0005e\u0000\u0000"+
-		"\u0152\u0153\u0005n\u0000\u0000\u0153\u0154\u0005t\u0000\u0000\u0154\u0155"+
-		"\u0005_\u0000\u0000\u0155\u0156\u0005i\u0000\u0000\u0156\u0157\u0005s"+
-		"\u0000\u0000\u0157\u0158\u0005_\u0000\u0000\u0158\u0159\u0005a\u0000\u0000"+
-		"\u0159\u015a\u0005f\u0000\u0000\u015a\u015b\u0005t\u0000\u0000\u015b\u015c"+
-		"\u0005e\u0000\u0000\u015c\u015d\u0005r\u0000\u0000\u015d\u015e\u0005_"+
-		"\u0000\u0000\u015e\u015f\u0005g\u0000\u0000\u015f\u0160\u0005r\u0000\u0000"+
-		"\u0160\u0161\u0005o\u0000\u0000\u0161\u0162\u0005u\u0000\u0000\u0162\u03eb"+
-		"\u0005p\u0000\u0000\u0163\u0164\u0005e\u0000\u0000\u0164\u0165\u0005n"+
-		"\u0000\u0000\u0165\u0166\u0005t\u0000\u0000\u0166\u0167\u0005_\u0000\u0000"+
-		"\u0167\u0168\u0005i\u0000\u0000\u0168\u0169\u0005s\u0000\u0000\u0169\u016a"+
-		"\u0005_\u0000\u0000\u016a\u016b\u0005b\u0000\u0000\u016b\u016c\u0005e"+
-		"\u0000\u0000\u016c\u016d\u0005t\u0000\u0000\u016d\u016e\u0005w\u0000\u0000"+
-		"\u016e\u016f\u0005e\u0000\u0000\u016f\u0170\u0005e\u0000\u0000\u0170\u0171"+
-		"\u0005n\u0000\u0000\u0171\u0172\u0005_\u0000\u0000\u0172\u0173\u0005i"+
-		"\u0000\u0000\u0173\u0174\u0005d\u0000\u0000\u0174\u03eb\u0005s\u0000\u0000"+
-		"\u0175\u0176\u0005e\u0000\u0000\u0176\u0177\u0005n\u0000\u0000\u0177\u0178"+
-		"\u0005t\u0000\u0000\u0178\u0179\u0005_\u0000\u0000\u0179\u017a\u0005i"+
-		"\u0000\u0000\u017a\u017b\u0005s\u0000\u0000\u017b\u017c\u0005_\u0000\u0000"+
-		"\u017c\u017d\u0005b\u0000\u0000\u017d\u017e\u0005e\u0000\u0000\u017e\u017f"+
-		"\u0005t\u0000\u0000\u017f\u0180\u0005w\u0000\u0000\u0180\u0181\u0005e"+
-		"\u0000\u0000\u0181\u0182\u0005e\u0000\u0000\u0182\u0183\u0005n\u0000\u0000"+
-		"\u0183\u0184\u0005_\u0000\u0000\u0184\u0185\u0005g\u0000\u0000\u0185\u0186"+
-		"\u0005r\u0000\u0000\u0186\u0187\u0005o\u0000\u0000\u0187\u0188\u0005u"+
-		"\u0000\u0000\u0188\u0189\u0005p\u0000\u0000\u0189\u03eb\u0005s\u0000\u0000"+
-		"\u018a\u018b\u0005m\u0000\u0000\u018b\u018c\u0005d\u0000\u0000\u018c\u018d"+
-		"\u0005l\u0000\u0000\u018d\u018e\u0005_\u0000\u0000\u018e\u018f\u0005i"+
-		"\u0000\u0000\u018f\u03eb\u0005d\u0000\u0000\u0190\u0191\u0005m\u0000\u0000"+
-		"\u0191\u0192\u0005d\u0000\u0000\u0192\u0193\u0005l\u0000\u0000\u0193\u0194"+
-		"\u0005_\u0000\u0000\u0194\u0195\u0005n\u0000\u0000\u0195\u0196\u0005a"+
-		"\u0000\u0000\u0196\u0197\u0005m\u0000\u0000\u0197\u03eb\u0005e\u0000\u0000"+
-		"\u0198\u0199\u0005m\u0000\u0000\u0199\u019a\u0005d\u0000\u0000\u019a\u019b"+
-		"\u0005l\u0000\u0000\u019b\u019c\u0005_\u0000\u0000\u019c\u019d\u0005v"+
-		"\u0000\u0000\u019d\u019e\u0005e\u0000\u0000\u019e\u03eb\u0005r\u0000\u0000"+
-		"\u019f\u01a0\u0005m\u0000\u0000\u01a0\u01a1\u0005d\u0000\u0000\u01a1\u01a2"+
-		"\u0005l\u0000\u0000\u01a2\u01a3\u0005_\u0000\u0000\u01a3\u01a4\u0005o"+
-		"\u0000\u0000\u01a4\u01a5\u0005r\u0000\u0000\u01a5\u01a6\u0005i\u0000\u0000"+
-		"\u01a6\u01a7\u0005g\u0000\u0000\u01a7\u01a8\u0005i\u0000\u0000\u01a8\u03eb"+
-		"\u0005n\u0000\u0000\u01a9\u01aa\u0005r\u0000\u0000\u01aa\u01ab\u0005e"+
-		"\u0000\u0000\u01ab\u01ac\u0005q\u0000\u0000\u01ac\u01ad\u0005_\u0000\u0000"+
-		"\u01ad\u01ae\u0005i\u0000\u0000\u01ae\u03eb\u0005d\u0000\u0000\u01af\u01b0"+
-		"\u0005r\u0000\u0000\u01b0\u01b1\u0005e\u0000\u0000\u01b1\u01b2\u0005q"+
-		"\u0000\u0000\u01b2\u01b3\u0005_\u0000\u0000\u01b3\u01b4\u0005t\u0000\u0000"+
-		"\u01b4\u01b5\u0005e\u0000\u0000\u01b5\u01b6\u0005x\u0000\u0000\u01b6\u03eb"+
-		"\u0005t\u0000\u0000\u01b7\u01b8\u0005r\u0000\u0000\u01b8\u01b9\u0005e"+
-		"\u0000\u0000\u01b9\u01ba\u0005q\u0000\u0000\u01ba\u01bb\u0005_\u0000\u0000"+
-		"\u01bb\u01bc\u0005t\u0000\u0000\u01bc\u01bd\u0005s\u0000\u0000\u01bd\u01be"+
-		"\u0005t\u0000\u0000\u01be\u01bf\u0005a\u0000\u0000\u01bf\u01c0\u0005m"+
-		"\u0000\u0000\u01c0\u03eb\u0005p\u0000\u0000\u01c1\u01c2\u0005u\u0000\u0000"+
-		"\u01c2\u01c3\u0005s\u0000\u0000\u01c3\u01c4\u0005e\u0000\u0000\u01c4\u01c5"+
-		"\u0005r\u0000\u0000\u01c5\u01c6\u0005_\u0000\u0000\u01c6\u01c7\u0005i"+
-		"\u0000\u0000\u01c7\u03eb\u0005d\u0000\u0000\u01c8\u01c9\u0005t\u0000\u0000"+
-		"\u01c9\u01ca\u0005r\u0000\u0000\u01ca\u01cb\u0005i\u0000\u0000\u01cb\u03eb"+
-		"\u0005m\u0000\u0000\u01cc\u01cd\u0005r\u0000\u0000\u01cd\u01ce\u0005e"+
-		"\u0000\u0000\u01ce\u01cf\u0005g\u0000\u0000\u01cf\u01d0\u0005e\u0000\u0000"+
-		"\u01d0\u03eb\u0005x\u0000\u0000\u01d1\u01d2\u0005s\u0000\u0000\u01d2\u01d3"+
-		"\u0005t\u0000\u0000\u01d3\u01d4\u0005r\u0000\u0000\u01d4\u01d5\u0005i"+
-		"\u0000\u0000\u01d5\u03eb\u0005p\u0000\u0000\u01d6\u01d7\u0005u\u0000\u0000"+
-		"\u01d7\u01d8\u0005p\u0000\u0000\u01d8\u01d9\u0005p\u0000\u0000\u01d9\u01da"+
-		"\u0005e\u0000\u0000\u01da\u01db\u0005r\u0000\u0000\u01db\u01dc\u0005c"+
-		"\u0000\u0000\u01dc\u01dd\u0005a\u0000\u0000\u01dd\u01de\u0005s\u0000\u0000"+
-		"\u01de\u03eb\u0005e\u0000\u0000\u01df\u01e0\u0005l\u0000\u0000\u01e0\u01e1"+
-		"\u0005o\u0000\u0000\u01e1\u01e2\u0005w\u0000\u0000\u01e2\u01e3\u0005e"+
-		"\u0000\u0000\u01e3\u01e4\u0005r\u0000\u0000\u01e4\u01e5\u0005c\u0000\u0000"+
-		"\u01e5\u01e6\u0005a\u0000\u0000\u01e6\u01e7\u0005s\u0000\u0000\u01e7\u03eb"+
-		"\u0005e\u0000\u0000\u01e8\u01e9\u0005i\u0000\u0000\u01e9\u01ea\u0005s"+
-		"\u0000\u0000\u01ea\u01eb\u0005_\u0000\u0000\u01eb\u01ec\u0005a\u0000\u0000"+
-		"\u01ec\u01ed\u0005l\u0000\u0000\u01ed\u01ee\u0005p\u0000\u0000\u01ee\u01ef"+
-		"\u0005h\u0000\u0000\u01ef\u03eb\u0005a\u0000\u0000\u01f0\u01f1\u0005i"+
-		"\u0000\u0000\u01f1\u01f2\u0005s\u0000\u0000\u01f2\u01f3\u0005_\u0000\u0000"+
-		"\u01f3\u01f4\u0005a\u0000\u0000\u01f4\u01f5\u0005l\u0000\u0000\u01f5\u01f6"+
-		"\u0005p\u0000\u0000\u01f6\u01f7\u0005h\u0000\u0000\u01f7\u01f8\u0005a"+
-		"\u0000\u0000\u01f8\u01f9\u0005n\u0000\u0000\u01f9\u01fa\u0005u\u0000\u0000"+
-		"\u01fa\u03eb\u0005m\u0000\u0000\u01fb\u01fc\u0005i\u0000\u0000\u01fc\u01fd"+
-		"\u0005s\u0000\u0000\u01fd\u01fe\u0005_\u0000\u0000\u01fe\u01ff\u0005w"+
-		"\u0000\u0000\u01ff\u0200\u0005h\u0000\u0000\u0200\u0201\u0005i\u0000\u0000"+
-		"\u0201\u0202\u0005t\u0000\u0000\u0202\u0203\u0005e\u0000\u0000\u0203\u0204"+
-		"\u0005s\u0000\u0000\u0204\u0205\u0005p\u0000\u0000\u0205\u0206\u0005a"+
-		"\u0000\u0000\u0206\u0207\u0005c\u0000\u0000\u0207\u03eb\u0005e\u0000\u0000"+
-		"\u0208\u0209\u0005i\u0000\u0000\u0209\u020a\u0005s\u0000\u0000\u020a\u020b"+
-		"\u0005_\u0000\u0000\u020b\u020c\u0005n\u0000\u0000\u020c\u020d\u0005u"+
-		"\u0000\u0000\u020d\u03eb\u0005m\u0000\u0000\u020e\u020f\u0005i\u0000\u0000"+
-		"\u020f\u0210\u0005s\u0000\u0000\u0210\u0211\u0005_\u0000\u0000\u0211\u0212"+
-		"\u0005n\u0000\u0000\u0212\u0213\u0005u\u0000\u0000\u0213\u0214\u0005m"+
-		"\u0000\u0000\u0214\u0215\u0005s\u0000\u0000\u0215\u0216\u0005p\u0000\u0000"+
-		"\u0216\u0217\u0005a\u0000\u0000\u0217\u0218\u0005c\u0000\u0000\u0218\u03eb"+
-		"\u0005e\u0000\u0000\u0219\u021a\u0005i\u0000\u0000\u021a\u021b\u0005s"+
-		"\u0000\u0000\u021b\u021c\u0005_\u0000\u0000\u021c\u021d\u0005a\u0000\u0000"+
-		"\u021d\u021e\u0005l\u0000\u0000\u021e\u021f\u0005p\u0000\u0000\u021f\u0220"+
-		"\u0005h\u0000\u0000\u0220\u0221\u0005a\u0000\u0000\u0221\u0222\u0005s"+
-		"\u0000\u0000\u0222\u0223\u0005p\u0000\u0000\u0223\u0224\u0005a\u0000\u0000"+
-		"\u0224\u0225\u0005c\u0000\u0000\u0225\u03eb\u0005e\u0000\u0000\u0226\u0227"+
-		"\u0005i\u0000\u0000\u0227\u0228\u0005s\u0000\u0000\u0228\u0229\u0005_"+
-		"\u0000\u0000\u0229\u022a\u0005a\u0000\u0000\u022a\u022b\u0005l\u0000\u0000"+
-		"\u022b\u022c\u0005p\u0000\u0000\u022c\u022d\u0005h\u0000\u0000\u022d\u022e"+
-		"\u0005a\u0000\u0000\u022e\u022f\u0005n\u0000\u0000\u022f\u0230\u0005u"+
-		"\u0000\u0000\u0230\u0231\u0005m\u0000\u0000\u0231\u0232\u0005s\u0000\u0000"+
-		"\u0232\u0233\u0005p\u0000\u0000\u0233\u0234\u0005a\u0000\u0000\u0234\u0235"+
-		"\u0005c\u0000\u0000\u0235\u03eb\u0005e\u0000\u0000\u0236\u0237\u0005s"+
-		"\u0000\u0000\u0237\u0238\u0005p\u0000\u0000\u0238\u0239\u0005l\u0000\u0000"+
-		"\u0239\u023a\u0005i\u0000\u0000\u023a\u03eb\u0005t\u0000\u0000\u023b\u023c"+
-		"\u0005s\u0000\u0000\u023c\u023d\u0005p\u0000\u0000\u023d\u023e\u0005l"+
-		"\u0000\u0000\u023e\u023f\u0005i\u0000\u0000\u023f\u0240\u0005t\u0000\u0000"+
-		"\u0240\u0241\u0005_\u0000\u0000\u0241\u0242\u0005t\u0000\u0000\u0242\u0243"+
-		"\u0005r\u0000\u0000\u0243\u0244\u0005i\u0000\u0000\u0244\u03eb\u0005m"+
-		"\u0000\u0000\u0245\u0246\u0005s\u0000\u0000\u0246\u0247\u0005t\u0000\u0000"+
-		"\u0247\u0248\u0005a\u0000\u0000\u0248\u0249\u0005r\u0000\u0000\u0249\u024a"+
-		"\u0005t\u0000\u0000\u024a\u024b\u0005s\u0000\u0000\u024b\u024c\u0005_"+
-		"\u0000\u0000\u024c\u024d\u0005w\u0000\u0000\u024d\u024e\u0005i\u0000\u0000"+
-		"\u024e\u024f\u0005t\u0000\u0000\u024f\u03eb\u0005h\u0000\u0000\u0250\u0251"+
-		"\u0005e\u0000\u0000\u0251\u0252\u0005n\u0000\u0000\u0252\u0253\u0005d"+
-		"\u0000\u0000\u0253\u0254\u0005s\u0000\u0000\u0254\u0255\u0005_\u0000\u0000"+
-		"\u0255\u0256\u0005w\u0000\u0000\u0256\u0257\u0005i\u0000\u0000\u0257\u0258"+
-		"\u0005t\u0000\u0000\u0258\u03eb\u0005h\u0000\u0000\u0259\u025a\u0005i"+
-		"\u0000\u0000\u025a\u025b\u0005n\u0000\u0000\u025b\u025c\u0005d\u0000\u0000"+
-		"\u025c\u025d\u0005e\u0000\u0000\u025d\u025e\u0005x\u0000\u0000\u025e\u025f"+
-		"\u0005_\u0000\u0000\u025f\u0260\u0005o\u0000\u0000\u0260\u03eb\u0005f"+
-		"\u0000\u0000\u0261\u0262\u0005c\u0000\u0000\u0262\u0263\u0005o\u0000\u0000"+
-		"\u0263\u0264\u0005n\u0000\u0000\u0264\u0265\u0005t\u0000\u0000\u0265\u0266"+
-		"\u0005a\u0000\u0000\u0266\u0267\u0005i\u0000\u0000\u0267\u0268\u0005n"+
-		"\u0000\u0000\u0268\u03eb\u0005s\u0000\u0000\u0269\u026a\u0005s\u0000\u0000"+
-		"\u026a\u026b\u0005u\u0000\u0000\u026b\u026c\u0005b\u0000\u0000\u026c\u026d"+
-		"\u0005s\u0000\u0000\u026d\u026e\u0005t\u0000\u0000\u026e\u03eb\u0005r"+
-		"\u0000\u0000\u026f\u0270\u0005r\u0000\u0000\u0270\u0271\u0005e\u0000\u0000"+
-		"\u0271\u0272\u0005p\u0000\u0000\u0272\u0273\u0005l\u0000\u0000\u0273\u0274"+
-		"\u0005a\u0000\u0000\u0274\u0275\u0005c\u0000\u0000\u0275\u03eb\u0005e"+
-		"\u0000\u0000\u0276\u0277\u0005a\u0000\u0000\u0277\u0278\u0005b\u0000\u0000"+
-		"\u0278\u03eb\u0005s\u0000\u0000\u0279\u027a\u0005c\u0000\u0000\u027a\u027b"+
-		"\u0005e\u0000\u0000\u027b\u027c\u0005i\u0000\u0000\u027c\u03eb\u0005l"+
-		"\u0000\u0000\u027d\u027e\u0005f\u0000\u0000\u027e\u027f\u0005l\u0000\u0000"+
-		"\u027f\u0280\u0005o\u0000\u0000\u0280\u0281\u0005o\u0000\u0000\u0281\u03eb"+
-		"\u0005r\u0000\u0000\u0282\u0283\u0005r\u0000\u0000\u0283\u0284\u0005i"+
-		"\u0000\u0000\u0284\u0285\u0005n\u0000\u0000\u0285\u03eb\u0005t\u0000\u0000"+
-		"\u0286\u0287\u0005r\u0000\u0000\u0287\u0288\u0005o\u0000\u0000\u0288\u0289"+
-		"\u0005u\u0000\u0000\u0289\u028a\u0005n\u0000\u0000\u028a\u03eb\u0005d"+
-		"\u0000\u0000\u028b\u028c\u0005s\u0000\u0000\u028c\u028d\u0005i\u0000\u0000"+
-		"\u028d\u028e\u0005g\u0000\u0000\u028e\u028f\u0005n\u0000\u0000\u028f\u0290"+
-		"\u0005u\u0000\u0000\u0290\u03eb\u0005m\u0000\u0000\u0291\u0292\u0005s"+
-		"\u0000\u0000\u0292\u0293\u0005q\u0000\u0000\u0293\u0294\u0005r\u0000\u0000"+
-		"\u0294\u03eb\u0005t\u0000\u0000\u0295\u0296\u0005c\u0000\u0000\u0296\u0297"+
-		"\u0005b\u0000\u0000\u0297\u0298\u0005r\u0000\u0000\u0298\u03eb\u0005t"+
-		"\u0000\u0000\u0299\u029a\u0005p\u0000\u0000\u029a\u03eb\u0005i\u0000\u0000"+
-		"\u029b\u029c\u0005t\u0000\u0000\u029c\u029d\u0005o\u0000\u0000\u029d\u029e"+
-		"\u0005_\u0000\u0000\u029e\u029f\u0005d\u0000\u0000\u029f\u02a0\u0005o"+
-		"\u0000\u0000\u02a0\u02a1\u0005u\u0000\u0000\u02a1\u02a2\u0005b\u0000\u0000"+
-		"\u02a2\u02a3\u0005l\u0000\u0000\u02a3\u03eb\u0005e\u0000\u0000\u02a4\u02a5"+
-		"\u0005t\u0000\u0000\u02a5\u02a6\u0005o\u0000\u0000\u02a6\u02a7\u0005_"+
-		"\u0000\u0000\u02a7\u02a8\u0005i\u0000\u0000\u02a8\u02a9\u0005n\u0000\u0000"+
-		"\u02a9\u03eb\u0005t\u0000\u0000\u02aa\u02ab\u0005e\u0000\u0000\u02ab\u02ac"+
-		"\u0005u\u0000\u0000\u02ac\u02ad\u0005l\u0000\u0000\u02ad\u02ae\u0005e"+
-		"\u0000\u0000\u02ae\u03eb\u0005r\u0000\u0000\u02af\u02b0\u0005a\u0000\u0000"+
-		"\u02b0\u02b1\u0005c\u0000\u0000\u02b1\u02b2\u0005o\u0000\u0000\u02b2\u03eb"+
-		"\u0005s\u0000\u0000\u02b3\u02b4\u0005a\u0000\u0000\u02b4\u02b5\u0005s"+
-		"\u0000\u0000\u02b5\u02b6\u0005i\u0000\u0000\u02b6\u03eb\u0005n\u0000\u0000"+
-		"\u02b7\u02b8\u0005a\u0000\u0000\u02b8\u02b9\u0005t\u0000\u0000\u02b9\u02ba"+
-		"\u0005a\u0000\u0000\u02ba\u03eb\u0005n\u0000\u0000\u02bb\u02bc\u0005c"+
-		"\u0000\u0000\u02bc\u02bd\u0005o\u0000\u0000\u02bd\u03eb\u0005s\u0000\u0000"+
-		"\u02be\u02bf\u0005s\u0000\u0000\u02bf\u02c0\u0005i\u0000\u0000\u02c0\u03eb"+
-		"\u0005n\u0000\u0000\u02c1\u02c2\u0005t\u0000\u0000\u02c2\u02c3\u0005a"+
-		"\u0000\u0000\u02c3\u03eb\u0005n\u0000\u0000\u02c4\u02c5\u0005c\u0000\u0000"+
-		"\u02c5\u02c6\u0005o\u0000\u0000\u02c6\u02c7\u0005s\u0000\u0000\u02c7\u03eb"+
-		"\u0005h\u0000\u0000\u02c8\u02c9\u0005s\u0000\u0000\u02c9\u02ca\u0005i"+
-		"\u0000\u0000\u02ca\u02cb\u0005n\u0000\u0000\u02cb\u03eb\u0005h\u0000\u0000"+
-		"\u02cc\u02cd\u0005t\u0000\u0000\u02cd\u02ce\u0005a\u0000\u0000\u02ce\u02cf"+
-		"\u0005n\u0000\u0000\u02cf\u03eb\u0005h\u0000\u0000\u02d0\u02d1\u0005a"+
-		"\u0000\u0000\u02d1\u02d2\u0005t\u0000\u0000\u02d2\u02d3\u0005a\u0000\u0000"+
-		"\u02d3\u02d4\u0005n\u0000\u0000\u02d4\u03eb\u00052\u0000\u0000\u02d5\u02d6"+
-		"\u0005d\u0000\u0000\u02d6\u02d7\u0005e\u0000\u0000\u02d7\u02d8\u0005g"+
-		"\u0000\u0000\u02d8\u02d9\u0005r\u0000\u0000\u02d9\u02da\u0005e\u0000\u0000"+
-		"\u02da\u02db\u0005e\u0000\u0000\u02db\u03eb\u0005s\u0000\u0000\u02dc\u02dd"+
-		"\u0005r\u0000\u0000\u02dd\u02de\u0005a\u0000\u0000\u02de\u02df\u0005d"+
-		"\u0000\u0000\u02df\u02e0\u0005i\u0000\u0000\u02e0\u02e1\u0005a\u0000\u0000"+
-		"\u02e1\u02e2\u0005n\u0000\u0000\u02e2\u03eb\u0005s\u0000\u0000\u02e3\u02e4"+
-		"\u0005e\u0000\u0000\u02e4\u02e5\u0005x\u0000\u0000\u02e5\u03eb\u0005p"+
-		"\u0000\u0000\u02e6\u02e7\u0005e\u0000\u0000\u02e7\u02e8\u0005x\u0000\u0000"+
-		"\u02e8\u02e9\u0005p\u0000\u0000\u02e9\u02ea\u0005m\u0000\u0000\u02ea\u03eb"+
-		"\u00051\u0000\u0000\u02eb\u02ec\u0005h\u0000\u0000\u02ec\u02ed\u0005y"+
-		"\u0000\u0000\u02ed\u02ee\u0005p\u0000\u0000\u02ee\u02ef\u0005o\u0000\u0000"+
-		"\u02ef\u03eb\u0005t\u0000\u0000\u02f0\u02f1\u0005l\u0000\u0000\u02f1\u02f2"+
-		"\u0005o\u0000\u0000\u02f2\u03eb\u0005g\u0000\u0000\u02f3\u02f4\u0005l"+
-		"\u0000\u0000\u02f4\u02f5\u0005o\u0000\u0000\u02f5\u02f6\u0005g\u0000\u0000"+
-		"\u02f6\u02f7\u00051\u0000\u0000\u02f7\u03eb\u00050\u0000\u0000\u02f8\u02f9"+
-		"\u0005l\u0000\u0000\u02f9\u02fa\u0005o\u0000\u0000\u02fa\u02fb\u0005g"+
-		"\u0000\u0000\u02fb\u02fc\u00051\u0000\u0000\u02fc\u03eb\u0005p\u0000\u0000"+
-		"\u02fd\u02fe\u0005p\u0000\u0000\u02fe\u02ff\u0005o\u0000\u0000\u02ff\u03eb"+
-		"\u0005w\u0000\u0000\u0300\u0301\u0005r\u0000\u0000\u0301\u0302\u0005a"+
-		"\u0000\u0000\u0302\u0303\u0005n\u0000\u0000\u0303\u03eb\u0005d\u0000\u0000"+
-		"\u0304\u0305\u0005s\u0000\u0000\u0305\u0306\u0005q\u0000\u0000\u0306\u0307"+
-		"\u0005u\u0000\u0000\u0307\u0308\u0005a\u0000\u0000\u0308\u0309\u0005r"+
-		"\u0000\u0000\u0309\u03eb\u0005e\u0000\u0000\u030a\u030b\u0005l\u0000\u0000"+
-		"\u030b\u030c\u0005i\u0000\u0000\u030c\u030d\u0005s\u0000\u0000\u030d\u03eb"+
-		"\u0005t\u0000\u0000\u030e\u030f\u0005g\u0000\u0000\u030f\u0310\u0005e"+
-		"\u0000\u0000\u0310\u03eb\u0005t\u0000\u0000\u0311\u0312\u0005h\u0000\u0000"+
-		"\u0312\u0313\u0005a\u0000\u0000\u0313\u03eb\u0005s\u0000\u0000\u0314\u0315"+
-		"\u0005h\u0000\u0000\u0315\u0316\u0005a\u0000\u0000\u0316\u0317\u0005s"+
-		"\u0000\u0000\u0317\u0318\u0005_\u0000\u0000\u0318\u0319\u0005a\u0000\u0000"+
-		"\u0319\u031a\u0005n\u0000\u0000\u031a\u03eb\u0005y\u0000\u0000\u031b\u031c"+
-		"\u0005h\u0000\u0000\u031c\u031d\u0005a\u0000\u0000\u031d\u031e\u0005s"+
-		"\u0000\u0000\u031e\u031f\u0005_\u0000\u0000\u031f\u0320\u0005a\u0000\u0000"+
-		"\u0320\u0321\u0005l\u0000\u0000\u0321\u03eb\u0005l\u0000\u0000\u0322\u0323"+
-		"\u0005f\u0000\u0000\u0323\u0324\u0005i\u0000\u0000\u0324\u0325\u0005r"+
-		"\u0000\u0000\u0325\u0326\u0005s\u0000\u0000\u0326\u03eb\u0005t\u0000\u0000"+
-		"\u0327\u0328\u0005l\u0000\u0000\u0328\u0329\u0005a\u0000\u0000\u0329\u032a"+
-		"\u0005s\u0000\u0000\u032a\u03eb\u0005t\u0000\u0000\u032b\u032c\u0005k"+
-		"\u0000\u0000\u032c\u032d\u0005e\u0000\u0000\u032d\u032e\u0005y\u0000\u0000"+
-		"\u032e\u03eb\u0005s\u0000\u0000\u032f\u0330\u0005v\u0000\u0000\u0330\u0331"+
-		"\u0005a\u0000\u0000\u0331\u0332\u0005l\u0000\u0000\u0332\u0333\u0005u"+
-		"\u0000\u0000\u0333\u0334\u0005e\u0000\u0000\u0334\u03eb\u0005s\u0000\u0000"+
-		"\u0335\u0336\u0005l\u0000\u0000\u0336\u0337\u0005e\u0000\u0000\u0337\u0338"+
-		"\u0005n\u0000\u0000\u0338\u0339\u0005g\u0000\u0000\u0339\u033a\u0005t"+
-		"\u0000\u0000\u033a\u03eb\u0005h\u0000\u0000\u033b\u033c\u0005c\u0000\u0000"+
-		"\u033c\u033d\u0005o\u0000\u0000\u033d\u033e\u0005u\u0000\u0000\u033e\u033f"+
-		"\u0005n\u0000\u0000\u033f\u03eb\u0005t\u0000\u0000\u0340\u0341\u0005s"+
-		"\u0000\u0000\u0341\u0342\u0005i\u0000\u0000\u0342\u0343\u0005z\u0000\u0000"+
-		"\u0343\u03eb\u0005e\u0000\u0000\u0344\u0345\u0005s\u0000\u0000\u0345\u0346"+
-		"\u0005o\u0000\u0000\u0346\u0347\u0005r\u0000\u0000\u0347\u03eb\u0005t"+
-		"\u0000\u0000\u0348\u0349\u0005r\u0000\u0000\u0349\u034a\u0005e\u0000\u0000"+
-		"\u034a\u034b\u0005v\u0000\u0000\u034b\u034c\u0005e\u0000\u0000\u034c\u034d"+
-		"\u0005r\u0000\u0000\u034d\u034e\u0005s\u0000\u0000\u034e\u03eb\u0005e"+
-		"\u0000\u0000\u034f\u0350\u0005i\u0000\u0000\u0350\u0351\u0005s\u0000\u0000"+
-		"\u0351\u0352\u0005_\u0000\u0000\u0352\u0353\u0005e\u0000\u0000\u0353\u0354"+
-		"\u0005m\u0000\u0000\u0354\u0355\u0005p\u0000\u0000\u0355\u0356\u0005t"+
-		"\u0000\u0000\u0356\u03eb\u0005y\u0000\u0000\u0357\u0358\u0005n\u0000\u0000"+
-		"\u0358\u0359\u0005o\u0000\u0000\u0359\u035a\u0005n\u0000\u0000\u035a\u035b"+
-		"\u0005_\u0000\u0000\u035b\u035c\u0005e\u0000\u0000\u035c\u035d\u0005m"+
-		"\u0000\u0000\u035d\u035e\u0005p\u0000\u0000\u035e\u035f\u0005t\u0000\u0000"+
-		"\u035f\u03eb\u0005y\u0000\u0000\u0360\u0361\u0005d\u0000\u0000\u0361\u0362"+
-		"\u0005i\u0000\u0000\u0362\u0363\u0005s\u0000\u0000\u0363\u0364\u0005t"+
-		"\u0000\u0000\u0364\u0365\u0005i\u0000\u0000\u0365\u0366\u0005n\u0000\u0000"+
-		"\u0366\u0367\u0005c\u0000\u0000\u0367\u03eb\u0005t\u0000\u0000\u0368\u0369"+
-		"\u0005c\u0000\u0000\u0369\u036a\u0005o\u0000\u0000\u036a\u036b\u0005n"+
-		"\u0000\u0000\u036b\u036c\u0005c\u0000\u0000\u036c\u036d\u0005a\u0000\u0000"+
-		"\u036d\u03eb\u0005t\u0000\u0000\u036e\u036f\u0005t\u0000\u0000\u036f\u0370"+
-		"\u0005o\u0000\u0000\u0370\u0371\u0005_\u0000\u0000\u0371\u0372\u0005s"+
-		"\u0000\u0000\u0372\u0373\u0005t\u0000\u0000\u0373\u0374\u0005r\u0000\u0000"+
-		"\u0374\u0375\u0005i\u0000\u0000\u0375\u0376\u0005n\u0000\u0000\u0376\u03eb"+
-		"\u0005g\u0000\u0000\u0377\u0378\u0005m\u0000\u0000\u0378\u0379\u0005a"+
-		"\u0000\u0000\u0379\u03eb\u0005x\u0000\u0000\u037a\u037b\u0005m\u0000\u0000"+
-		"\u037b\u037c\u0005i\u0000\u0000\u037c\u03eb\u0005n\u0000\u0000\u037d\u037e"+
-		"\u0005a\u0000\u0000\u037e\u037f\u0005v\u0000\u0000\u037f\u03eb\u0005g"+
-		"\u0000\u0000\u0380\u0381\u0005s\u0000\u0000\u0381\u0382\u0005t\u0000\u0000"+
-		"\u0382\u0383\u0005d\u0000\u0000\u0383\u0384\u0005e\u0000\u0000\u0384\u03eb"+
-		"\u0005v\u0000\u0000\u0385\u0386\u0005y\u0000\u0000\u0386\u0387\u0005e"+
-		"\u0000\u0000\u0387\u0388\u0005a\u0000\u0000\u0388\u03eb\u0005r\u0000\u0000"+
-		"\u0389\u038a\u0005m\u0000\u0000\u038a\u038b\u0005o\u0000\u0000\u038b\u038c"+
-		"\u0005n\u0000\u0000\u038c\u038d\u0005t\u0000\u0000\u038d\u03eb\u0005h"+
-		"\u0000\u0000\u038e\u038f\u0005d\u0000\u0000\u038f\u0390\u0005a\u0000\u0000"+
-		"\u0390\u0391\u0005y\u0000\u0000\u0391\u0392\u0005_\u0000\u0000\u0392\u0393"+
-		"\u0005o\u0000\u0000\u0393\u0394\u0005f\u0000\u0000\u0394\u0395\u0005_"+
-		"\u0000\u0000\u0395\u0396\u0005m\u0000\u0000\u0396\u0397\u0005o\u0000\u0000"+
-		"\u0397\u0398\u0005n\u0000\u0000\u0398\u0399\u0005t\u0000\u0000\u0399\u03eb"+
-		"\u0005h\u0000\u0000\u039a\u039b\u0005d\u0000\u0000\u039b\u039c\u0005a"+
-		"\u0000\u0000\u039c\u039d\u0005y\u0000\u0000\u039d\u039e\u0005_\u0000\u0000"+
-		"\u039e\u039f\u0005o\u0000\u0000\u039f\u03a0\u0005f\u0000\u0000\u03a0\u03a1"+
-		"\u0005_\u0000\u0000\u03a1\u03a2\u0005w\u0000\u0000\u03a2\u03a3\u0005e"+
-		"\u0000\u0000\u03a3\u03a4\u0005e\u0000\u0000\u03a4\u03eb\u0005k\u0000\u0000"+
-		"\u03a5\u03a6\u0005d\u0000\u0000\u03a6\u03a7\u0005a\u0000\u0000\u03a7\u03a8"+
-		"\u0005y\u0000\u0000\u03a8\u03a9\u0005_\u0000\u0000\u03a9\u03aa\u0005o"+
-		"\u0000\u0000\u03aa\u03ab\u0005f\u0000\u0000\u03ab\u03ac\u0005_\u0000\u0000"+
-		"\u03ac\u03ad\u0005y\u0000\u0000\u03ad\u03ae\u0005e\u0000\u0000\u03ae\u03af"+
-		"\u0005a\u0000\u0000\u03af\u03eb\u0005r\u0000\u0000\u03b0\u03b1\u0005h"+
-		"\u0000\u0000\u03b1\u03b2\u0005o\u0000\u0000\u03b2\u03b3\u0005u\u0000\u0000"+
-		"\u03b3\u03eb\u0005r\u0000\u0000\u03b4\u03b5\u0005m\u0000\u0000\u03b5\u03b6"+
-		"\u0005i\u0000\u0000\u03b6\u03b7\u0005n\u0000\u0000\u03b7\u03b8\u0005u"+
-		"\u0000\u0000\u03b8\u03b9\u0005t\u0000\u0000\u03b9\u03eb\u0005e\u0000\u0000"+
-		"\u03ba\u03bb\u0005s\u0000\u0000\u03bb\u03bc\u0005e\u0000\u0000\u03bc\u03bd"+
-		"\u0005c\u0000\u0000\u03bd\u03be\u0005o\u0000\u0000\u03be\u03bf\u0005n"+
-		"\u0000\u0000\u03bf\u03eb\u0005d\u0000\u0000\u03c0\u03c1\u0005w\u0000\u0000"+
-		"\u03c1\u03c2\u0005e\u0000\u0000\u03c2\u03c3\u0005e\u0000\u0000\u03c3\u03c4"+
-		"\u0005k\u0000\u0000\u03c4\u03c5\u0005_\u0000\u0000\u03c5\u03c6\u0005o"+
-		"\u0000\u0000\u03c6\u03c7\u0005f\u0000\u0000\u03c7\u03c8\u0005_\u0000\u0000"+
-		"\u03c8\u03c9\u0005m\u0000\u0000\u03c9\u03ca\u0005o\u0000\u0000\u03ca\u03cb"+
-		"\u0005n\u0000\u0000\u03cb\u03cc\u0005t\u0000\u0000\u03cc\u03eb\u0005h"+
-		"\u0000\u0000\u03cd\u03ce\u0005w\u0000\u0000\u03ce\u03cf\u0005e\u0000\u0000"+
-		"\u03cf\u03d0\u0005e\u0000\u0000\u03d0\u03d1\u0005k\u0000\u0000\u03d1\u03d2"+
-		"\u0005_\u0000\u0000\u03d2\u03d3\u0005o\u0000\u0000\u03d3\u03d4\u0005f"+
-		"\u0000\u0000\u03d4\u03d5\u0005_\u0000\u0000\u03d5\u03d6\u0005y\u0000\u0000"+
-		"\u03d6\u03d7\u0005e\u0000\u0000\u03d7\u03d8\u0005a\u0000\u0000\u03d8\u03eb"+
-		"\u0005r\u0000\u0000\u03d9\u03da\u0005q\u0000\u0000\u03da\u03db\u0005u"+
-		"\u0000\u0000\u03db\u03dc\u0005a\u0000\u0000\u03dc\u03dd\u0005r\u0000\u0000"+
-		"\u03dd\u03de\u0005t\u0000\u0000\u03de\u03df\u0005e\u0000\u0000\u03df\u03eb"+
-		"\u0005r\u0000\u0000\u03e0\u03e1\u0005n\u0000\u0000\u03e1\u03e2\u0005o"+
-		"\u0000\u0000\u03e2\u03eb\u0005w\u0000\u0000\u03e3\u03e4\u0005o\u0000\u0000"+
-		"\u03e4\u03e5\u0005r\u0000\u0000\u03e5\u03e6\u0005_\u0000\u0000\u03e6\u03e7"+
-		"\u0005e\u0000\u0000\u03e7\u03e8\u0005l\u0000\u0000\u03e8\u03e9\u0005s"+
-		"\u0000\u0000\u03e9\u03eb\u0005e\u0000\u0000\u03eam\u0001\u0000\u0000\u0000"+
-		"\u03eau\u0001\u0000\u0000\u0000\u03ea}\u0001\u0000\u0000\u0000\u03ea\u0088"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0090\u0001\u0000\u0000\u0000\u03ea\u0098"+
-		"\u0001\u0000\u0000\u0000\u03ea\u00a1\u0001\u0000\u0000\u0000\u03ea\u00aa"+
-		"\u0001\u0000\u0000\u0000\u03ea\u00ae\u0001\u0000\u0000\u0000\u03ea\u00b0"+
-		"\u0001\u0000\u0000\u0000\u03ea\u00b6\u0001\u0000\u0000\u0000\u03ea\u00bf"+
-		"\u0001\u0000\u0000\u0000\u03ea\u00c7\u0001\u0000\u0000\u0000\u03ea\u00d1"+
-		"\u0001\u0000\u0000\u0000\u03ea\u00da\u0001\u0000\u0000\u0000\u03ea\u00e1"+
-		"\u0001\u0000\u0000\u0000\u03ea\u00ef\u0001\u0000\u0000\u0000\u03ea\u0100"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0108\u0001\u0000\u0000\u0000\u03ea\u0113"+
-		"\u0001\u0000\u0000\u0000\u03ea\u011f\u0001\u0000\u0000\u0000\u03ea\u012f"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0142\u0001\u0000\u0000\u0000\u03ea\u0151"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0163\u0001\u0000\u0000\u0000\u03ea\u0175"+
-		"\u0001\u0000\u0000\u0000\u03ea\u018a\u0001\u0000\u0000\u0000\u03ea\u0190"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0198\u0001\u0000\u0000\u0000\u03ea\u019f"+
-		"\u0001\u0000\u0000\u0000\u03ea\u01a9\u0001\u0000\u0000\u0000\u03ea\u01af"+
-		"\u0001\u0000\u0000\u0000\u03ea\u01b7\u0001\u0000\u0000\u0000\u03ea\u01c1"+
-		"\u0001\u0000\u0000\u0000\u03ea\u01c8\u0001\u0000\u0000\u0000\u03ea\u01cc"+
-		"\u0001\u0000\u0000\u0000\u03ea\u01d1\u0001\u0000\u0000\u0000\u03ea\u01d6"+
-		"\u0001\u0000\u0000\u0000\u03ea\u01df\u0001\u0000\u0000\u0000\u03ea\u01e8"+
-		"\u0001\u0000\u0000\u0000\u03ea\u01f0\u0001\u0000\u0000\u0000\u03ea\u01fb"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0208\u0001\u0000\u0000\u0000\u03ea\u020e"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0219\u0001\u0000\u0000\u0000\u03ea\u0226"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0236\u0001\u0000\u0000\u0000\u03ea\u023b"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0245\u0001\u0000\u0000\u0000\u03ea\u0250"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0259\u0001\u0000\u0000\u0000\u03ea\u0261"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0269\u0001\u0000\u0000\u0000\u03ea\u026f"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0276\u0001\u0000\u0000\u0000\u03ea\u0279"+
-		"\u0001\u0000\u0000\u0000\u03ea\u027d\u0001\u0000\u0000\u0000\u03ea\u0282"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0286\u0001\u0000\u0000\u0000\u03ea\u028b"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0291\u0001\u0000\u0000\u0000\u03ea\u0295"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0299\u0001\u0000\u0000\u0000\u03ea\u029b"+
-		"\u0001\u0000\u0000\u0000\u03ea\u02a4\u0001\u0000\u0000\u0000\u03ea\u02aa"+
-		"\u0001\u0000\u0000\u0000\u03ea\u02af\u0001\u0000\u0000\u0000\u03ea\u02b3"+
-		"\u0001\u0000\u0000\u0000\u03ea\u02b7\u0001\u0000\u0000\u0000\u03ea\u02bb"+
-		"\u0001\u0000\u0000\u0000\u03ea\u02be\u0001\u0000\u0000\u0000\u03ea\u02c1"+
-		"\u0001\u0000\u0000\u0000\u03ea\u02c4\u0001\u0000\u0000\u0000\u03ea\u02c8"+
-		"\u0001\u0000\u0000\u0000\u03ea\u02cc\u0001\u0000\u0000\u0000\u03ea\u02d0"+
-		"\u0001\u0000\u0000\u0000\u03ea\u02d5\u0001\u0000\u0000\u0000\u03ea\u02dc"+
-		"\u0001\u0000\u0000\u0000\u03ea\u02e3\u0001\u0000\u0000\u0000\u03ea\u02e6"+
-		"\u0001\u0000\u0000\u0000\u03ea\u02eb\u0001\u0000\u0000\u0000\u03ea\u02f0"+
-		"\u0001\u0000\u0000\u0000\u03ea\u02f3\u0001\u0000\u0000\u0000\u03ea\u02f8"+
-		"\u0001\u0000\u0000\u0000\u03ea\u02fd\u0001\u0000\u0000\u0000\u03ea\u0300"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0304\u0001\u0000\u0000\u0000\u03ea\u030a"+
-		"\u0001\u0000\u0000\u0000\u03ea\u030e\u0001\u0000\u0000\u0000\u03ea\u0311"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0314\u0001\u0000\u0000\u0000\u03ea\u031b"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0322\u0001\u0000\u0000\u0000\u03ea\u0327"+
-		"\u0001\u0000\u0000\u0000\u03ea\u032b\u0001\u0000\u0000\u0000\u03ea\u032f"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0335\u0001\u0000\u0000\u0000\u03ea\u033b"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0340\u0001\u0000\u0000\u0000\u03ea\u0344"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0348\u0001\u0000\u0000\u0000\u03ea\u034f"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0357\u0001\u0000\u0000\u0000\u03ea\u0360"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0368\u0001\u0000\u0000\u0000\u03ea\u036e"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0377\u0001\u0000\u0000\u0000\u03ea\u037a"+
-		"\u0001\u0000\u0000\u0000\u03ea\u037d\u0001\u0000\u0000\u0000\u03ea\u0380"+
-		"\u0001\u0000\u0000\u0000\u03ea\u0385\u0001\u0000\u0000\u0000\u03ea\u0389"+
-		"\u0001\u0000\u0000\u0000\u03ea\u038e\u0001\u0000\u0000\u0000\u03ea\u039a"+
-		"\u0001\u0000\u0000\u0000\u03ea\u03a5\u0001\u0000\u0000\u0000\u03ea\u03b0"+
-		"\u0001\u0000\u0000\u0000\u03ea\u03b4\u0001\u0000\u0000\u0000\u03ea\u03ba"+
-		"\u0001\u0000\u0000\u0000\u03ea\u03c0\u0001\u0000\u0000\u0000\u03ea\u03cd"+
-		"\u0001\u0000\u0000\u0000\u03ea\u03d9\u0001\u0000\u0000\u0000\u03ea\u03e0"+
-		"\u0001\u0000\u0000\u0000\u03ea\u03e3\u0001\u0000\u0000\u0000\u03eb\u0002"+
-		"\u0001\u0000\u0000\u0000\u03ec\u03ed\u0005i\u0000\u0000\u03ed\u03ee\u0005"+
-		"m\u0000\u0000\u03ee\u03ef\u0005p\u0000\u0000\u03ef\u03f0\u0005o\u0000"+
-		"\u0000\u03f0\u03f1\u0005r\u0000\u0000\u03f1\u03f2\u0005t\u0000\u0000\u03f2"+
-		"\u0004\u0001\u0000\u0000\u0000\u03f3\u03f4\u0005i\u0000\u0000\u03f4\u03f5"+
-		"\u0005n\u0000\u0000\u03f5\u03f6\u0005t\u0000\u0000\u03f6\u03f7\u0005e"+
-		"\u0000\u0000\u03f7\u03f8\u0005n\u0000\u0000\u03f8\u03f9\u0005t\u0000\u0000"+
-		"\u03f9\u0006\u0001\u0000\u0000\u0000\u03fa\u03fb\u0005o\u0000\u0000\u03fb"+
-		"\u03fc\u0005p\u0000\u0000\u03fc\u03fd\u0005t\u0000\u0000\u03fd\u03fe\u0005"+
-		"i\u0000\u0000\u03fe\u03ff\u0005o\u0000\u0000\u03ff\u0400\u0005n\u0000"+
-		"\u0000\u0400\u0401\u0005s\u0000\u0000\u0401\b\u0001\u0000\u0000\u0000"+
-		"\u0402\u0403\u0005f\u0000\u0000\u0403\u0404\u0005l\u0000\u0000\u0404\u0405"+
-		"\u0005o\u0000\u0000\u0405\u0406\u0005w\u0000\u0000\u0406\n\u0001\u0000"+
-		"\u0000\u0000\u0407\u0408\u0005m\u0000\u0000\u0408\u0409\u0005e\u0000\u0000"+
-		"\u0409\u040a\u0005t\u0000\u0000\u040a\u040b\u0005a\u0000\u0000\u040b\f"+
-		"\u0001\u0000\u0000\u0000\u040c\u040d\u0005t\u0000\u0000\u040d\u040e\u0005"+
-		"e\u0000\u0000\u040e\u040f\u0005r\u0000\u0000\u040f\u0410\u0005m\u0000"+
-		"\u0000\u0410\u000e\u0001\u0000\u0000\u0000\u0411\u0412\u0005f\u0000\u0000"+
-		"\u0412\u0413\u0005r\u0000\u0000\u0413\u0414\u0005a\u0000\u0000\u0414\u0415"+
-		"\u0005g\u0000\u0000\u0415\u0416\u0005m\u0000\u0000\u0416\u0417\u0005e"+
-		"\u0000\u0000\u0417\u0418\u0005n\u0000\u0000\u0418\u0419\u0005t\u0000\u0000"+
-		"\u0419\u0010\u0001\u0000\u0000\u0000\u041a\u0420\u00035\u001a\u0000\u041b"+
-		"\u041f\b\u0000\u0000\u0000\u041c\u041d\u0005\\\u0000\u0000\u041d\u041f"+
-		"\u0005\'\u0000\u0000\u041e\u041b\u0001\u0000\u0000\u0000\u041e\u041c\u0001"+
-		"\u0000\u0000\u0000\u041f\u0422\u0001\u0000\u0000\u0000\u0420\u041e\u0001"+
-		"\u0000\u0000\u0000\u0420\u0421\u0001\u0000\u0000\u0000\u0421\u0423\u0001"+
-		"\u0000\u0000\u0000\u0422\u0420\u0001\u0000\u0000\u0000\u0423\u0424\u0003"+
-		"5\u001a\u0000\u0424\u0012\u0001\u0000\u0000\u0000\u0425\u042b\u00037\u001b"+
-		"\u0000\u0426\u042a\b\u0001\u0000\u0000\u0427\u0428\u0005\\\u0000\u0000"+
-		"\u0428\u042a\u0005\"\u0000\u0000\u0429\u0426\u0001\u0000\u0000\u0000\u0429"+
-		"\u0427\u0001\u0000\u0000\u0000\u042a\u042d\u0001\u0000\u0000\u0000\u042b"+
-		"\u0429\u0001\u0000\u0000\u0000\u042b\u042c\u0001\u0000\u0000\u0000\u042c"+
-		"\u042e\u0001\u0000\u0000\u0000\u042d\u042b\u0001\u0000\u0000\u0000\u042e"+
-		"\u042f\u00037\u001b\u0000\u042f\u0014\u0001\u0000\u0000\u0000\u0430\u0431"+
-		"\u0005t\u0000\u0000\u0431\u0432\u0005r\u0000\u0000\u0432\u0433\u0005u"+
-		"\u0000\u0000\u0433\u043a\u0005e\u0000\u0000\u0434\u0435\u0005f\u0000\u0000"+
-		"\u0435\u0436\u0005a\u0000\u0000\u0436\u0437\u0005l\u0000\u0000\u0437\u0438"+
-		"\u0005s\u0000\u0000\u0438\u043a\u0005e\u0000\u0000\u0439\u0430\u0001\u0000"+
-		"\u0000\u0000\u0439\u0434\u0001\u0000\u0000\u0000\u043a\u0016\u0001\u0000"+
-		"\u0000\u0000\u043b\u043c\u0005n\u0000\u0000\u043c\u043d\u0005u\u0000\u0000"+
-		"\u043d\u043e\u0005l\u0000\u0000\u043e\u043f\u0005l\u0000\u0000\u043f\u0018"+
-		"\u0001\u0000\u0000\u0000\u0440\u0441\u0005=\u0000\u0000\u0441\u0442\u0005"+
-		"=\u0000\u0000\u0442\u001a\u0001\u0000\u0000\u0000\u0443\u0444\u0005!\u0000"+
-		"\u0000\u0444\u0445\u0005=\u0000\u0000\u0445\u001c\u0001\u0000\u0000\u0000"+
-		"\u0446\u0447\u0005>\u0000\u0000\u0447\u0448\u0005=\u0000\u0000\u0448\u001e"+
-		"\u0001\u0000\u0000\u0000\u0449\u044a\u0005<\u0000\u0000\u044a\u044b\u0005"+
-		"=\u0000\u0000\u044b \u0001\u0000\u0000\u0000\u044c\u044d\u0005>\u0000"+
-		"\u0000\u044d\"\u0001\u0000\u0000\u0000\u044e\u044f\u0005<\u0000\u0000"+
-		"\u044f$\u0001\u0000\u0000\u0000\u0450\u0451\u0005&\u0000\u0000\u0451\u0452"+
-		"\u0005&\u0000\u0000\u0452&\u0001\u0000\u0000\u0000\u0453\u0454\u0005|"+
-		"\u0000\u0000\u0454\u0455\u0005|\u0000\u0000\u0455(\u0001\u0000\u0000\u0000"+
-		"\u0456\u0457\u0005|\u0000\u0000\u0457*\u0001\u0000\u0000\u0000\u0458\u0459"+
-		"\u0005!\u0000\u0000\u0459,\u0001\u0000\u0000\u0000\u045a\u045b\u0005("+
-		"\u0000\u0000\u045b.\u0001\u0000\u0000\u0000\u045c\u045d\u0005)\u0000\u0000"+
-		"\u045d0\u0001\u0000\u0000\u0000\u045e\u045f\u0005{\u0000\u0000\u045f2"+
-		"\u0001\u0000\u0000\u0000\u0460\u0461\u0005}\u0000\u0000\u04614\u0001\u0000"+
-		"\u0000\u0000\u0462\u0463\u0005\'\u0000\u0000\u04636\u0001\u0000\u0000"+
-		"\u0000\u0464\u0465\u0005\"\u0000\u0000\u04658\u0001\u0000\u0000\u0000"+
-		"\u0466\u0467\u0005~\u0000\u0000\u0467:\u0001\u0000\u0000\u0000\u0468\u0469"+
-		"\u0005[\u0000\u0000\u0469<\u0001\u0000\u0000\u0000\u046a\u046b\u0005]"+
-		"\u0000\u0000\u046b>\u0001\u0000\u0000\u0000\u046c\u046d\u0005#\u0000\u0000"+
-		"\u046d@\u0001\u0000\u0000\u0000\u046e\u046f\u0005,\u0000\u0000\u046fB"+
-		"\u0001\u0000\u0000\u0000\u0470\u0471\u0005:\u0000\u0000\u0471D\u0001\u0000"+
-		"\u0000\u0000\u0472\u0473\u0005-\u0000\u0000\u0473F\u0001\u0000\u0000\u0000"+
-		"\u0474\u0475\u0005.\u0000\u0000\u0475H\u0001\u0000\u0000\u0000\u0476\u0477"+
-		"\u0005_\u0000\u0000\u0477J\u0001\u0000\u0000\u0000\u0478\u0479\u0005="+
-		"\u0000\u0000\u0479L\u0001\u0000\u0000\u0000\u047a\u047b\u0005+\u0000\u0000"+
-		"\u047bN\u0001\u0000\u0000\u0000\u047c\u047d\u0005?\u0000\u0000\u047dP"+
-		"\u0001\u0000\u0000\u0000\u047e\u047f\u0005*\u0000\u0000\u047fR\u0001\u0000"+
-		"\u0000\u0000\u0480\u0481\u0005/\u0000\u0000\u0481T\u0001\u0000\u0000\u0000"+
-		"\u0482\u0483\u0005%\u0000\u0000\u0483V\u0001\u0000\u0000\u0000\u0484\u0485"+
-		"\u0005@\u0000\u0000\u0485X\u0001\u0000\u0000\u0000\u0486\u0487\u0005$"+
-		"\u0000\u0000\u0487Z\u0001\u0000\u0000\u0000\u0488\u0491\u00050\u0000\u0000"+
-		"\u0489\u048d\u0007\u0002\u0000\u0000\u048a\u048c\u0007\u0003\u0000\u0000"+
-		"\u048b\u048a\u0001\u0000\u0000\u0000\u048c\u048f\u0001\u0000\u0000\u0000"+
-		"\u048d\u048b\u0001\u0000\u0000\u0000\u048d\u048e\u0001\u0000\u0000\u0000"+
-		"\u048e\u0491\u0001\u0000\u0000\u0000\u048f\u048d\u0001\u0000\u0000\u0000"+
-		"\u0490\u0488\u0001\u0000\u0000\u0000\u0490\u0489\u0001\u0000\u0000\u0000"+
-		"\u0491\\\u0001\u0000\u0000\u0000\u0492\u0494\u0003G#\u0000\u0493\u0495"+
-		"\u0007\u0004\u0000\u0000\u0494\u0493\u0001\u0000\u0000\u0000\u0495\u0496"+
-		"\u0001\u0000\u0000\u0000\u0496\u0494\u0001\u0000\u0000\u0000\u0496\u0497"+
-		"\u0001\u0000\u0000\u0000\u0497^\u0001\u0000\u0000\u0000\u0498\u049a\u0007"+
-		"\u0005\u0000\u0000\u0499\u049b\u0007\u0006\u0000\u0000\u049a\u0499\u0001"+
-		"\u0000\u0000\u0000\u049a\u049b\u0001\u0000\u0000\u0000\u049b\u049c\u0001"+
-		"\u0000\u0000\u0000\u049c\u049d\u0003[-\u0000\u049d`\u0001\u0000\u0000"+
-		"\u0000\u049e\u04a2\b\u0007\u0000\u0000\u049f\u04a0\u0007\b\u0000\u0000"+
-		"\u04a0\u04a2\u0007\t\u0000\u0000\u04a1\u049e\u0001\u0000\u0000\u0000\u04a1"+
-		"\u049f\u0001\u0000\u0000\u0000\u04a2b\u0001\u0000\u0000\u0000\u04a3\u04a4"+
-		"\u0007\n\u0000\u0000\u04a4d\u0001\u0000\u0000\u0000\u04a5\u04aa\u0003"+
-		"a0\u0000\u04a6\u04aa\u0003I$\u0000\u04a7\u04aa\u0003c1\u0000\u04a8\u04aa"+
-		"\u0003Y,\u0000\u04a9\u04a5\u0001\u0000\u0000\u0000\u04a9\u04a6\u0001\u0000"+
-		"\u0000\u0000\u04a9\u04a7\u0001\u0000\u0000\u0000\u04a9\u04a8\u0001\u0000"+
-		"\u0000\u0000\u04aa\u04ab\u0001\u0000\u0000\u0000\u04ab\u04a9\u0001\u0000"+
-		"\u0000\u0000\u04ab\u04ac\u0001\u0000\u0000\u0000\u04ac\u04b6\u0001\u0000"+
-		"\u0000\u0000\u04ad\u04b5\u0003a0\u0000\u04ae\u04b5\u0003Y,\u0000\u04af"+
-		"\u04b5\u0003c1\u0000\u04b0\u04b5\u0007\u0004\u0000\u0000\u04b1\u04b5\u0003"+
-		"C!\u0000\u04b2\u04b5\u0003E\"\u0000\u04b3\u04b5\u0003I$\u0000\u04b4\u04ad"+
-		"\u0001\u0000\u0000\u0000\u04b4\u04ae\u0001\u0000\u0000\u0000\u04b4\u04af"+
-		"\u0001\u0000\u0000\u0000\u04b4\u04b0\u0001\u0000\u0000\u0000\u04b4\u04b1"+
-		"\u0001\u0000\u0000\u0000\u04b4\u04b2\u0001\u0000\u0000\u0000\u04b4\u04b3"+
-		"\u0001\u0000\u0000\u0000\u04b5\u04b8\u0001\u0000\u0000\u0000\u04b6\u04b4"+
-		"\u0001\u0000\u0000\u0000\u04b6\u04b7\u0001\u0000\u0000\u0000\u04b7f\u0001"+
-		"\u0000\u0000\u0000\u04b8\u04b6\u0001\u0000\u0000\u0000\u04b9\u04ba\u0005"+
-		"/\u0000\u0000\u04ba\u04bb\u0005/\u0000\u0000\u04bb\u04bf\u0001\u0000\u0000"+
-		"\u0000\u04bc\u04be\b\u000b\u0000\u0000\u04bd\u04bc\u0001\u0000\u0000\u0000"+
-		"\u04be\u04c1\u0001\u0000\u0000\u0000\u04bf\u04bd\u0001\u0000\u0000\u0000"+
-		"\u04bf\u04c0\u0001\u0000\u0000\u0000\u04c0\u04c3\u0001\u0000\u0000\u0000"+
-		"\u04c1\u04bf\u0001\u0000\u0000\u0000\u04c2\u04c4\u0005\r\u0000\u0000\u04c3"+
-		"\u04c2\u0001\u0000\u0000\u0000\u04c3\u04c4\u0001\u0000\u0000\u0000\u04c4"+
-		"\u04c6\u0001\u0000\u0000\u0000\u04c5\u04c7\u0007\f\u0000\u0000\u04c6\u04c5"+
-		"\u0001\u0000\u0000\u0000\u04c7\u04d4\u0001\u0000\u0000\u0000\u04c8\u04c9"+
-		"\u0005/\u0000\u0000\u04c9\u04ca\u0005*\u0000\u0000\u04ca\u04ce\u0001\u0000"+
-		"\u0000\u0000\u04cb\u04cd\t\u0000\u0000\u0000\u04cc\u04cb\u0001\u0000\u0000"+
-		"\u0000\u04cd\u04d0\u0001\u0000\u0000\u0000\u04ce\u04cf\u0001\u0000\u0000"+
-		"\u0000\u04ce\u04cc\u0001\u0000\u0000\u0000\u04cf\u04d1\u0001\u0000\u0000"+
-		"\u0000\u04d0\u04ce\u0001\u0000\u0000\u0000\u04d1\u04d2\u0005*\u0000\u0000"+
-		"\u04d2\u04d4\u0005/\u0000\u0000\u04d3\u04b9\u0001\u0000\u0000\u0000\u04d3"+
-		"\u04c8\u0001\u0000\u0000\u0000\u04d4\u04d5\u0001\u0000\u0000\u0000\u04d5"+
-		"\u04d6\u00063\u0000\u0000\u04d6h\u0001\u0000\u0000\u0000\u04d7\u04d9\u0007"+
-		"\r\u0000\u0000\u04d8\u04d7\u0001\u0000\u0000\u0000\u04d9\u04da\u0001\u0000"+
-		"\u0000\u0000\u04da\u04d8\u0001\u0000\u0000\u0000\u04da\u04db\u0001\u0000"+
-		"\u0000\u0000\u04db\u04dc\u0001\u0000\u0000\u0000\u04dc\u04dd\u00064\u0000"+
-		"\u0000\u04ddj\u0001\u0000\u0000\u0000\u04de\u04df\t\u0000\u0000\u0000"+
-		"\u04dfl\u0001\u0000\u0000\u0000\u0016\u0000\u03ea\u041e\u0420\u0429\u042b"+
-		"\u0439\u048d\u0490\u0496\u049a\u04a1\u04a9\u04ab\u04b4\u04b6\u04bf\u04c3"+
-		"\u04c6\u04ce\u04d3\u04da\u0001\u0006\u0000\u0000";
+		"\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000\u0001\u0000"+
+		"\u0001\u0000\u0003\u0000\u03ed\b\u0000\u0001\u0001\u0001\u0001\u0001\u0001"+
+		"\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0001\u0002\u0001\u0002"+
+		"\u0001\u0002\u0001\u0002\u0001\u0002\u0001\u0002\u0001\u0002\u0001\u0003"+
+		"\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0003\u0001\u0003"+
+		"\u0001\u0003\u0001\u0004\u0001\u0004\u0001\u0004\u0001\u0004\u0001\u0004"+
+		"\u0001\u0005\u0001\u0005\u0001\u0005\u0001\u0005\u0001\u0005\u0001\u0006"+
+		"\u0001\u0006\u0001\u0006\u0001\u0006\u0001\u0006\u0001\u0007\u0001\u0007"+
+		"\u0001\u0007\u0001\u0007\u0001\u0007\u0001\u0007\u0001\u0007\u0001\u0007"+
+		"\u0001\u0007\u0001\b\u0001\b\u0001\b\u0001\b\u0005\b\u0421\b\b\n\b\f\b"+
+		"\u0424\t\b\u0001\b\u0001\b\u0001\t\u0001\t\u0001\t\u0001\t\u0005\t\u042c"+
+		"\b\t\n\t\f\t\u042f\t\t\u0001\t\u0001\t\u0001\n\u0001\n\u0001\n\u0001\n"+
+		"\u0001\n\u0001\n\u0001\n\u0001\n\u0001\n\u0003\n\u043c\b\n\u0001\u000b"+
+		"\u0001\u000b\u0001\u000b\u0001\u000b\u0001\u000b\u0001\f\u0001\f\u0001"+
+		"\f\u0001\r\u0001\r\u0001\r\u0001\u000e\u0001\u000e\u0001\u000e\u0001\u000f"+
+		"\u0001\u000f\u0001\u000f\u0001\u0010\u0001\u0010\u0001\u0011\u0001\u0011"+
+		"\u0001\u0012\u0001\u0012\u0001\u0012\u0001\u0013\u0001\u0013\u0001\u0013"+
+		"\u0001\u0014\u0001\u0014\u0001\u0015\u0001\u0015\u0001\u0016\u0001\u0016"+
+		"\u0001\u0017\u0001\u0017\u0001\u0018\u0001\u0018\u0001\u0019\u0001\u0019"+
+		"\u0001\u001a\u0001\u001a\u0001\u001b\u0001\u001b\u0001\u001c\u0001\u001c"+
+		"\u0001\u001d\u0001\u001d\u0001\u001e\u0001\u001e\u0001\u001f\u0001\u001f"+
+		"\u0001 \u0001 \u0001!\u0001!\u0001\"\u0001\"\u0001#\u0001#\u0001$\u0001"+
+		"$\u0001%\u0001%\u0001&\u0001&\u0001\'\u0001\'\u0001(\u0001(\u0001)\u0001"+
+		")\u0001*\u0001*\u0001+\u0001+\u0001,\u0001,\u0001-\u0001-\u0001-\u0005"+
+		"-\u048e\b-\n-\f-\u0491\t-\u0003-\u0493\b-\u0001.\u0001.\u0004.\u0497\b"+
+		".\u000b.\f.\u0498\u0001/\u0001/\u0003/\u049d\b/\u0001/\u0001/\u00010\u0001"+
+		"0\u00010\u00030\u04a4\b0\u00011\u00011\u00012\u00012\u00012\u00012\u0004"+
+		"2\u04ac\b2\u000b2\f2\u04ad\u00012\u00012\u00012\u00012\u00012\u00012\u0001"+
+		"2\u00052\u04b7\b2\n2\f2\u04ba\t2\u00013\u00013\u00013\u00013\u00053\u04c0"+
+		"\b3\n3\f3\u04c3\t3\u00013\u00033\u04c6\b3\u00013\u00033\u04c9\b3\u0001"+
+		"3\u00013\u00013\u00013\u00053\u04cf\b3\n3\f3\u04d2\t3\u00013\u00013\u0003"+
+		"3\u04d6\b3\u00013\u00013\u00014\u00044\u04db\b4\u000b4\f4\u04dc\u0001"+
+		"4\u00014\u00015\u00015\u0001\u04d0\u00006\u0001\u0001\u0003\u0002\u0005"+
+		"\u0003\u0007\u0004\t\u0005\u000b\u0006\r\u0007\u000f\b\u0011\t\u0013\n"+
+		"\u0015\u000b\u0017\f\u0019\r\u001b\u000e\u001d\u000f\u001f\u0010!\u0011"+
+		"#\u0012%\u0013\'\u0014)\u0015+\u0016-\u0017/\u00181\u00193\u001a5\u001b"+
+		"7\u001c9\u001d;\u001e=\u001f? A!C\"E#G$I%K&M\'O(Q)S*U+W,Y-[.]/_0a\u0000"+
+		"c\u0000e1g2i3k4\u0001\u0000\u000e\u0001\u0000\'\'\u0001\u0000\"\"\u0001"+
+		"\u000019\u0002\u000009__\u0001\u000009\u0002\u0000EEee\u0002\u0000++-"+
+		"-\u0002\u0000\u0000\u007f\u8000\ud800\u8000\udbff\u0001\u0000\u8000\ud800"+
+		"\u8000\udbff\u0001\u0000\u8000\udc00\u8000\udfff\u0002\u0000AZaz\u0002"+
+		"\u0000\n\n\r\r\u0001\u0001\n\n\u0003\u0000\t\n\f\r  \u0573\u0000\u0001"+
+		"\u0001\u0000\u0000\u0000\u0000\u0003\u0001\u0000\u0000\u0000\u0000\u0005"+
+		"\u0001\u0000\u0000\u0000\u0000\u0007\u0001\u0000\u0000\u0000\u0000\t\u0001"+
+		"\u0000\u0000\u0000\u0000\u000b\u0001\u0000\u0000\u0000\u0000\r\u0001\u0000"+
+		"\u0000\u0000\u0000\u000f\u0001\u0000\u0000\u0000\u0000\u0011\u0001\u0000"+
+		"\u0000\u0000\u0000\u0013\u0001\u0000\u0000\u0000\u0000\u0015\u0001\u0000"+
+		"\u0000\u0000\u0000\u0017\u0001\u0000\u0000\u0000\u0000\u0019\u0001\u0000"+
+		"\u0000\u0000\u0000\u001b\u0001\u0000\u0000\u0000\u0000\u001d\u0001\u0000"+
+		"\u0000\u0000\u0000\u001f\u0001\u0000\u0000\u0000\u0000!\u0001\u0000\u0000"+
+		"\u0000\u0000#\u0001\u0000\u0000\u0000\u0000%\u0001\u0000\u0000\u0000\u0000"+
+		"\'\u0001\u0000\u0000\u0000\u0000)\u0001\u0000\u0000\u0000\u0000+\u0001"+
+		"\u0000\u0000\u0000\u0000-\u0001\u0000\u0000\u0000\u0000/\u0001\u0000\u0000"+
+		"\u0000\u00001\u0001\u0000\u0000\u0000\u00003\u0001\u0000\u0000\u0000\u0000"+
+		"5\u0001\u0000\u0000\u0000\u00007\u0001\u0000\u0000\u0000\u00009\u0001"+
+		"\u0000\u0000\u0000\u0000;\u0001\u0000\u0000\u0000\u0000=\u0001\u0000\u0000"+
+		"\u0000\u0000?\u0001\u0000\u0000\u0000\u0000A\u0001\u0000\u0000\u0000\u0000"+
+		"C\u0001\u0000\u0000\u0000\u0000E\u0001\u0000\u0000\u0000\u0000G\u0001"+
+		"\u0000\u0000\u0000\u0000I\u0001\u0000\u0000\u0000\u0000K\u0001\u0000\u0000"+
+		"\u0000\u0000M\u0001\u0000\u0000\u0000\u0000O\u0001\u0000\u0000\u0000\u0000"+
+		"Q\u0001\u0000\u0000\u0000\u0000S\u0001\u0000\u0000\u0000\u0000U\u0001"+
+		"\u0000\u0000\u0000\u0000W\u0001\u0000\u0000\u0000\u0000Y\u0001\u0000\u0000"+
+		"\u0000\u0000[\u0001\u0000\u0000\u0000\u0000]\u0001\u0000\u0000\u0000\u0000"+
+		"_\u0001\u0000\u0000\u0000\u0000e\u0001\u0000\u0000\u0000\u0000g\u0001"+
+		"\u0000\u0000\u0000\u0000i\u0001\u0000\u0000\u0000\u0000k\u0001\u0000\u0000"+
+		"\u0000\u0001\u03ec\u0001\u0000\u0000\u0000\u0003\u03ee\u0001\u0000\u0000"+
+		"\u0000\u0005\u03f5\u0001\u0000\u0000\u0000\u0007\u03fc\u0001\u0000\u0000"+
+		"\u0000\t\u0404\u0001\u0000\u0000\u0000\u000b\u0409\u0001\u0000\u0000\u0000"+
+		"\r\u040e\u0001\u0000\u0000\u0000\u000f\u0413\u0001\u0000\u0000\u0000\u0011"+
+		"\u041c\u0001\u0000\u0000\u0000\u0013\u0427\u0001\u0000\u0000\u0000\u0015"+
+		"\u043b\u0001\u0000\u0000\u0000\u0017\u043d\u0001\u0000\u0000\u0000\u0019"+
+		"\u0442\u0001\u0000\u0000\u0000\u001b\u0445\u0001\u0000\u0000\u0000\u001d"+
+		"\u0448\u0001\u0000\u0000\u0000\u001f\u044b\u0001\u0000\u0000\u0000!\u044e"+
+		"\u0001\u0000\u0000\u0000#\u0450\u0001\u0000\u0000\u0000%\u0452\u0001\u0000"+
+		"\u0000\u0000\'\u0455\u0001\u0000\u0000\u0000)\u0458\u0001\u0000\u0000"+
+		"\u0000+\u045a\u0001\u0000\u0000\u0000-\u045c\u0001\u0000\u0000\u0000/"+
+		"\u045e\u0001\u0000\u0000\u00001\u0460\u0001\u0000\u0000\u00003\u0462\u0001"+
+		"\u0000\u0000\u00005\u0464\u0001\u0000\u0000\u00007\u0466\u0001\u0000\u0000"+
+		"\u00009\u0468\u0001\u0000\u0000\u0000;\u046a\u0001\u0000\u0000\u0000="+
+		"\u046c\u0001\u0000\u0000\u0000?\u046e\u0001\u0000\u0000\u0000A\u0470\u0001"+
+		"\u0000\u0000\u0000C\u0472\u0001\u0000\u0000\u0000E\u0474\u0001\u0000\u0000"+
+		"\u0000G\u0476\u0001\u0000\u0000\u0000I\u0478\u0001\u0000\u0000\u0000K"+
+		"\u047a\u0001\u0000\u0000\u0000M\u047c\u0001\u0000\u0000\u0000O\u047e\u0001"+
+		"\u0000\u0000\u0000Q\u0480\u0001\u0000\u0000\u0000S\u0482\u0001\u0000\u0000"+
+		"\u0000U\u0484\u0001\u0000\u0000\u0000W\u0486\u0001\u0000\u0000\u0000Y"+
+		"\u0488\u0001\u0000\u0000\u0000[\u0492\u0001\u0000\u0000\u0000]\u0494\u0001"+
+		"\u0000\u0000\u0000_\u049a\u0001\u0000\u0000\u0000a\u04a3\u0001\u0000\u0000"+
+		"\u0000c\u04a5\u0001\u0000\u0000\u0000e\u04ab\u0001\u0000\u0000\u0000g"+
+		"\u04d5\u0001\u0000\u0000\u0000i\u04da\u0001\u0000\u0000\u0000k\u04e0\u0001"+
+		"\u0000\u0000\u0000mn\u0005m\u0000\u0000no\u0005e\u0000\u0000op\u0005t"+
+		"\u0000\u0000pq\u0005a\u0000\u0000qr\u0005_\u0000\u0000rs\u0005e\u0000"+
+		"\u0000st\u0005n\u0000\u0000t\u03ed\u0005t\u0000\u0000uv\u0005m\u0000\u0000"+
+		"vw\u0005e\u0000\u0000wx\u0005t\u0000\u0000xy\u0005a\u0000\u0000yz\u0005"+
+		"_\u0000\u0000z{\u0005c\u0000\u0000{|\u0005f\u0000\u0000|\u03ed\u0005g"+
+		"\u0000\u0000}~\u0005m\u0000\u0000~\u007f\u0005e\u0000\u0000\u007f\u0080"+
+		"\u0005t\u0000\u0000\u0080\u0081\u0005a\u0000\u0000\u0081\u0082\u0005_"+
+		"\u0000\u0000\u0082\u0083\u0005i\u0000\u0000\u0083\u0084\u0005n\u0000\u0000"+
+		"\u0084\u0085\u0005t\u0000\u0000\u0085\u0086\u0005e\u0000\u0000\u0086\u0087"+
+		"\u0005n\u0000\u0000\u0087\u03ed\u0005t\u0000\u0000\u0088\u0089\u0005m"+
+		"\u0000\u0000\u0089\u008a\u0005e\u0000\u0000\u008a\u008b\u0005t\u0000\u0000"+
+		"\u008b\u008c\u0005a\u0000\u0000\u008c\u008d\u0005_\u0000\u0000\u008d\u008e"+
+		"\u0005r\u0000\u0000\u008e\u008f\u0005e\u0000\u0000\u008f\u03ed\u0005q"+
+		"\u0000\u0000\u0090\u0091\u0005m\u0000\u0000\u0091\u0092\u0005e\u0000\u0000"+
+		"\u0092\u0093\u0005t\u0000\u0000\u0093\u0094\u0005a\u0000\u0000\u0094\u0095"+
+		"\u0005_\u0000\u0000\u0095\u0096\u0005s\u0000\u0000\u0096\u0097\u0005y"+
+		"\u0000\u0000\u0097\u03ed\u0005s\u0000\u0000\u0098\u0099\u0005m\u0000\u0000"+
+		"\u0099\u009a\u0005e\u0000\u0000\u009a\u009b\u0005t\u0000\u0000\u009b\u009c"+
+		"\u0005a\u0000\u0000\u009c\u009d\u0005_\u0000\u0000\u009d\u009e\u0005c"+
+		"\u0000\u0000\u009e\u009f\u0005o\u0000\u0000\u009f\u00a0\u0005n\u0000\u0000"+
+		"\u00a0\u03ed\u0005v\u0000\u0000\u00a1\u00a2\u0005m\u0000\u0000\u00a2\u00a3"+
+		"\u0005e\u0000\u0000\u00a3\u00a4\u0005t\u0000\u0000\u00a4\u00a5\u0005a"+
+		"\u0000\u0000\u00a5\u00a6\u0005_\u0000\u0000\u00a6\u00a7\u0005f\u0000\u0000"+
+		"\u00a7\u00a8\u0005r\u0000\u0000\u00a8\u00a9\u0005a\u0000\u0000\u00a9\u03ed"+
+		"\u0005g\u0000\u0000\u00aa\u00ab\u0005j\u0000\u0000\u00ab\u00ac\u0005s"+
+		"\u0000\u0000\u00ac\u00ad\u0005o\u0000\u0000\u00ad\u03ed\u0005n\u0000\u0000"+
+		"\u00ae\u00af\u0005i\u0000\u0000\u00af\u03ed\u0005f\u0000\u0000\u00b0\u00b1"+
+		"\u0005e\u0000\u0000\u00b1\u00b2\u0005n\u0000\u0000\u00b2\u00b3\u0005t"+
+		"\u0000\u0000\u00b3\u00b4\u0005_\u0000\u0000\u00b4\u00b5\u0005t\u0000\u0000"+
+		"\u00b5\u00b6\u0005y\u0000\u0000\u00b6\u00b7\u0005p\u0000\u0000\u00b7\u03ed"+
+		"\u0005e\u0000\u0000\u00b8\u00b9\u0005e\u0000\u0000\u00b9\u00ba\u0005n"+
+		"\u0000\u0000\u00ba\u00bb\u0005t\u0000\u0000\u00bb\u00bc\u0005_\u0000\u0000"+
+		"\u00bc\u00bd\u0005i\u0000\u0000\u00bd\u00be\u0005n\u0000\u0000\u00be\u00bf"+
+		"\u0005d\u0000\u0000\u00bf\u00c0\u0005e\u0000\u0000\u00c0\u03ed\u0005x"+
+		"\u0000\u0000\u00c1\u00c2\u0005e\u0000\u0000\u00c2\u00c3\u0005n\u0000\u0000"+
+		"\u00c3\u00c4\u0005t\u0000\u0000\u00c4\u00c5\u0005_\u0000\u0000\u00c5\u00c6"+
+		"\u0005t\u0000\u0000\u00c6\u00c7\u0005e\u0000\u0000\u00c7\u00c8\u0005x"+
+		"\u0000\u0000\u00c8\u03ed\u0005t\u0000\u0000\u00c9\u00ca\u0005e\u0000\u0000"+
+		"\u00ca\u00cb\u0005n\u0000\u0000\u00cb\u00cc\u0005t\u0000\u0000\u00cc\u00cd"+
+		"\u0005_\u0000\u0000\u00cd\u00ce\u0005g\u0000\u0000\u00ce\u00cf\u0005r"+
+		"\u0000\u0000\u00cf\u00d0\u0005o\u0000\u0000\u00d0\u00d1\u0005u\u0000\u0000"+
+		"\u00d1\u00d2\u0005p\u0000\u0000\u00d2\u03ed\u0005s\u0000\u0000\u00d3\u00d4"+
+		"\u0005e\u0000\u0000\u00d4\u00d5\u0005n\u0000\u0000\u00d5\u00d6\u0005t"+
+		"\u0000\u0000\u00d6\u00d7\u0005_\u0000\u0000\u00d7\u00d8\u0005c\u0000\u0000"+
+		"\u00d8\u00d9\u0005o\u0000\u0000\u00d9\u00da\u0005u\u0000\u0000\u00da\u00db"+
+		"\u0005n\u0000\u0000\u00db\u03ed\u0005t\u0000\u0000\u00dc\u00dd\u0005e"+
+		"\u0000\u0000\u00dd\u00de\u0005n\u0000\u0000\u00de\u00df\u0005t\u0000\u0000"+
+		"\u00df\u00e0\u0005_\u0000\u0000\u00e0\u00e1\u0005a\u0000\u0000\u00e1\u00e2"+
+		"\u0005l\u0000\u0000\u00e2\u03ed\u0005l\u0000\u0000\u00e3\u00e4\u0005e"+
+		"\u0000\u0000\u00e4\u00e5\u0005n\u0000\u0000\u00e5\u00e6\u0005t\u0000\u0000"+
+		"\u00e6\u00e7\u0005_\u0000\u0000\u00e7\u00e8\u0005a\u0000\u0000\u00e8\u00e9"+
+		"\u0005l\u0000\u0000\u00e9\u00ea\u0005l\u0000\u0000\u00ea\u00eb\u0005_"+
+		"\u0000\u0000\u00eb\u00ec\u0005f\u0000\u0000\u00ec\u00ed\u0005o\u0000\u0000"+
+		"\u00ed\u00ee\u0005r\u0000\u0000\u00ee\u00ef\u0005_\u0000\u0000\u00ef\u00f0"+
+		"\u0005i\u0000\u0000\u00f0\u03ed\u0005d\u0000\u0000\u00f1\u00f2\u0005e"+
+		"\u0000\u0000\u00f2\u00f3\u0005n\u0000\u0000\u00f3\u00f4\u0005t\u0000\u0000"+
+		"\u00f4\u00f5\u0005_\u0000\u0000\u00f5\u00f6\u0005a\u0000\u0000\u00f6\u00f7"+
+		"\u0005l\u0000\u0000\u00f7\u00f8\u0005l\u0000\u0000\u00f8\u00f9\u0005_"+
+		"\u0000\u0000\u00f9\u00fa\u0005f\u0000\u0000\u00fa\u00fb\u0005o\u0000\u0000"+
+		"\u00fb\u00fc\u0005r\u0000\u0000\u00fc\u00fd\u0005_\u0000\u0000\u00fd\u00fe"+
+		"\u0005g\u0000\u0000\u00fe\u00ff\u0005r\u0000\u0000\u00ff\u0100\u0005o"+
+		"\u0000\u0000\u0100\u0101\u0005u\u0000\u0000\u0101\u03ed\u0005p\u0000\u0000"+
+		"\u0102\u0103\u0005e\u0000\u0000\u0103\u0104\u0005n\u0000\u0000\u0104\u0105"+
+		"\u0005t\u0000\u0000\u0105\u0106\u0005_\u0000\u0000\u0106\u0107\u0005t"+
+		"\u0000\u0000\u0107\u0108\u0005h\u0000\u0000\u0108\u0109\u0005i\u0000\u0000"+
+		"\u0109\u03ed\u0005s\u0000\u0000\u010a\u010b\u0005e\u0000\u0000\u010b\u010c"+
+		"\u0005n\u0000\u0000\u010c\u010d\u0005t\u0000\u0000\u010d\u010e\u0005_"+
+		"\u0000\u0000\u010e\u010f\u0005i\u0000\u0000\u010f\u0110\u0005s\u0000\u0000"+
+		"\u0110\u0111\u0005_\u0000\u0000\u0111\u0112\u0005l\u0000\u0000\u0112\u0113"+
+		"\u0005a\u0000\u0000\u0113\u0114\u0005s\u0000\u0000\u0114\u03ed\u0005t"+
+		"\u0000\u0000\u0115\u0116\u0005e\u0000\u0000\u0116\u0117\u0005n\u0000\u0000"+
+		"\u0117\u0118\u0005t\u0000\u0000\u0118\u0119\u0005_\u0000\u0000\u0119\u011a"+
+		"\u0005i\u0000\u0000\u011a\u011b\u0005s\u0000\u0000\u011b\u011c\u0005_"+
+		"\u0000\u0000\u011c\u011d\u0005f\u0000\u0000\u011d\u011e\u0005i\u0000\u0000"+
+		"\u011e\u011f\u0005r\u0000\u0000\u011f\u0120\u0005s\u0000\u0000\u0120\u03ed"+
+		"\u0005t\u0000\u0000\u0121\u0122\u0005e\u0000\u0000\u0122\u0123\u0005n"+
+		"\u0000\u0000\u0123\u0124\u0005t\u0000\u0000\u0124\u0125\u0005_\u0000\u0000"+
+		"\u0125\u0126\u0005i\u0000\u0000\u0126\u0127\u0005s\u0000\u0000\u0127\u0128"+
+		"\u0005_\u0000\u0000\u0128\u0129\u0005b\u0000\u0000\u0129\u012a\u0005e"+
+		"\u0000\u0000\u012a\u012b\u0005f\u0000\u0000\u012b\u012c\u0005o\u0000\u0000"+
+		"\u012c\u012d\u0005r\u0000\u0000\u012d\u012e\u0005e\u0000\u0000\u012e\u012f"+
+		"\u0005_\u0000\u0000\u012f\u0130\u0005i\u0000\u0000\u0130\u03ed\u0005d"+
+		"\u0000\u0000\u0131\u0132\u0005e\u0000\u0000\u0132\u0133\u0005n\u0000\u0000"+
+		"\u0133\u0134\u0005t\u0000\u0000\u0134\u0135\u0005_\u0000\u0000\u0135\u0136"+
+		"\u0005i\u0000\u0000\u0136\u0137\u0005s\u0000\u0000\u0137\u0138\u0005_"+
+		"\u0000\u0000\u0138\u0139\u0005b\u0000\u0000\u0139\u013a\u0005e\u0000\u0000"+
+		"\u013a\u013b\u0005f\u0000\u0000\u013b\u013c\u0005o\u0000\u0000\u013c\u013d"+
+		"\u0005r\u0000\u0000\u013d\u013e\u0005e\u0000\u0000\u013e\u013f\u0005_"+
+		"\u0000\u0000\u013f\u0140\u0005g\u0000\u0000\u0140\u0141\u0005r\u0000\u0000"+
+		"\u0141\u0142\u0005o\u0000\u0000\u0142\u0143\u0005u\u0000\u0000\u0143\u03ed"+
+		"\u0005p\u0000\u0000\u0144\u0145\u0005e\u0000\u0000\u0145\u0146\u0005n"+
+		"\u0000\u0000\u0146\u0147\u0005t\u0000\u0000\u0147\u0148\u0005_\u0000\u0000"+
+		"\u0148\u0149\u0005i\u0000\u0000\u0149\u014a\u0005s\u0000\u0000\u014a\u014b"+
+		"\u0005_\u0000\u0000\u014b\u014c\u0005a\u0000\u0000\u014c\u014d\u0005f"+
+		"\u0000\u0000\u014d\u014e\u0005t\u0000\u0000\u014e\u014f\u0005e\u0000\u0000"+
+		"\u014f\u0150\u0005r\u0000\u0000\u0150\u0151\u0005_\u0000\u0000\u0151\u0152"+
+		"\u0005i\u0000\u0000\u0152\u03ed\u0005d\u0000\u0000\u0153\u0154\u0005e"+
+		"\u0000\u0000\u0154\u0155\u0005n\u0000\u0000\u0155\u0156\u0005t\u0000\u0000"+
+		"\u0156\u0157\u0005_\u0000\u0000\u0157\u0158\u0005i\u0000\u0000\u0158\u0159"+
+		"\u0005s\u0000\u0000\u0159\u015a\u0005_\u0000\u0000\u015a\u015b\u0005a"+
+		"\u0000\u0000\u015b\u015c\u0005f\u0000\u0000\u015c\u015d\u0005t\u0000\u0000"+
+		"\u015d\u015e\u0005e\u0000\u0000\u015e\u015f\u0005r\u0000\u0000\u015f\u0160"+
+		"\u0005_\u0000\u0000\u0160\u0161\u0005g\u0000\u0000\u0161\u0162\u0005r"+
+		"\u0000\u0000\u0162\u0163\u0005o\u0000\u0000\u0163\u0164\u0005u\u0000\u0000"+
+		"\u0164\u03ed\u0005p\u0000\u0000\u0165\u0166\u0005e\u0000\u0000\u0166\u0167"+
+		"\u0005n\u0000\u0000\u0167\u0168\u0005t\u0000\u0000\u0168\u0169\u0005_"+
+		"\u0000\u0000\u0169\u016a\u0005i\u0000\u0000\u016a\u016b\u0005s\u0000\u0000"+
+		"\u016b\u016c\u0005_\u0000\u0000\u016c\u016d\u0005b\u0000\u0000\u016d\u016e"+
+		"\u0005e\u0000\u0000\u016e\u016f\u0005t\u0000\u0000\u016f\u0170\u0005w"+
+		"\u0000\u0000\u0170\u0171\u0005e\u0000\u0000\u0171\u0172\u0005e\u0000\u0000"+
+		"\u0172\u0173\u0005n\u0000\u0000\u0173\u0174\u0005_\u0000\u0000\u0174\u0175"+
+		"\u0005i\u0000\u0000\u0175\u0176\u0005d\u0000\u0000\u0176\u03ed\u0005s"+
+		"\u0000\u0000\u0177\u0178\u0005e\u0000\u0000\u0178\u0179\u0005n\u0000\u0000"+
+		"\u0179\u017a\u0005t\u0000\u0000\u017a\u017b\u0005_\u0000\u0000\u017b\u017c"+
+		"\u0005i\u0000\u0000\u017c\u017d\u0005s\u0000\u0000\u017d\u017e\u0005_"+
+		"\u0000\u0000\u017e\u017f\u0005b\u0000\u0000\u017f\u0180\u0005e\u0000\u0000"+
+		"\u0180\u0181\u0005t\u0000\u0000\u0181\u0182\u0005w\u0000\u0000\u0182\u0183"+
+		"\u0005e\u0000\u0000\u0183\u0184\u0005e\u0000\u0000\u0184\u0185\u0005n"+
+		"\u0000\u0000\u0185\u0186\u0005_\u0000\u0000\u0186\u0187\u0005g\u0000\u0000"+
+		"\u0187\u0188\u0005r\u0000\u0000\u0188\u0189\u0005o\u0000\u0000\u0189\u018a"+
+		"\u0005u\u0000\u0000\u018a\u018b\u0005p\u0000\u0000\u018b\u03ed\u0005s"+
+		"\u0000\u0000\u018c\u018d\u0005m\u0000\u0000\u018d\u018e\u0005d\u0000\u0000"+
+		"\u018e\u018f\u0005l\u0000\u0000\u018f\u0190\u0005_\u0000\u0000\u0190\u0191"+
+		"\u0005i\u0000\u0000\u0191\u03ed\u0005d\u0000\u0000\u0192\u0193\u0005m"+
+		"\u0000\u0000\u0193\u0194\u0005d\u0000\u0000\u0194\u0195\u0005l\u0000\u0000"+
+		"\u0195\u0196\u0005_\u0000\u0000\u0196\u0197\u0005n\u0000\u0000\u0197\u0198"+
+		"\u0005a\u0000\u0000\u0198\u0199\u0005m\u0000\u0000\u0199\u03ed\u0005e"+
+		"\u0000\u0000\u019a\u019b\u0005m\u0000\u0000\u019b\u019c\u0005d\u0000\u0000"+
+		"\u019c\u019d\u0005l\u0000\u0000\u019d\u019e\u0005_\u0000\u0000\u019e\u019f"+
+		"\u0005v\u0000\u0000\u019f\u01a0\u0005e\u0000\u0000\u01a0\u03ed\u0005r"+
+		"\u0000\u0000\u01a1\u01a2\u0005m\u0000\u0000\u01a2\u01a3\u0005d\u0000\u0000"+
+		"\u01a3\u01a4\u0005l\u0000\u0000\u01a4\u01a5\u0005_\u0000\u0000\u01a5\u01a6"+
+		"\u0005o\u0000\u0000\u01a6\u01a7\u0005r\u0000\u0000\u01a7\u01a8\u0005i"+
+		"\u0000\u0000\u01a8\u01a9\u0005g\u0000\u0000\u01a9\u01aa\u0005i\u0000\u0000"+
+		"\u01aa\u03ed\u0005n\u0000\u0000\u01ab\u01ac\u0005r\u0000\u0000\u01ac\u01ad"+
+		"\u0005e\u0000\u0000\u01ad\u01ae\u0005q\u0000\u0000\u01ae\u01af\u0005_"+
+		"\u0000\u0000\u01af\u01b0\u0005i\u0000\u0000\u01b0\u03ed\u0005d\u0000\u0000"+
+		"\u01b1\u01b2\u0005r\u0000\u0000\u01b2\u01b3\u0005e\u0000\u0000\u01b3\u01b4"+
+		"\u0005q\u0000\u0000\u01b4\u01b5\u0005_\u0000\u0000\u01b5\u01b6\u0005t"+
+		"\u0000\u0000\u01b6\u01b7\u0005e\u0000\u0000\u01b7\u01b8\u0005x\u0000\u0000"+
+		"\u01b8\u03ed\u0005t\u0000\u0000\u01b9\u01ba\u0005r\u0000\u0000\u01ba\u01bb"+
+		"\u0005e\u0000\u0000\u01bb\u01bc\u0005q\u0000\u0000\u01bc\u01bd\u0005_"+
+		"\u0000\u0000\u01bd\u01be\u0005t\u0000\u0000\u01be\u01bf\u0005s\u0000\u0000"+
+		"\u01bf\u01c0\u0005t\u0000\u0000\u01c0\u01c1\u0005a\u0000\u0000\u01c1\u01c2"+
+		"\u0005m\u0000\u0000\u01c2\u03ed\u0005p\u0000\u0000\u01c3\u01c4\u0005u"+
+		"\u0000\u0000\u01c4\u01c5\u0005s\u0000\u0000\u01c5\u01c6\u0005e\u0000\u0000"+
+		"\u01c6\u01c7\u0005r\u0000\u0000\u01c7\u01c8\u0005_\u0000\u0000\u01c8\u01c9"+
+		"\u0005i\u0000\u0000\u01c9\u03ed\u0005d\u0000\u0000\u01ca\u01cb\u0005t"+
+		"\u0000\u0000\u01cb\u01cc\u0005r\u0000\u0000\u01cc\u01cd\u0005i\u0000\u0000"+
+		"\u01cd\u03ed\u0005m\u0000\u0000\u01ce\u01cf\u0005r\u0000\u0000\u01cf\u01d0"+
+		"\u0005e\u0000\u0000\u01d0\u01d1\u0005g\u0000\u0000\u01d1\u01d2\u0005e"+
+		"\u0000\u0000\u01d2\u03ed\u0005x\u0000\u0000\u01d3\u01d4\u0005s\u0000\u0000"+
+		"\u01d4\u01d5\u0005t\u0000\u0000\u01d5\u01d6\u0005r\u0000\u0000\u01d6\u01d7"+
+		"\u0005i\u0000\u0000\u01d7\u03ed\u0005p\u0000\u0000\u01d8\u01d9\u0005u"+
+		"\u0000\u0000\u01d9\u01da\u0005p\u0000\u0000\u01da\u01db\u0005p\u0000\u0000"+
+		"\u01db\u01dc\u0005e\u0000\u0000\u01dc\u01dd\u0005r\u0000\u0000\u01dd\u01de"+
+		"\u0005c\u0000\u0000\u01de\u01df\u0005a\u0000\u0000\u01df\u01e0\u0005s"+
+		"\u0000\u0000\u01e0\u03ed\u0005e\u0000\u0000\u01e1\u01e2\u0005l\u0000\u0000"+
+		"\u01e2\u01e3\u0005o\u0000\u0000\u01e3\u01e4\u0005w\u0000\u0000\u01e4\u01e5"+
+		"\u0005e\u0000\u0000\u01e5\u01e6\u0005r\u0000\u0000\u01e6\u01e7\u0005c"+
+		"\u0000\u0000\u01e7\u01e8\u0005a\u0000\u0000\u01e8\u01e9\u0005s\u0000\u0000"+
+		"\u01e9\u03ed\u0005e\u0000\u0000\u01ea\u01eb\u0005i\u0000\u0000\u01eb\u01ec"+
+		"\u0005s\u0000\u0000\u01ec\u01ed\u0005_\u0000\u0000\u01ed\u01ee\u0005a"+
+		"\u0000\u0000\u01ee\u01ef\u0005l\u0000\u0000\u01ef\u01f0\u0005p\u0000\u0000"+
+		"\u01f0\u01f1\u0005h\u0000\u0000\u01f1\u03ed\u0005a\u0000\u0000\u01f2\u01f3"+
+		"\u0005i\u0000\u0000\u01f3\u01f4\u0005s\u0000\u0000\u01f4\u01f5\u0005_"+
+		"\u0000\u0000\u01f5\u01f6\u0005a\u0000\u0000\u01f6\u01f7\u0005l\u0000\u0000"+
+		"\u01f7\u01f8\u0005p\u0000\u0000\u01f8\u01f9\u0005h\u0000\u0000\u01f9\u01fa"+
+		"\u0005a\u0000\u0000\u01fa\u01fb\u0005n\u0000\u0000\u01fb\u01fc\u0005u"+
+		"\u0000\u0000\u01fc\u03ed\u0005m\u0000\u0000\u01fd\u01fe\u0005i\u0000\u0000"+
+		"\u01fe\u01ff\u0005s\u0000\u0000\u01ff\u0200\u0005_\u0000\u0000\u0200\u0201"+
+		"\u0005w\u0000\u0000\u0201\u0202\u0005h\u0000\u0000\u0202\u0203\u0005i"+
+		"\u0000\u0000\u0203\u0204\u0005t\u0000\u0000\u0204\u0205\u0005e\u0000\u0000"+
+		"\u0205\u0206\u0005s\u0000\u0000\u0206\u0207\u0005p\u0000\u0000\u0207\u0208"+
+		"\u0005a\u0000\u0000\u0208\u0209\u0005c\u0000\u0000\u0209\u03ed\u0005e"+
+		"\u0000\u0000\u020a\u020b\u0005i\u0000\u0000\u020b\u020c\u0005s\u0000\u0000"+
+		"\u020c\u020d\u0005_\u0000\u0000\u020d\u020e\u0005n\u0000\u0000\u020e\u020f"+
+		"\u0005u\u0000\u0000\u020f\u03ed\u0005m\u0000\u0000\u0210\u0211\u0005i"+
+		"\u0000\u0000\u0211\u0212\u0005s\u0000\u0000\u0212\u0213\u0005_\u0000\u0000"+
+		"\u0213\u0214\u0005n\u0000\u0000\u0214\u0215\u0005u\u0000\u0000\u0215\u0216"+
+		"\u0005m\u0000\u0000\u0216\u0217\u0005s\u0000\u0000\u0217\u0218\u0005p"+
+		"\u0000\u0000\u0218\u0219\u0005a\u0000\u0000\u0219\u021a\u0005c\u0000\u0000"+
+		"\u021a\u03ed\u0005e\u0000\u0000\u021b\u021c\u0005i\u0000\u0000\u021c\u021d"+
+		"\u0005s\u0000\u0000\u021d\u021e\u0005_\u0000\u0000\u021e\u021f\u0005a"+
+		"\u0000\u0000\u021f\u0220\u0005l\u0000\u0000\u0220\u0221\u0005p\u0000\u0000"+
+		"\u0221\u0222\u0005h\u0000\u0000\u0222\u0223\u0005a\u0000\u0000\u0223\u0224"+
+		"\u0005s\u0000\u0000\u0224\u0225\u0005p\u0000\u0000\u0225\u0226\u0005a"+
+		"\u0000\u0000\u0226\u0227\u0005c\u0000\u0000\u0227\u03ed\u0005e\u0000\u0000"+
+		"\u0228\u0229\u0005i\u0000\u0000\u0229\u022a\u0005s\u0000\u0000\u022a\u022b"+
+		"\u0005_\u0000\u0000\u022b\u022c\u0005a\u0000\u0000\u022c\u022d\u0005l"+
+		"\u0000\u0000\u022d\u022e\u0005p\u0000\u0000\u022e\u022f\u0005h\u0000\u0000"+
+		"\u022f\u0230\u0005a\u0000\u0000\u0230\u0231\u0005n\u0000\u0000\u0231\u0232"+
+		"\u0005u\u0000\u0000\u0232\u0233\u0005m\u0000\u0000\u0233\u0234\u0005s"+
+		"\u0000\u0000\u0234\u0235\u0005p\u0000\u0000\u0235\u0236\u0005a\u0000\u0000"+
+		"\u0236\u0237\u0005c\u0000\u0000\u0237\u03ed\u0005e\u0000\u0000\u0238\u0239"+
+		"\u0005s\u0000\u0000\u0239\u023a\u0005p\u0000\u0000\u023a\u023b\u0005l"+
+		"\u0000\u0000\u023b\u023c\u0005i\u0000\u0000\u023c\u03ed\u0005t\u0000\u0000"+
+		"\u023d\u023e\u0005s\u0000\u0000\u023e\u023f\u0005p\u0000\u0000\u023f\u0240"+
+		"\u0005l\u0000\u0000\u0240\u0241\u0005i\u0000\u0000\u0241\u0242\u0005t"+
+		"\u0000\u0000\u0242\u0243\u0005_\u0000\u0000\u0243\u0244\u0005t\u0000\u0000"+
+		"\u0244\u0245\u0005r\u0000\u0000\u0245\u0246\u0005i\u0000\u0000\u0246\u03ed"+
+		"\u0005m\u0000\u0000\u0247\u0248\u0005s\u0000\u0000\u0248\u0249\u0005t"+
+		"\u0000\u0000\u0249\u024a\u0005a\u0000\u0000\u024a\u024b\u0005r\u0000\u0000"+
+		"\u024b\u024c\u0005t\u0000\u0000\u024c\u024d\u0005s\u0000\u0000\u024d\u024e"+
+		"\u0005_\u0000\u0000\u024e\u024f\u0005w\u0000\u0000\u024f\u0250\u0005i"+
+		"\u0000\u0000\u0250\u0251\u0005t\u0000\u0000\u0251\u03ed\u0005h\u0000\u0000"+
+		"\u0252\u0253\u0005e\u0000\u0000\u0253\u0254\u0005n\u0000\u0000\u0254\u0255"+
+		"\u0005d\u0000\u0000\u0255\u0256\u0005s\u0000\u0000\u0256\u0257\u0005_"+
+		"\u0000\u0000\u0257\u0258\u0005w\u0000\u0000\u0258\u0259\u0005i\u0000\u0000"+
+		"\u0259\u025a\u0005t\u0000\u0000\u025a\u03ed\u0005h\u0000\u0000\u025b\u025c"+
+		"\u0005i\u0000\u0000\u025c\u025d\u0005n\u0000\u0000\u025d\u025e\u0005d"+
+		"\u0000\u0000\u025e\u025f\u0005e\u0000\u0000\u025f\u0260\u0005x\u0000\u0000"+
+		"\u0260\u0261\u0005_\u0000\u0000\u0261\u0262\u0005o\u0000\u0000\u0262\u03ed"+
+		"\u0005f\u0000\u0000\u0263\u0264\u0005c\u0000\u0000\u0264\u0265\u0005o"+
+		"\u0000\u0000\u0265\u0266\u0005n\u0000\u0000\u0266\u0267\u0005t\u0000\u0000"+
+		"\u0267\u0268\u0005a\u0000\u0000\u0268\u0269\u0005i\u0000\u0000\u0269\u026a"+
+		"\u0005n\u0000\u0000\u026a\u03ed\u0005s\u0000\u0000\u026b\u026c\u0005s"+
+		"\u0000\u0000\u026c\u026d\u0005u\u0000\u0000\u026d\u026e\u0005b\u0000\u0000"+
+		"\u026e\u026f\u0005s\u0000\u0000\u026f\u0270\u0005t\u0000\u0000\u0270\u03ed"+
+		"\u0005r\u0000\u0000\u0271\u0272\u0005r\u0000\u0000\u0272\u0273\u0005e"+
+		"\u0000\u0000\u0273\u0274\u0005p\u0000\u0000\u0274\u0275\u0005l\u0000\u0000"+
+		"\u0275\u0276\u0005a\u0000\u0000\u0276\u0277\u0005c\u0000\u0000\u0277\u03ed"+
+		"\u0005e\u0000\u0000\u0278\u0279\u0005a\u0000\u0000\u0279\u027a\u0005b"+
+		"\u0000\u0000\u027a\u03ed\u0005s\u0000\u0000\u027b\u027c\u0005c\u0000\u0000"+
+		"\u027c\u027d\u0005e\u0000\u0000\u027d\u027e\u0005i\u0000\u0000\u027e\u03ed"+
+		"\u0005l\u0000\u0000\u027f\u0280\u0005f\u0000\u0000\u0280\u0281\u0005l"+
+		"\u0000\u0000\u0281\u0282\u0005o\u0000\u0000\u0282\u0283\u0005o\u0000\u0000"+
+		"\u0283\u03ed\u0005r\u0000\u0000\u0284\u0285\u0005r\u0000\u0000\u0285\u0286"+
+		"\u0005i\u0000\u0000\u0286\u0287\u0005n\u0000\u0000\u0287\u03ed\u0005t"+
+		"\u0000\u0000\u0288\u0289\u0005r\u0000\u0000\u0289\u028a\u0005o\u0000\u0000"+
+		"\u028a\u028b\u0005u\u0000\u0000\u028b\u028c\u0005n\u0000\u0000\u028c\u03ed"+
+		"\u0005d\u0000\u0000\u028d\u028e\u0005s\u0000\u0000\u028e\u028f\u0005i"+
+		"\u0000\u0000\u028f\u0290\u0005g\u0000\u0000\u0290\u0291\u0005n\u0000\u0000"+
+		"\u0291\u0292\u0005u\u0000\u0000\u0292\u03ed\u0005m\u0000\u0000\u0293\u0294"+
+		"\u0005s\u0000\u0000\u0294\u0295\u0005q\u0000\u0000\u0295\u0296\u0005r"+
+		"\u0000\u0000\u0296\u03ed\u0005t\u0000\u0000\u0297\u0298\u0005c\u0000\u0000"+
+		"\u0298\u0299\u0005b\u0000\u0000\u0299\u029a\u0005r\u0000\u0000\u029a\u03ed"+
+		"\u0005t\u0000\u0000\u029b\u029c\u0005p\u0000\u0000\u029c\u03ed\u0005i"+
+		"\u0000\u0000\u029d\u029e\u0005t\u0000\u0000\u029e\u029f\u0005o\u0000\u0000"+
+		"\u029f\u02a0\u0005_\u0000\u0000\u02a0\u02a1\u0005d\u0000\u0000\u02a1\u02a2"+
+		"\u0005o\u0000\u0000\u02a2\u02a3\u0005u\u0000\u0000\u02a3\u02a4\u0005b"+
+		"\u0000\u0000\u02a4\u02a5\u0005l\u0000\u0000\u02a5\u03ed\u0005e\u0000\u0000"+
+		"\u02a6\u02a7\u0005t\u0000\u0000\u02a7\u02a8\u0005o\u0000\u0000\u02a8\u02a9"+
+		"\u0005_\u0000\u0000\u02a9\u02aa\u0005i\u0000\u0000\u02aa\u02ab\u0005n"+
+		"\u0000\u0000\u02ab\u03ed\u0005t\u0000\u0000\u02ac\u02ad\u0005e\u0000\u0000"+
+		"\u02ad\u02ae\u0005u\u0000\u0000\u02ae\u02af\u0005l\u0000\u0000\u02af\u02b0"+
+		"\u0005e\u0000\u0000\u02b0\u03ed\u0005r\u0000\u0000\u02b1\u02b2\u0005a"+
+		"\u0000\u0000\u02b2\u02b3\u0005c\u0000\u0000\u02b3\u02b4\u0005o\u0000\u0000"+
+		"\u02b4\u03ed\u0005s\u0000\u0000\u02b5\u02b6\u0005a\u0000\u0000\u02b6\u02b7"+
+		"\u0005s\u0000\u0000\u02b7\u02b8\u0005i\u0000\u0000\u02b8\u03ed\u0005n"+
+		"\u0000\u0000\u02b9\u02ba\u0005a\u0000\u0000\u02ba\u02bb\u0005t\u0000\u0000"+
+		"\u02bb\u02bc\u0005a\u0000\u0000\u02bc\u03ed\u0005n\u0000\u0000\u02bd\u02be"+
+		"\u0005c\u0000\u0000\u02be\u02bf\u0005o\u0000\u0000\u02bf\u03ed\u0005s"+
+		"\u0000\u0000\u02c0\u02c1\u0005s\u0000\u0000\u02c1\u02c2\u0005i\u0000\u0000"+
+		"\u02c2\u03ed\u0005n\u0000\u0000\u02c3\u02c4\u0005t\u0000\u0000\u02c4\u02c5"+
+		"\u0005a\u0000\u0000\u02c5\u03ed\u0005n\u0000\u0000\u02c6\u02c7\u0005c"+
+		"\u0000\u0000\u02c7\u02c8\u0005o\u0000\u0000\u02c8\u02c9\u0005s\u0000\u0000"+
+		"\u02c9\u03ed\u0005h\u0000\u0000\u02ca\u02cb\u0005s\u0000\u0000\u02cb\u02cc"+
+		"\u0005i\u0000\u0000\u02cc\u02cd\u0005n\u0000\u0000\u02cd\u03ed\u0005h"+
+		"\u0000\u0000\u02ce\u02cf\u0005t\u0000\u0000\u02cf\u02d0\u0005a\u0000\u0000"+
+		"\u02d0\u02d1\u0005n\u0000\u0000\u02d1\u03ed\u0005h\u0000\u0000\u02d2\u02d3"+
+		"\u0005a\u0000\u0000\u02d3\u02d4\u0005t\u0000\u0000\u02d4\u02d5\u0005a"+
+		"\u0000\u0000\u02d5\u02d6\u0005n\u0000\u0000\u02d6\u03ed\u00052\u0000\u0000"+
+		"\u02d7\u02d8\u0005d\u0000\u0000\u02d8\u02d9\u0005e\u0000\u0000\u02d9\u02da"+
+		"\u0005g\u0000\u0000\u02da\u02db\u0005r\u0000\u0000\u02db\u02dc\u0005e"+
+		"\u0000\u0000\u02dc\u02dd\u0005e\u0000\u0000\u02dd\u03ed\u0005s\u0000\u0000"+
+		"\u02de\u02df\u0005r\u0000\u0000\u02df\u02e0\u0005a\u0000\u0000\u02e0\u02e1"+
+		"\u0005d\u0000\u0000\u02e1\u02e2\u0005i\u0000\u0000\u02e2\u02e3\u0005a"+
+		"\u0000\u0000\u02e3\u02e4\u0005n\u0000\u0000\u02e4\u03ed\u0005s\u0000\u0000"+
+		"\u02e5\u02e6\u0005e\u0000\u0000\u02e6\u02e7\u0005x\u0000\u0000\u02e7\u03ed"+
+		"\u0005p\u0000\u0000\u02e8\u02e9\u0005e\u0000\u0000\u02e9\u02ea\u0005x"+
+		"\u0000\u0000\u02ea\u02eb\u0005p\u0000\u0000\u02eb\u02ec\u0005m\u0000\u0000"+
+		"\u02ec\u03ed\u00051\u0000\u0000\u02ed\u02ee\u0005h\u0000\u0000\u02ee\u02ef"+
+		"\u0005y\u0000\u0000\u02ef\u02f0\u0005p\u0000\u0000\u02f0\u02f1\u0005o"+
+		"\u0000\u0000\u02f1\u03ed\u0005t\u0000\u0000\u02f2\u02f3\u0005l\u0000\u0000"+
+		"\u02f3\u02f4\u0005o\u0000\u0000\u02f4\u03ed\u0005g\u0000\u0000\u02f5\u02f6"+
+		"\u0005l\u0000\u0000\u02f6\u02f7\u0005o\u0000\u0000\u02f7\u02f8\u0005g"+
+		"\u0000\u0000\u02f8\u02f9\u00051\u0000\u0000\u02f9\u03ed\u00050\u0000\u0000"+
+		"\u02fa\u02fb\u0005l\u0000\u0000\u02fb\u02fc\u0005o\u0000\u0000\u02fc\u02fd"+
+		"\u0005g\u0000\u0000\u02fd\u02fe\u00051\u0000\u0000\u02fe\u03ed\u0005p"+
+		"\u0000\u0000\u02ff\u0300\u0005p\u0000\u0000\u0300\u0301\u0005o\u0000\u0000"+
+		"\u0301\u03ed\u0005w\u0000\u0000\u0302\u0303\u0005r\u0000\u0000\u0303\u0304"+
+		"\u0005a\u0000\u0000\u0304\u0305\u0005n\u0000\u0000\u0305\u03ed\u0005d"+
+		"\u0000\u0000\u0306\u0307\u0005s\u0000\u0000\u0307\u0308\u0005q\u0000\u0000"+
+		"\u0308\u0309\u0005u\u0000\u0000\u0309\u030a\u0005a\u0000\u0000\u030a\u030b"+
+		"\u0005r\u0000\u0000\u030b\u03ed\u0005e\u0000\u0000\u030c\u030d\u0005l"+
+		"\u0000\u0000\u030d\u030e\u0005i\u0000\u0000\u030e\u030f\u0005s\u0000\u0000"+
+		"\u030f\u03ed\u0005t\u0000\u0000\u0310\u0311\u0005g\u0000\u0000\u0311\u0312"+
+		"\u0005e\u0000\u0000\u0312\u03ed\u0005t\u0000\u0000\u0313\u0314\u0005h"+
+		"\u0000\u0000\u0314\u0315\u0005a\u0000\u0000\u0315\u03ed\u0005s\u0000\u0000"+
+		"\u0316\u0317\u0005h\u0000\u0000\u0317\u0318\u0005a\u0000\u0000\u0318\u0319"+
+		"\u0005s\u0000\u0000\u0319\u031a\u0005_\u0000\u0000\u031a\u031b\u0005a"+
+		"\u0000\u0000\u031b\u031c\u0005n\u0000\u0000\u031c\u03ed\u0005y\u0000\u0000"+
+		"\u031d\u031e\u0005h\u0000\u0000\u031e\u031f\u0005a\u0000\u0000\u031f\u0320"+
+		"\u0005s\u0000\u0000\u0320\u0321\u0005_\u0000\u0000\u0321\u0322\u0005a"+
+		"\u0000\u0000\u0322\u0323\u0005l\u0000\u0000\u0323\u03ed\u0005l\u0000\u0000"+
+		"\u0324\u0325\u0005f\u0000\u0000\u0325\u0326\u0005i\u0000\u0000\u0326\u0327"+
+		"\u0005r\u0000\u0000\u0327\u0328\u0005s\u0000\u0000\u0328\u03ed\u0005t"+
+		"\u0000\u0000\u0329\u032a\u0005l\u0000\u0000\u032a\u032b\u0005a\u0000\u0000"+
+		"\u032b\u032c\u0005s\u0000\u0000\u032c\u03ed\u0005t\u0000\u0000\u032d\u032e"+
+		"\u0005k\u0000\u0000\u032e\u032f\u0005e\u0000\u0000\u032f\u0330\u0005y"+
+		"\u0000\u0000\u0330\u03ed\u0005s\u0000\u0000\u0331\u0332\u0005v\u0000\u0000"+
+		"\u0332\u0333\u0005a\u0000\u0000\u0333\u0334\u0005l\u0000\u0000\u0334\u0335"+
+		"\u0005u\u0000\u0000\u0335\u0336\u0005e\u0000\u0000\u0336\u03ed\u0005s"+
+		"\u0000\u0000\u0337\u0338\u0005l\u0000\u0000\u0338\u0339\u0005e\u0000\u0000"+
+		"\u0339\u033a\u0005n\u0000\u0000\u033a\u033b\u0005g\u0000\u0000\u033b\u033c"+
+		"\u0005t\u0000\u0000\u033c\u03ed\u0005h\u0000\u0000\u033d\u033e\u0005c"+
+		"\u0000\u0000\u033e\u033f\u0005o\u0000\u0000\u033f\u0340\u0005u\u0000\u0000"+
+		"\u0340\u0341\u0005n\u0000\u0000\u0341\u03ed\u0005t\u0000\u0000\u0342\u0343"+
+		"\u0005s\u0000\u0000\u0343\u0344\u0005i\u0000\u0000\u0344\u0345\u0005z"+
+		"\u0000\u0000\u0345\u03ed\u0005e\u0000\u0000\u0346\u0347\u0005s\u0000\u0000"+
+		"\u0347\u0348\u0005o\u0000\u0000\u0348\u0349\u0005r\u0000\u0000\u0349\u03ed"+
+		"\u0005t\u0000\u0000\u034a\u034b\u0005r\u0000\u0000\u034b\u034c\u0005e"+
+		"\u0000\u0000\u034c\u034d\u0005v\u0000\u0000\u034d\u034e\u0005e\u0000\u0000"+
+		"\u034e\u034f\u0005r\u0000\u0000\u034f\u0350\u0005s\u0000\u0000\u0350\u03ed"+
+		"\u0005e\u0000\u0000\u0351\u0352\u0005i\u0000\u0000\u0352\u0353\u0005s"+
+		"\u0000\u0000\u0353\u0354\u0005_\u0000\u0000\u0354\u0355\u0005e\u0000\u0000"+
+		"\u0355\u0356\u0005m\u0000\u0000\u0356\u0357\u0005p\u0000\u0000\u0357\u0358"+
+		"\u0005t\u0000\u0000\u0358\u03ed\u0005y\u0000\u0000\u0359\u035a\u0005n"+
+		"\u0000\u0000\u035a\u035b\u0005o\u0000\u0000\u035b\u035c\u0005n\u0000\u0000"+
+		"\u035c\u035d\u0005_\u0000\u0000\u035d\u035e\u0005e\u0000\u0000\u035e\u035f"+
+		"\u0005m\u0000\u0000\u035f\u0360\u0005p\u0000\u0000\u0360\u0361\u0005t"+
+		"\u0000\u0000\u0361\u03ed\u0005y\u0000\u0000\u0362\u0363\u0005d\u0000\u0000"+
+		"\u0363\u0364\u0005i\u0000\u0000\u0364\u0365\u0005s\u0000\u0000\u0365\u0366"+
+		"\u0005t\u0000\u0000\u0366\u0367\u0005i\u0000\u0000\u0367\u0368\u0005n"+
+		"\u0000\u0000\u0368\u0369\u0005c\u0000\u0000\u0369\u03ed\u0005t\u0000\u0000"+
+		"\u036a\u036b\u0005c\u0000\u0000\u036b\u036c\u0005o\u0000\u0000\u036c\u036d"+
+		"\u0005n\u0000\u0000\u036d\u036e\u0005c\u0000\u0000\u036e\u036f\u0005a"+
+		"\u0000\u0000\u036f\u03ed\u0005t\u0000\u0000\u0370\u0371\u0005t\u0000\u0000"+
+		"\u0371\u0372\u0005o\u0000\u0000\u0372\u0373\u0005_\u0000\u0000\u0373\u0374"+
+		"\u0005s\u0000\u0000\u0374\u0375\u0005t\u0000\u0000\u0375\u0376\u0005r"+
+		"\u0000\u0000\u0376\u0377\u0005i\u0000\u0000\u0377\u0378\u0005n\u0000\u0000"+
+		"\u0378\u03ed\u0005g\u0000\u0000\u0379\u037a\u0005m\u0000\u0000\u037a\u037b"+
+		"\u0005a\u0000\u0000\u037b\u03ed\u0005x\u0000\u0000\u037c\u037d\u0005m"+
+		"\u0000\u0000\u037d\u037e\u0005i\u0000\u0000\u037e\u03ed\u0005n\u0000\u0000"+
+		"\u037f\u0380\u0005a\u0000\u0000\u0380\u0381\u0005v\u0000\u0000\u0381\u03ed"+
+		"\u0005g\u0000\u0000\u0382\u0383\u0005s\u0000\u0000\u0383\u0384\u0005t"+
+		"\u0000\u0000\u0384\u0385\u0005d\u0000\u0000\u0385\u0386\u0005e\u0000\u0000"+
+		"\u0386\u03ed\u0005v\u0000\u0000\u0387\u0388\u0005y\u0000\u0000\u0388\u0389"+
+		"\u0005e\u0000\u0000\u0389\u038a\u0005a\u0000\u0000\u038a\u03ed\u0005r"+
+		"\u0000\u0000\u038b\u038c\u0005m\u0000\u0000\u038c\u038d\u0005o\u0000\u0000"+
+		"\u038d\u038e\u0005n\u0000\u0000\u038e\u038f\u0005t\u0000\u0000\u038f\u03ed"+
+		"\u0005h\u0000\u0000\u0390\u0391\u0005d\u0000\u0000\u0391\u0392\u0005a"+
+		"\u0000\u0000\u0392\u0393\u0005y\u0000\u0000\u0393\u0394\u0005_\u0000\u0000"+
+		"\u0394\u0395\u0005o\u0000\u0000\u0395\u0396\u0005f\u0000\u0000\u0396\u0397"+
+		"\u0005_\u0000\u0000\u0397\u0398\u0005m\u0000\u0000\u0398\u0399\u0005o"+
+		"\u0000\u0000\u0399\u039a\u0005n\u0000\u0000\u039a\u039b\u0005t\u0000\u0000"+
+		"\u039b\u03ed\u0005h\u0000\u0000\u039c\u039d\u0005d\u0000\u0000\u039d\u039e"+
+		"\u0005a\u0000\u0000\u039e\u039f\u0005y\u0000\u0000\u039f\u03a0\u0005_"+
+		"\u0000\u0000\u03a0\u03a1\u0005o\u0000\u0000\u03a1\u03a2\u0005f\u0000\u0000"+
+		"\u03a2\u03a3\u0005_\u0000\u0000\u03a3\u03a4\u0005w\u0000\u0000\u03a4\u03a5"+
+		"\u0005e\u0000\u0000\u03a5\u03a6\u0005e\u0000\u0000\u03a6\u03ed\u0005k"+
+		"\u0000\u0000\u03a7\u03a8\u0005d\u0000\u0000\u03a8\u03a9\u0005a\u0000\u0000"+
+		"\u03a9\u03aa\u0005y\u0000\u0000\u03aa\u03ab\u0005_\u0000\u0000\u03ab\u03ac"+
+		"\u0005o\u0000\u0000\u03ac\u03ad\u0005f\u0000\u0000\u03ad\u03ae\u0005_"+
+		"\u0000\u0000\u03ae\u03af\u0005y\u0000\u0000\u03af\u03b0\u0005e\u0000\u0000"+
+		"\u03b0\u03b1\u0005a\u0000\u0000\u03b1\u03ed\u0005r\u0000\u0000\u03b2\u03b3"+
+		"\u0005h\u0000\u0000\u03b3\u03b4\u0005o\u0000\u0000\u03b4\u03b5\u0005u"+
+		"\u0000\u0000\u03b5\u03ed\u0005r\u0000\u0000\u03b6\u03b7\u0005m\u0000\u0000"+
+		"\u03b7\u03b8\u0005i\u0000\u0000\u03b8\u03b9\u0005n\u0000\u0000\u03b9\u03ba"+
+		"\u0005u\u0000\u0000\u03ba\u03bb\u0005t\u0000\u0000\u03bb\u03ed\u0005e"+
+		"\u0000\u0000\u03bc\u03bd\u0005s\u0000\u0000\u03bd\u03be\u0005e\u0000\u0000"+
+		"\u03be\u03bf\u0005c\u0000\u0000\u03bf\u03c0\u0005o\u0000\u0000\u03c0\u03c1"+
+		"\u0005n\u0000\u0000\u03c1\u03ed\u0005d\u0000\u0000\u03c2\u03c3\u0005w"+
+		"\u0000\u0000\u03c3\u03c4\u0005e\u0000\u0000\u03c4\u03c5\u0005e\u0000\u0000"+
+		"\u03c5\u03c6\u0005k\u0000\u0000\u03c6\u03c7\u0005_\u0000\u0000\u03c7\u03c8"+
+		"\u0005o\u0000\u0000\u03c8\u03c9\u0005f\u0000\u0000\u03c9\u03ca\u0005_"+
+		"\u0000\u0000\u03ca\u03cb\u0005m\u0000\u0000\u03cb\u03cc\u0005o\u0000\u0000"+
+		"\u03cc\u03cd\u0005n\u0000\u0000\u03cd\u03ce\u0005t\u0000\u0000\u03ce\u03ed"+
+		"\u0005h\u0000\u0000\u03cf\u03d0\u0005w\u0000\u0000\u03d0\u03d1\u0005e"+
+		"\u0000\u0000\u03d1\u03d2\u0005e\u0000\u0000\u03d2\u03d3\u0005k\u0000\u0000"+
+		"\u03d3\u03d4\u0005_\u0000\u0000\u03d4\u03d5\u0005o\u0000\u0000\u03d5\u03d6"+
+		"\u0005f\u0000\u0000\u03d6\u03d7\u0005_\u0000\u0000\u03d7\u03d8\u0005y"+
+		"\u0000\u0000\u03d8\u03d9\u0005e\u0000\u0000\u03d9\u03da\u0005a\u0000\u0000"+
+		"\u03da\u03ed\u0005r\u0000\u0000\u03db\u03dc\u0005q\u0000\u0000\u03dc\u03dd"+
+		"\u0005u\u0000\u0000\u03dd\u03de\u0005a\u0000\u0000\u03de\u03df\u0005r"+
+		"\u0000\u0000\u03df\u03e0\u0005t\u0000\u0000\u03e0\u03e1\u0005e\u0000\u0000"+
+		"\u03e1\u03ed\u0005r\u0000\u0000\u03e2\u03e3\u0005n\u0000\u0000\u03e3\u03e4"+
+		"\u0005o\u0000\u0000\u03e4\u03ed\u0005w\u0000\u0000\u03e5\u03e6\u0005o"+
+		"\u0000\u0000\u03e6\u03e7\u0005r\u0000\u0000\u03e7\u03e8\u0005_\u0000\u0000"+
+		"\u03e8\u03e9\u0005e\u0000\u0000\u03e9\u03ea\u0005l\u0000\u0000\u03ea\u03eb"+
+		"\u0005s\u0000\u0000\u03eb\u03ed\u0005e\u0000\u0000\u03ecm\u0001\u0000"+
+		"\u0000\u0000\u03ecu\u0001\u0000\u0000\u0000\u03ec}\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0088\u0001\u0000\u0000\u0000\u03ec\u0090\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0098\u0001\u0000\u0000\u0000\u03ec\u00a1\u0001\u0000\u0000\u0000"+
+		"\u03ec\u00aa\u0001\u0000\u0000\u0000\u03ec\u00ae\u0001\u0000\u0000\u0000"+
+		"\u03ec\u00b0\u0001\u0000\u0000\u0000\u03ec\u00b8\u0001\u0000\u0000\u0000"+
+		"\u03ec\u00c1\u0001\u0000\u0000\u0000\u03ec\u00c9\u0001\u0000\u0000\u0000"+
+		"\u03ec\u00d3\u0001\u0000\u0000\u0000\u03ec\u00dc\u0001\u0000\u0000\u0000"+
+		"\u03ec\u00e3\u0001\u0000\u0000\u0000\u03ec\u00f1\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0102\u0001\u0000\u0000\u0000\u03ec\u010a\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0115\u0001\u0000\u0000\u0000\u03ec\u0121\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0131\u0001\u0000\u0000\u0000\u03ec\u0144\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0153\u0001\u0000\u0000\u0000\u03ec\u0165\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0177\u0001\u0000\u0000\u0000\u03ec\u018c\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0192\u0001\u0000\u0000\u0000\u03ec\u019a\u0001\u0000\u0000\u0000"+
+		"\u03ec\u01a1\u0001\u0000\u0000\u0000\u03ec\u01ab\u0001\u0000\u0000\u0000"+
+		"\u03ec\u01b1\u0001\u0000\u0000\u0000\u03ec\u01b9\u0001\u0000\u0000\u0000"+
+		"\u03ec\u01c3\u0001\u0000\u0000\u0000\u03ec\u01ca\u0001\u0000\u0000\u0000"+
+		"\u03ec\u01ce\u0001\u0000\u0000\u0000\u03ec\u01d3\u0001\u0000\u0000\u0000"+
+		"\u03ec\u01d8\u0001\u0000\u0000\u0000\u03ec\u01e1\u0001\u0000\u0000\u0000"+
+		"\u03ec\u01ea\u0001\u0000\u0000\u0000\u03ec\u01f2\u0001\u0000\u0000\u0000"+
+		"\u03ec\u01fd\u0001\u0000\u0000\u0000\u03ec\u020a\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0210\u0001\u0000\u0000\u0000\u03ec\u021b\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0228\u0001\u0000\u0000\u0000\u03ec\u0238\u0001\u0000\u0000\u0000"+
+		"\u03ec\u023d\u0001\u0000\u0000\u0000\u03ec\u0247\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0252\u0001\u0000\u0000\u0000\u03ec\u025b\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0263\u0001\u0000\u0000\u0000\u03ec\u026b\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0271\u0001\u0000\u0000\u0000\u03ec\u0278\u0001\u0000\u0000\u0000"+
+		"\u03ec\u027b\u0001\u0000\u0000\u0000\u03ec\u027f\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0284\u0001\u0000\u0000\u0000\u03ec\u0288\u0001\u0000\u0000\u0000"+
+		"\u03ec\u028d\u0001\u0000\u0000\u0000\u03ec\u0293\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0297\u0001\u0000\u0000\u0000\u03ec\u029b\u0001\u0000\u0000\u0000"+
+		"\u03ec\u029d\u0001\u0000\u0000\u0000\u03ec\u02a6\u0001\u0000\u0000\u0000"+
+		"\u03ec\u02ac\u0001\u0000\u0000\u0000\u03ec\u02b1\u0001\u0000\u0000\u0000"+
+		"\u03ec\u02b5\u0001\u0000\u0000\u0000\u03ec\u02b9\u0001\u0000\u0000\u0000"+
+		"\u03ec\u02bd\u0001\u0000\u0000\u0000\u03ec\u02c0\u0001\u0000\u0000\u0000"+
+		"\u03ec\u02c3\u0001\u0000\u0000\u0000\u03ec\u02c6\u0001\u0000\u0000\u0000"+
+		"\u03ec\u02ca\u0001\u0000\u0000\u0000\u03ec\u02ce\u0001\u0000\u0000\u0000"+
+		"\u03ec\u02d2\u0001\u0000\u0000\u0000\u03ec\u02d7\u0001\u0000\u0000\u0000"+
+		"\u03ec\u02de\u0001\u0000\u0000\u0000\u03ec\u02e5\u0001\u0000\u0000\u0000"+
+		"\u03ec\u02e8\u0001\u0000\u0000\u0000\u03ec\u02ed\u0001\u0000\u0000\u0000"+
+		"\u03ec\u02f2\u0001\u0000\u0000\u0000\u03ec\u02f5\u0001\u0000\u0000\u0000"+
+		"\u03ec\u02fa\u0001\u0000\u0000\u0000\u03ec\u02ff\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0302\u0001\u0000\u0000\u0000\u03ec\u0306\u0001\u0000\u0000\u0000"+
+		"\u03ec\u030c\u0001\u0000\u0000\u0000\u03ec\u0310\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0313\u0001\u0000\u0000\u0000\u03ec\u0316\u0001\u0000\u0000\u0000"+
+		"\u03ec\u031d\u0001\u0000\u0000\u0000\u03ec\u0324\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0329\u0001\u0000\u0000\u0000\u03ec\u032d\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0331\u0001\u0000\u0000\u0000\u03ec\u0337\u0001\u0000\u0000\u0000"+
+		"\u03ec\u033d\u0001\u0000\u0000\u0000\u03ec\u0342\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0346\u0001\u0000\u0000\u0000\u03ec\u034a\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0351\u0001\u0000\u0000\u0000\u03ec\u0359\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0362\u0001\u0000\u0000\u0000\u03ec\u036a\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0370\u0001\u0000\u0000\u0000\u03ec\u0379\u0001\u0000\u0000\u0000"+
+		"\u03ec\u037c\u0001\u0000\u0000\u0000\u03ec\u037f\u0001\u0000\u0000\u0000"+
+		"\u03ec\u0382\u0001\u0000\u0000\u0000\u03ec\u0387\u0001\u0000\u0000\u0000"+
+		"\u03ec\u038b\u0001\u0000\u0000\u0000\u03ec\u0390\u0001\u0000\u0000\u0000"+
+		"\u03ec\u039c\u0001\u0000\u0000\u0000\u03ec\u03a7\u0001\u0000\u0000\u0000"+
+		"\u03ec\u03b2\u0001\u0000\u0000\u0000\u03ec\u03b6\u0001\u0000\u0000\u0000"+
+		"\u03ec\u03bc\u0001\u0000\u0000\u0000\u03ec\u03c2\u0001\u0000\u0000\u0000"+
+		"\u03ec\u03cf\u0001\u0000\u0000\u0000\u03ec\u03db\u0001\u0000\u0000\u0000"+
+		"\u03ec\u03e2\u0001\u0000\u0000\u0000\u03ec\u03e5\u0001\u0000\u0000\u0000"+
+		"\u03ed\u0002\u0001\u0000\u0000\u0000\u03ee\u03ef\u0005i\u0000\u0000\u03ef"+
+		"\u03f0\u0005m\u0000\u0000\u03f0\u03f1\u0005p\u0000\u0000\u03f1\u03f2\u0005"+
+		"o\u0000\u0000\u03f2\u03f3\u0005r\u0000\u0000\u03f3\u03f4\u0005t\u0000"+
+		"\u0000\u03f4\u0004\u0001\u0000\u0000\u0000\u03f5\u03f6\u0005i\u0000\u0000"+
+		"\u03f6\u03f7\u0005n\u0000\u0000\u03f7\u03f8\u0005t\u0000\u0000\u03f8\u03f9"+
+		"\u0005e\u0000\u0000\u03f9\u03fa\u0005n\u0000\u0000\u03fa\u03fb\u0005t"+
+		"\u0000\u0000\u03fb\u0006\u0001\u0000\u0000\u0000\u03fc\u03fd\u0005o\u0000"+
+		"\u0000\u03fd\u03fe\u0005p\u0000\u0000\u03fe\u03ff\u0005t\u0000\u0000\u03ff"+
+		"\u0400\u0005i\u0000\u0000\u0400\u0401\u0005o\u0000\u0000\u0401\u0402\u0005"+
+		"n\u0000\u0000\u0402\u0403\u0005s\u0000\u0000\u0403\b\u0001\u0000\u0000"+
+		"\u0000\u0404\u0405\u0005f\u0000\u0000\u0405\u0406\u0005l\u0000\u0000\u0406"+
+		"\u0407\u0005o\u0000\u0000\u0407\u0408\u0005w\u0000\u0000\u0408\n\u0001"+
+		"\u0000\u0000\u0000\u0409\u040a\u0005m\u0000\u0000\u040a\u040b\u0005e\u0000"+
+		"\u0000\u040b\u040c\u0005t\u0000\u0000\u040c\u040d\u0005a\u0000\u0000\u040d"+
+		"\f\u0001\u0000\u0000\u0000\u040e\u040f\u0005t\u0000\u0000\u040f\u0410"+
+		"\u0005e\u0000\u0000\u0410\u0411\u0005r\u0000\u0000\u0411\u0412\u0005m"+
+		"\u0000\u0000\u0412\u000e\u0001\u0000\u0000\u0000\u0413\u0414\u0005f\u0000"+
+		"\u0000\u0414\u0415\u0005r\u0000\u0000\u0415\u0416\u0005a\u0000\u0000\u0416"+
+		"\u0417\u0005g\u0000\u0000\u0417\u0418\u0005m\u0000\u0000\u0418\u0419\u0005"+
+		"e\u0000\u0000\u0419\u041a\u0005n\u0000\u0000\u041a\u041b\u0005t\u0000"+
+		"\u0000\u041b\u0010\u0001\u0000\u0000\u0000\u041c\u0422\u00035\u001a\u0000"+
+		"\u041d\u0421\b\u0000\u0000\u0000\u041e\u041f\u0005\\\u0000\u0000\u041f"+
+		"\u0421\u0005\'\u0000\u0000\u0420\u041d\u0001\u0000\u0000\u0000\u0420\u041e"+
+		"\u0001\u0000\u0000\u0000\u0421\u0424\u0001\u0000\u0000\u0000\u0422\u0420"+
+		"\u0001\u0000\u0000\u0000\u0422\u0423\u0001\u0000\u0000\u0000\u0423\u0425"+
+		"\u0001\u0000\u0000\u0000\u0424\u0422\u0001\u0000\u0000\u0000\u0425\u0426"+
+		"\u00035\u001a\u0000\u0426\u0012\u0001\u0000\u0000\u0000\u0427\u042d\u0003"+
+		"7\u001b\u0000\u0428\u042c\b\u0001\u0000\u0000\u0429\u042a\u0005\\\u0000"+
+		"\u0000\u042a\u042c\u0005\"\u0000\u0000\u042b\u0428\u0001\u0000\u0000\u0000"+
+		"\u042b\u0429\u0001\u0000\u0000\u0000\u042c\u042f\u0001\u0000\u0000\u0000"+
+		"\u042d\u042b\u0001\u0000\u0000\u0000\u042d\u042e\u0001\u0000\u0000\u0000"+
+		"\u042e\u0430\u0001\u0000\u0000\u0000\u042f\u042d\u0001\u0000\u0000\u0000"+
+		"\u0430\u0431\u00037\u001b\u0000\u0431\u0014\u0001\u0000\u0000\u0000\u0432"+
+		"\u0433\u0005t\u0000\u0000\u0433\u0434\u0005r\u0000\u0000\u0434\u0435\u0005"+
+		"u\u0000\u0000\u0435\u043c\u0005e\u0000\u0000\u0436\u0437\u0005f\u0000"+
+		"\u0000\u0437\u0438\u0005a\u0000\u0000\u0438\u0439\u0005l\u0000\u0000\u0439"+
+		"\u043a\u0005s\u0000\u0000\u043a\u043c\u0005e\u0000\u0000\u043b\u0432\u0001"+
+		"\u0000\u0000\u0000\u043b\u0436\u0001\u0000\u0000\u0000\u043c\u0016\u0001"+
+		"\u0000\u0000\u0000\u043d\u043e\u0005n\u0000\u0000\u043e\u043f\u0005u\u0000"+
+		"\u0000\u043f\u0440\u0005l\u0000\u0000\u0440\u0441\u0005l\u0000\u0000\u0441"+
+		"\u0018\u0001\u0000\u0000\u0000\u0442\u0443\u0005=\u0000\u0000\u0443\u0444"+
+		"\u0005=\u0000\u0000\u0444\u001a\u0001\u0000\u0000\u0000\u0445\u0446\u0005"+
+		"!\u0000\u0000\u0446\u0447\u0005=\u0000\u0000\u0447\u001c\u0001\u0000\u0000"+
+		"\u0000\u0448\u0449\u0005>\u0000\u0000\u0449\u044a\u0005=\u0000\u0000\u044a"+
+		"\u001e\u0001\u0000\u0000\u0000\u044b\u044c\u0005<\u0000\u0000\u044c\u044d"+
+		"\u0005=\u0000\u0000\u044d \u0001\u0000\u0000\u0000\u044e\u044f\u0005>"+
+		"\u0000\u0000\u044f\"\u0001\u0000\u0000\u0000\u0450\u0451\u0005<\u0000"+
+		"\u0000\u0451$\u0001\u0000\u0000\u0000\u0452\u0453\u0005&\u0000\u0000\u0453"+
+		"\u0454\u0005&\u0000\u0000\u0454&\u0001\u0000\u0000\u0000\u0455\u0456\u0005"+
+		"|\u0000\u0000\u0456\u0457\u0005|\u0000\u0000\u0457(\u0001\u0000\u0000"+
+		"\u0000\u0458\u0459\u0005|\u0000\u0000\u0459*\u0001\u0000\u0000\u0000\u045a"+
+		"\u045b\u0005!\u0000\u0000\u045b,\u0001\u0000\u0000\u0000\u045c\u045d\u0005"+
+		"(\u0000\u0000\u045d.\u0001\u0000\u0000\u0000\u045e\u045f\u0005)\u0000"+
+		"\u0000\u045f0\u0001\u0000\u0000\u0000\u0460\u0461\u0005{\u0000\u0000\u0461"+
+		"2\u0001\u0000\u0000\u0000\u0462\u0463\u0005}\u0000\u0000\u04634\u0001"+
+		"\u0000\u0000\u0000\u0464\u0465\u0005\'\u0000\u0000\u04656\u0001\u0000"+
+		"\u0000\u0000\u0466\u0467\u0005\"\u0000\u0000\u04678\u0001\u0000\u0000"+
+		"\u0000\u0468\u0469\u0005~\u0000\u0000\u0469:\u0001\u0000\u0000\u0000\u046a"+
+		"\u046b\u0005[\u0000\u0000\u046b<\u0001\u0000\u0000\u0000\u046c\u046d\u0005"+
+		"]\u0000\u0000\u046d>\u0001\u0000\u0000\u0000\u046e\u046f\u0005#\u0000"+
+		"\u0000\u046f@\u0001\u0000\u0000\u0000\u0470\u0471\u0005,\u0000\u0000\u0471"+
+		"B\u0001\u0000\u0000\u0000\u0472\u0473\u0005:\u0000\u0000\u0473D\u0001"+
+		"\u0000\u0000\u0000\u0474\u0475\u0005-\u0000\u0000\u0475F\u0001\u0000\u0000"+
+		"\u0000\u0476\u0477\u0005.\u0000\u0000\u0477H\u0001\u0000\u0000\u0000\u0478"+
+		"\u0479\u0005_\u0000\u0000\u0479J\u0001\u0000\u0000\u0000\u047a\u047b\u0005"+
+		"=\u0000\u0000\u047bL\u0001\u0000\u0000\u0000\u047c\u047d\u0005+\u0000"+
+		"\u0000\u047dN\u0001\u0000\u0000\u0000\u047e\u047f\u0005?\u0000\u0000\u047f"+
+		"P\u0001\u0000\u0000\u0000\u0480\u0481\u0005*\u0000\u0000\u0481R\u0001"+
+		"\u0000\u0000\u0000\u0482\u0483\u0005/\u0000\u0000\u0483T\u0001\u0000\u0000"+
+		"\u0000\u0484\u0485\u0005%\u0000\u0000\u0485V\u0001\u0000\u0000\u0000\u0486"+
+		"\u0487\u0005@\u0000\u0000\u0487X\u0001\u0000\u0000\u0000\u0488\u0489\u0005"+
+		"$\u0000\u0000\u0489Z\u0001\u0000\u0000\u0000\u048a\u0493\u00050\u0000"+
+		"\u0000\u048b\u048f\u0007\u0002\u0000\u0000\u048c\u048e\u0007\u0003\u0000"+
+		"\u0000\u048d\u048c\u0001\u0000\u0000\u0000\u048e\u0491\u0001\u0000\u0000"+
+		"\u0000\u048f\u048d\u0001\u0000\u0000\u0000\u048f\u0490\u0001\u0000\u0000"+
+		"\u0000\u0490\u0493\u0001\u0000\u0000\u0000\u0491\u048f\u0001\u0000\u0000"+
+		"\u0000\u0492\u048a\u0001\u0000\u0000\u0000\u0492\u048b\u0001\u0000\u0000"+
+		"\u0000\u0493\\\u0001\u0000\u0000\u0000\u0494\u0496\u0003G#\u0000\u0495"+
+		"\u0497\u0007\u0004\u0000\u0000\u0496\u0495\u0001\u0000\u0000\u0000\u0497"+
+		"\u0498\u0001\u0000\u0000\u0000\u0498\u0496\u0001\u0000\u0000\u0000\u0498"+
+		"\u0499\u0001\u0000\u0000\u0000\u0499^\u0001\u0000\u0000\u0000\u049a\u049c"+
+		"\u0007\u0005\u0000\u0000\u049b\u049d\u0007\u0006\u0000\u0000\u049c\u049b"+
+		"\u0001\u0000\u0000\u0000\u049c\u049d\u0001\u0000\u0000\u0000\u049d\u049e"+
+		"\u0001\u0000\u0000\u0000\u049e\u049f\u0003[-\u0000\u049f`\u0001\u0000"+
+		"\u0000\u0000\u04a0\u04a4\b\u0007\u0000\u0000\u04a1\u04a2\u0007\b\u0000"+
+		"\u0000\u04a2\u04a4\u0007\t\u0000\u0000\u04a3\u04a0\u0001\u0000\u0000\u0000"+
+		"\u04a3\u04a1\u0001\u0000\u0000\u0000\u04a4b\u0001\u0000\u0000\u0000\u04a5"+
+		"\u04a6\u0007\n\u0000\u0000\u04a6d\u0001\u0000\u0000\u0000\u04a7\u04ac"+
+		"\u0003a0\u0000\u04a8\u04ac\u0003I$\u0000\u04a9\u04ac\u0003c1\u0000\u04aa"+
+		"\u04ac\u0003Y,\u0000\u04ab\u04a7\u0001\u0000\u0000\u0000\u04ab\u04a8\u0001"+
+		"\u0000\u0000\u0000\u04ab\u04a9\u0001\u0000\u0000\u0000\u04ab\u04aa\u0001"+
+		"\u0000\u0000\u0000\u04ac\u04ad\u0001\u0000\u0000\u0000\u04ad\u04ab\u0001"+
+		"\u0000\u0000\u0000\u04ad\u04ae\u0001\u0000\u0000\u0000\u04ae\u04b8\u0001"+
+		"\u0000\u0000\u0000\u04af\u04b7\u0003a0\u0000\u04b0\u04b7\u0003Y,\u0000"+
+		"\u04b1\u04b7\u0003c1\u0000\u04b2\u04b7\u0007\u0004\u0000\u0000\u04b3\u04b7"+
+		"\u0003C!\u0000\u04b4\u04b7\u0003E\"\u0000\u04b5\u04b7\u0003I$\u0000\u04b6"+
+		"\u04af\u0001\u0000\u0000\u0000\u04b6\u04b0\u0001\u0000\u0000\u0000\u04b6"+
+		"\u04b1\u0001\u0000\u0000\u0000\u04b6\u04b2\u0001\u0000\u0000\u0000\u04b6"+
+		"\u04b3\u0001\u0000\u0000\u0000\u04b6\u04b4\u0001\u0000\u0000\u0000\u04b6"+
+		"\u04b5\u0001\u0000\u0000\u0000\u04b7\u04ba\u0001\u0000\u0000\u0000\u04b8"+
+		"\u04b6\u0001\u0000\u0000\u0000\u04b8\u04b9\u0001\u0000\u0000\u0000\u04b9"+
+		"f\u0001\u0000\u0000\u0000\u04ba\u04b8\u0001\u0000\u0000\u0000\u04bb\u04bc"+
+		"\u0005/\u0000\u0000\u04bc\u04bd\u0005/\u0000\u0000\u04bd\u04c1\u0001\u0000"+
+		"\u0000\u0000\u04be\u04c0\b\u000b\u0000\u0000\u04bf\u04be\u0001\u0000\u0000"+
+		"\u0000\u04c0\u04c3\u0001\u0000\u0000\u0000\u04c1\u04bf\u0001\u0000\u0000"+
+		"\u0000\u04c1\u04c2\u0001\u0000\u0000\u0000\u04c2\u04c5\u0001\u0000\u0000"+
+		"\u0000\u04c3\u04c1\u0001\u0000\u0000\u0000\u04c4\u04c6\u0005\r\u0000\u0000"+
+		"\u04c5\u04c4\u0001\u0000\u0000\u0000\u04c5\u04c6\u0001\u0000\u0000\u0000"+
+		"\u04c6\u04c8\u0001\u0000\u0000\u0000\u04c7\u04c9\u0007\f\u0000\u0000\u04c8"+
+		"\u04c7\u0001\u0000\u0000\u0000\u04c9\u04d6\u0001\u0000\u0000\u0000\u04ca"+
+		"\u04cb\u0005/\u0000\u0000\u04cb\u04cc\u0005*\u0000\u0000\u04cc\u04d0\u0001"+
+		"\u0000\u0000\u0000\u04cd\u04cf\t\u0000\u0000\u0000\u04ce\u04cd\u0001\u0000"+
+		"\u0000\u0000\u04cf\u04d2\u0001\u0000\u0000\u0000\u04d0\u04d1\u0001\u0000"+
+		"\u0000\u0000\u04d0\u04ce\u0001\u0000\u0000\u0000\u04d1\u04d3\u0001\u0000"+
+		"\u0000\u0000\u04d2\u04d0\u0001\u0000\u0000\u0000\u04d3\u04d4\u0005*\u0000"+
+		"\u0000\u04d4\u04d6\u0005/\u0000\u0000\u04d5\u04bb\u0001\u0000\u0000\u0000"+
+		"\u04d5\u04ca\u0001\u0000\u0000\u0000\u04d6\u04d7\u0001\u0000\u0000\u0000"+
+		"\u04d7\u04d8\u00063\u0000\u0000\u04d8h\u0001\u0000\u0000\u0000\u04d9\u04db"+
+		"\u0007\r\u0000\u0000\u04da\u04d9\u0001\u0000\u0000\u0000\u04db\u04dc\u0001"+
+		"\u0000\u0000\u0000\u04dc\u04da\u0001\u0000\u0000\u0000\u04dc\u04dd\u0001"+
+		"\u0000\u0000\u0000\u04dd\u04de\u0001\u0000\u0000\u0000\u04de\u04df\u0006"+
+		"4\u0000\u0000\u04dfj\u0001\u0000\u0000\u0000\u04e0\u04e1\t\u0000\u0000"+
+		"\u0000\u04e1l\u0001\u0000\u0000\u0000\u0016\u0000\u03ec\u0420\u0422\u042b"+
+		"\u042d\u043b\u048f\u0492\u0498\u049c\u04a3\u04ab\u04ad\u04b6\u04b8\u04c1"+
+		"\u04c5\u04c8\u04d0\u04d5\u04dc\u0001\u0006\u0000\u0000";
 	public static final ATN _ATN =
 		new ATNDeserializer().deserialize(_serializedATN.toCharArray());
 	static {
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLListener.java b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLListener.java
index 5e218db5..ed55e59d 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLListener.java
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLListener.java
@@ -1,4 +1,4 @@
-// Generated from /Users/nivanov/incubator-nlpcraft/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4 by ANTLR 4.10.1
+// Generated from java-escape by ANTLR 4.11.1
 package org.apache.nlpcraft.internal.intent.compiler.antlr4;
 import org.antlr.v4.runtime.tree.ParseTreeListener;
 
diff --git a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLParser.java b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLParser.java
index b311f6c9..8eda0185 100644
--- a/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLParser.java
+++ b/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDLParser.java
@@ -1,4 +1,4 @@
-// Generated from /Users/nivanov/incubator-nlpcraft/nlpcraft/src/main/scala/org/apache/nlpcraft/internal/intent/compiler/antlr4/NCIDL.g4 by ANTLR 4.10.1
+// Generated from java-escape by ANTLR 4.11.1
 package org.apache.nlpcraft.internal.intent.compiler.antlr4;
 import org.antlr.v4.runtime.atn.*;
 import org.antlr.v4.runtime.dfa.DFA;
@@ -9,9 +9,9 @@ import java.util.List;
 import java.util.Iterator;
 import java.util.ArrayList;
 
-@SuppressWarnings({"all", "warnings", "unchecked", "unused", "cast"})
+@SuppressWarnings({"all", "warnings", "unchecked", "unused", "cast", "CheckReturnValue"})
 public class NCIDLParser extends Parser {
-	static { RuntimeMetaData.checkVersion("4.10.1", RuntimeMetaData.VERSION); }
+	static { RuntimeMetaData.checkVersion("4.11.1", RuntimeMetaData.VERSION); }
 
 	protected static final DFA[] _decisionToDFA;
 	protected static final PredictionContextCache _sharedContextCache =
@@ -101,7 +101,7 @@ public class NCIDLParser extends Parser {
 	}
 
 	@Override
-	public String getGrammarFileName() { return "NCIDL.g4"; }
+	public String getGrammarFileName() { return "java-escape"; }
 
 	@Override
 	public String[] getRuleNames() { return ruleNames; }
@@ -117,6 +117,7 @@ public class NCIDLParser extends Parser {
 		_interp = new ParserATNSimulator(this,_ATN,_decisionToDFA,_sharedContextCache);
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class IdlContext extends ParserRuleContext {
 		public IdlDeclsContext idlDecls() {
 			return getRuleContext(IdlDeclsContext.class,0);
@@ -159,6 +160,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class IdlDeclsContext extends ParserRuleContext {
 		public IdlDeclContext idlDecl() {
 			return getRuleContext(IdlDeclContext.class,0);
@@ -235,6 +237,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class IdlDeclContext extends ParserRuleContext {
 		public IntentContext intent() {
 			return getRuleContext(IntentContext.class,0);
@@ -302,6 +305,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class ImprtContext extends ParserRuleContext {
 		public TerminalNode IMPORT() { return getToken(NCIDLParser.IMPORT, 0); }
 		public TerminalNode LPAR() { return getToken(NCIDLParser.LPAR, 0); }
@@ -350,6 +354,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class FragContext extends ParserRuleContext {
 		public FragIdContext fragId() {
 			return getRuleContext(FragIdContext.class,0);
@@ -394,6 +399,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class FragIdContext extends ParserRuleContext {
 		public TerminalNode FRAG() { return getToken(NCIDLParser.FRAG, 0); }
 		public TerminalNode ASSIGN() { return getToken(NCIDLParser.ASSIGN, 0); }
@@ -439,6 +445,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class FragRefContext extends ParserRuleContext {
 		public TerminalNode FRAG() { return getToken(NCIDLParser.FRAG, 0); }
 		public TerminalNode LPAR() { return getToken(NCIDLParser.LPAR, 0); }
@@ -501,6 +508,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class FragMetaContext extends ParserRuleContext {
 		public TerminalNode COMMA() { return getToken(NCIDLParser.COMMA, 0); }
 		public JsonObjContext jsonObj() {
@@ -543,6 +551,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class IntentContext extends ParserRuleContext {
 		public IntentIdContext intentId() {
 			return getRuleContext(IntentIdContext.class,0);
@@ -627,6 +636,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class IntentIdContext extends ParserRuleContext {
 		public TerminalNode INTENT() { return getToken(NCIDLParser.INTENT, 0); }
 		public TerminalNode ASSIGN() { return getToken(NCIDLParser.ASSIGN, 0); }
@@ -672,6 +682,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class FlowDeclContext extends ParserRuleContext {
 		public TerminalNode FLOW() { return getToken(NCIDLParser.FLOW, 0); }
 		public TerminalNode ASSIGN() { return getToken(NCIDLParser.ASSIGN, 0); }
@@ -717,6 +728,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class MetaDeclContext extends ParserRuleContext {
 		public TerminalNode META() { return getToken(NCIDLParser.META, 0); }
 		public TerminalNode ASSIGN() { return getToken(NCIDLParser.ASSIGN, 0); }
@@ -762,6 +774,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class OptDeclContext extends ParserRuleContext {
 		public TerminalNode OPTIONS() { return getToken(NCIDLParser.OPTIONS, 0); }
 		public TerminalNode ASSIGN() { return getToken(NCIDLParser.ASSIGN, 0); }
@@ -807,6 +820,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class JsonObjContext extends ParserRuleContext {
 		public TerminalNode LBRACE() { return getToken(NCIDLParser.LBRACE, 0); }
 		public List<JsonPairContext> jsonPair() {
@@ -891,6 +905,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class JsonPairContext extends ParserRuleContext {
 		public QstringContext qstring() {
 			return getRuleContext(QstringContext.class,0);
@@ -938,6 +953,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class JsonValContext extends ParserRuleContext {
 		public QstringContext qstring() {
 			return getRuleContext(QstringContext.class,0);
@@ -1065,6 +1081,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class JsonArrContext extends ParserRuleContext {
 		public TerminalNode LBR() { return getToken(NCIDLParser.LBR, 0); }
 		public List<JsonValContext> jsonVal() {
@@ -1149,6 +1166,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class TermDeclsContext extends ParserRuleContext {
 		public TermDeclContext termDecl() {
 			return getRuleContext(TermDeclContext.class,0);
@@ -1225,6 +1243,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class TermDeclContext extends ParserRuleContext {
 		public TermContext term() {
 			return getRuleContext(TermContext.class,0);
@@ -1282,6 +1301,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class TermEqContext extends ParserRuleContext {
 		public TerminalNode ASSIGN() { return getToken(NCIDLParser.ASSIGN, 0); }
 		public TerminalNode TILDA() { return getToken(NCIDLParser.TILDA, 0); }
@@ -1329,6 +1349,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class TermContext extends ParserRuleContext {
 		public TerminalNode TERM() { return getToken(NCIDLParser.TERM, 0); }
 		public TermEqContext termEq() {
@@ -1422,6 +1443,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class MtdRefContext extends ParserRuleContext {
 		public TerminalNode POUND() { return getToken(NCIDLParser.POUND, 0); }
 		public IdContext id() {
@@ -1454,7 +1476,7 @@ public class NCIDLParser extends Parser {
 			setState(221);
 			_errHandler.sync(this);
 			_la = _input.LA(1);
-			if ((((_la) & ~0x3f) == 0 && ((1L << _la) & ((1L << FUN_NAME) | (1L << IMPORT) | (1L << INTENT) | (1L << OPTIONS) | (1L << FLOW) | (1L << META) | (1L << TERM) | (1L << FRAG) | (1L << ID))) != 0)) {
+			if (((_la) & ~0x3f) == 0 && ((1L << _la) & 562949953421822L) != 0) {
 				{
 				setState(220);
 				javaFqn(0);
@@ -1478,6 +1500,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class JavaFqnContext extends ParserRuleContext {
 		public JavaClassContext javaClass() {
 			return getRuleContext(JavaClassContext.class,0);
@@ -1557,6 +1580,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class JavaClassContext extends ParserRuleContext {
 		public IdContext id() {
 			return getRuleContext(IdContext.class,0);
@@ -1661,6 +1685,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class TermIdContext extends ParserRuleContext {
 		public TerminalNode LPAR() { return getToken(NCIDLParser.LPAR, 0); }
 		public IdContext id() {
@@ -1706,6 +1731,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class ExprContext extends ParserRuleContext {
 		public ExprContext(ParserRuleContext parent, int invokingState) {
 			super(parent, invokingState);
@@ -1717,6 +1743,7 @@ public class NCIDLParser extends Parser {
 			super.copyFrom(ctx);
 		}
 	}
+	@SuppressWarnings("CheckReturnValue")
 	public static class ParExprContext extends ExprContext {
 		public TerminalNode LPAR() { return getToken(NCIDLParser.LPAR, 0); }
 		public ExprContext expr() {
@@ -1733,6 +1760,7 @@ public class NCIDLParser extends Parser {
 			if ( listener instanceof NCIDLListener ) ((NCIDLListener)listener).exitParExpr(this);
 		}
 	}
+	@SuppressWarnings("CheckReturnValue")
 	public static class UnaryExprContext extends ExprContext {
 		public Token op;
 		public ExprContext expr() {
@@ -1750,6 +1778,7 @@ public class NCIDLParser extends Parser {
 			if ( listener instanceof NCIDLListener ) ((NCIDLListener)listener).exitUnaryExpr(this);
 		}
 	}
+	@SuppressWarnings("CheckReturnValue")
 	public static class CompExprContext extends ExprContext {
 		public Token op;
 		public List<ExprContext> expr() {
@@ -1772,6 +1801,7 @@ public class NCIDLParser extends Parser {
 			if ( listener instanceof NCIDLListener ) ((NCIDLListener)listener).exitCompExpr(this);
 		}
 	}
+	@SuppressWarnings("CheckReturnValue")
 	public static class PlusMinusExprContext extends ExprContext {
 		public Token op;
 		public List<ExprContext> expr() {
@@ -1792,6 +1822,7 @@ public class NCIDLParser extends Parser {
 			if ( listener instanceof NCIDLListener ) ((NCIDLListener)listener).exitPlusMinusExpr(this);
 		}
 	}
+	@SuppressWarnings("CheckReturnValue")
 	public static class AtomExprContext extends ExprContext {
 		public AtomContext atom() {
 			return getRuleContext(AtomContext.class,0);
@@ -1806,6 +1837,7 @@ public class NCIDLParser extends Parser {
 			if ( listener instanceof NCIDLListener ) ((NCIDLListener)listener).exitAtomExpr(this);
 		}
 	}
+	@SuppressWarnings("CheckReturnValue")
 	public static class VarRefContext extends ExprContext {
 		public TerminalNode AT() { return getToken(NCIDLParser.AT, 0); }
 		public IdContext id() {
@@ -1821,6 +1853,7 @@ public class NCIDLParser extends Parser {
 			if ( listener instanceof NCIDLListener ) ((NCIDLListener)listener).exitVarRef(this);
 		}
 	}
+	@SuppressWarnings("CheckReturnValue")
 	public static class MultDivModExprContext extends ExprContext {
 		public Token op;
 		public List<ExprContext> expr() {
@@ -1842,6 +1875,7 @@ public class NCIDLParser extends Parser {
 			if ( listener instanceof NCIDLListener ) ((NCIDLListener)listener).exitMultDivModExpr(this);
 		}
 	}
+	@SuppressWarnings("CheckReturnValue")
 	public static class AndOrExprContext extends ExprContext {
 		public Token op;
 		public List<ExprContext> expr() {
@@ -1862,6 +1896,7 @@ public class NCIDLParser extends Parser {
 			if ( listener instanceof NCIDLListener ) ((NCIDLListener)listener).exitAndOrExpr(this);
 		}
 	}
+	@SuppressWarnings("CheckReturnValue")
 	public static class CallExprContext extends ExprContext {
 		public TerminalNode LPAR() { return getToken(NCIDLParser.LPAR, 0); }
 		public TerminalNode RPAR() { return getToken(NCIDLParser.RPAR, 0); }
@@ -1880,6 +1915,7 @@ public class NCIDLParser extends Parser {
 			if ( listener instanceof NCIDLListener ) ((NCIDLListener)listener).exitCallExpr(this);
 		}
 	}
+	@SuppressWarnings("CheckReturnValue")
 	public static class EqNeqExprContext extends ExprContext {
 		public Token op;
 		public List<ExprContext> expr() {
@@ -1983,7 +2019,7 @@ public class NCIDLParser extends Parser {
 				setState(262);
 				_errHandler.sync(this);
 				_la = _input.LA(1);
-				if ((((_la) & ~0x3f) == 0 && ((1L << _la) & ((1L << FUN_NAME) | (1L << SQSTRING) | (1L << DQSTRING) | (1L << BOOL) | (1L << NULL) | (1L << NOT) | (1L << LPAR) | (1L << POUND) | (1L << MINUS) | (1L << AT) | (1L << INT))) != 0)) {
+				if (((_la) & ~0x3f) == 0 && ((1L << _la) & 87999597518338L) != 0) {
 					{
 					setState(261);
 					paramList(0);
@@ -2044,7 +2080,7 @@ public class NCIDLParser extends Parser {
 						setState(271);
 						((MultDivModExprContext)_localctx).op = _input.LT(1);
 						_la = _input.LA(1);
-						if ( !((((_la) & ~0x3f) == 0 && ((1L << _la) & ((1L << MULT) | (1L << DIV) | (1L << MOD))) != 0)) ) {
+						if ( !(((_la) & ~0x3f) == 0 && ((1L << _la) & 15393162788864L) != 0) ) {
 							((MultDivModExprContext)_localctx).op = (Token)_errHandler.recoverInline(this);
 						}
 						else {
@@ -2086,7 +2122,7 @@ public class NCIDLParser extends Parser {
 						setState(277);
 						((CompExprContext)_localctx).op = _input.LT(1);
 						_la = _input.LA(1);
-						if ( !((((_la) & ~0x3f) == 0 && ((1L << _la) & ((1L << GTEQ) | (1L << LTEQ) | (1L << GT) | (1L << LT))) != 0)) ) {
+						if ( !(((_la) & ~0x3f) == 0 && ((1L << _la) & 491520L) != 0) ) {
 							((CompExprContext)_localctx).op = (Token)_errHandler.recoverInline(this);
 						}
 						else {
@@ -2160,6 +2196,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class VarsContext extends ParserRuleContext {
 		public VarDeclContext varDecl() {
 			return getRuleContext(VarDeclContext.class,0);
@@ -2236,6 +2273,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class VarDeclContext extends ParserRuleContext {
 		public TerminalNode AT() { return getToken(NCIDLParser.AT, 0); }
 		public IdContext id() {
@@ -2286,6 +2324,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class ParamListContext extends ParserRuleContext {
 		public ExprContext expr() {
 			return getRuleContext(ExprContext.class,0);
@@ -2365,6 +2404,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class AtomContext extends ParserRuleContext {
 		public TerminalNode NULL() { return getToken(NCIDLParser.NULL, 0); }
 		public TerminalNode INT() { return getToken(NCIDLParser.INT, 0); }
@@ -2459,6 +2499,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class QstringContext extends ParserRuleContext {
 		public TerminalNode SQSTRING() { return getToken(NCIDLParser.SQSTRING, 0); }
 		public TerminalNode DQSTRING() { return getToken(NCIDLParser.DQSTRING, 0); }
@@ -2506,6 +2547,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class MinMaxContext extends ParserRuleContext {
 		public MinMaxShortcutContext minMaxShortcut() {
 			return getRuleContext(MinMaxShortcutContext.class,0);
@@ -2565,6 +2607,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class MinMaxShortcutContext extends ParserRuleContext {
 		public TerminalNode PLUS() { return getToken(NCIDLParser.PLUS, 0); }
 		public TerminalNode QUESTION() { return getToken(NCIDLParser.QUESTION, 0); }
@@ -2592,7 +2635,7 @@ public class NCIDLParser extends Parser {
 			{
 			setState(334);
 			_la = _input.LA(1);
-			if ( !((((_la) & ~0x3f) == 0 && ((1L << _la) & ((1L << PLUS) | (1L << QUESTION) | (1L << MULT))) != 0)) ) {
+			if ( !(((_la) & ~0x3f) == 0 && ((1L << _la) & 3848290697216L) != 0) ) {
 			_errHandler.recoverInline(this);
 			}
 			else {
@@ -2613,6 +2656,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class MinMaxRangeContext extends ParserRuleContext {
 		public TerminalNode LBR() { return getToken(NCIDLParser.LBR, 0); }
 		public List<TerminalNode> INT() { return getTokens(NCIDLParser.INT); }
@@ -2664,6 +2708,7 @@ public class NCIDLParser extends Parser {
 		return _localctx;
 	}
 
+	@SuppressWarnings("CheckReturnValue")
 	public static class IdContext extends ParserRuleContext {
 		public TerminalNode ID() { return getToken(NCIDLParser.ID, 0); }
 		public TerminalNode FUN_NAME() { return getToken(NCIDLParser.FUN_NAME, 0); }